Package org.elasticsearch.snapshots
Class AbstractSnapshotIntegTestCase
java.lang.Object
org.junit.Assert
org.apache.lucene.tests.util.LuceneTestCase
org.elasticsearch.test.ESTestCase
org.elasticsearch.test.ESIntegTestCase
org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
-
Nested Class Summary
Nested classes/interfaces inherited from class org.elasticsearch.test.ESIntegTestCase
ESIntegTestCase.AssertActionNamePlugin, ESIntegTestCase.ClusterScope, ESIntegTestCase.NumShards, ESIntegTestCase.Scope, ESIntegTestCase.SuiteScopeTestCase, ESIntegTestCase.TestSeedPluginNested classes/interfaces inherited from class org.elasticsearch.test.ESTestCase
ESTestCase.DeprecationWarning, ESTestCase.GeohashGenerator, ESTestCase.TestAnalysis, ESTestCase.WithoutSecurityManagerNested classes/interfaces inherited from class org.apache.lucene.tests.util.LuceneTestCase
org.apache.lucene.tests.util.LuceneTestCase.AwaitsFix, org.apache.lucene.tests.util.LuceneTestCase.BadApple, org.apache.lucene.tests.util.LuceneTestCase.Monster, org.apache.lucene.tests.util.LuceneTestCase.Nightly, org.apache.lucene.tests.util.LuceneTestCase.SuppressCodecs, org.apache.lucene.tests.util.LuceneTestCase.SuppressFileSystems, org.apache.lucene.tests.util.LuceneTestCase.SuppressFsync, org.apache.lucene.tests.util.LuceneTestCase.SuppressReproduceLine, org.apache.lucene.tests.util.LuceneTestCase.SuppressSysoutChecks, org.apache.lucene.tests.util.LuceneTestCase.SuppressTempFileChecks, org.apache.lucene.tests.util.LuceneTestCase.ThrowingConsumer<T>, org.apache.lucene.tests.util.LuceneTestCase.ThrowingRunnable, org.apache.lucene.tests.util.LuceneTestCase.Weekly -
Field Summary
FieldsModifier and TypeFieldDescriptionprotected static final intprotected static final Settingsstatic final Stringstatic final Stringstatic final Settingsprotected static final SettingsFields inherited from class org.elasticsearch.test.ESIntegTestCase
DEFAULT_MAX_NUM_SHARDS, DEFAULT_MIN_NUM_SHARDS, INDEX_TEST_SEED_SETTING, SUITE_CLUSTER_NODE_PREFIX, TEST_CLUSTER_NODE_PREFIX, TESTS_CLUSTER, TESTS_CLUSTER_NAME, TESTS_ENABLE_MOCK_MODULESFields inherited from class org.elasticsearch.test.ESTestCase
checkIndexFailures, DEFAULT_TEST_WORKER_ID, failureAndSuccessEvents, FIPS_SYSPROP, JAVA_TIMEZONE_IDS, JAVA_ZONE_IDS, logger, MIN_PRIVATE_PORT, SAFE_AWAIT_TIMEOUT, TEST_REQUEST_TIMEOUT, TEST_WORKER_SYS_PROPERTY, TEST_WORKER_VM_ID, UNSIGNED_LONG_MAXFields inherited from class org.apache.lucene.tests.util.LuceneTestCase
assertsAreEnabled, classRules, DEFAULT_LINE_DOCS_FILE, INFOSTREAM, JENKINS_LARGE_LINE_DOCS_FILE, LEAVE_TEMPORARY, MAYBE_CACHE_POLICY, RANDOM_MULTIPLIER, ruleChain, suiteFailureMarker, SYSPROP_AWAITSFIX, SYSPROP_BADAPPLES, SYSPROP_FAILFAST, SYSPROP_MAXFAILURES, SYSPROP_MONSTER, SYSPROP_NIGHTLY, SYSPROP_WEEKLY, TEST_ASSERTS_ENABLED, TEST_AWAITSFIX, TEST_BADAPPLES, TEST_CODEC, TEST_DIRECTORY, TEST_DOCVALUESFORMAT, TEST_LINE_DOCS_FILE, TEST_MONSTER, TEST_NIGHTLY, TEST_POSTINGSFORMAT, TEST_THROTTLING, TEST_WEEKLY, VERBOSE -
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionprotected voidAdds a snapshot in stateSnapshotState.FAILEDto the given repository.voidprotected voidassertDocCount(String index, long count) static voidassertFileCount(Path dir, int expectedCount) voidstatic voidassertSnapshotListSorted(List<SnapshotInfo> snapshotInfos, SnapshotSortKey sort, SortOrder sortOrder) static SnapshotInfoassertSuccessful(org.apache.logging.log4j.Logger logger, ActionFuture<CreateSnapshotResponse> future) protected SnapshotInfoprotected voidprotected voidawaitNDeletionsInProgress(int count) protected voidprotected voidawaitNoMoreRunningOperations(String viaNode) protected voidawaitNumberOfSnapshotsInProgress(int count) static voidawaitNumberOfSnapshotsInProgress(org.apache.logging.log4j.Logger logger, int count) static voidblockAllDataNodes(String repository) static voidblockAndFailDataNode(String repository, String nodeName) static voidblockDataNode(String repository, String nodeName) static voidblockMasterFromDeletingIndexNFile(String repositoryName) static voidblockMasterFromFinalizingSnapshotOnIndexFile(String repositoryName) static voidblockMasterFromFinalizingSnapshotOnSnapFile(String repositoryName) static voidblockMasterOnAnyDataFile(String repositoryName) static voidblockMasterOnShardLevelSnapshotFile(String repositoryName, String indexId) static voidblockMasterOnWriteIndexFile(String repositoryName) static voidblockNodeOnAnyFiles(String repository, String nodeName) static StringblockNodeWithIndex(String repositoryName, String indexName) protected SnapshotInfocreateFullSnapshot(String repoName, String snapshotName) static SnapshotInfocreateFullSnapshot(org.apache.logging.log4j.Logger logger, String repoName, String snapshotName) protected voidcreateIndexWithContent(String indexName) protected voidcreateIndexWithContent(String indexName, Settings indexSettings) protected voidcreateIndexWithRandomDocs(String indexName, int docCount) createNSnapshots(String repoName, int count) createNSnapshots(org.apache.logging.log4j.Logger logger, String repoName, int count) protected voidcreateRepository(String repoName, String type) protected voidcreateRepository(String repoName, String type, Path location) protected voidcreateRepository(String repoName, String type, Settings.Builder settings) protected voidcreateRepository(String repoName, String type, Settings.Builder settings, boolean verify) static voidcreateRepository(org.apache.logging.log4j.Logger logger, String repoName, String type) static voidcreateRepository(org.apache.logging.log4j.Logger logger, String repoName, String type, Settings.Builder settings, boolean verify) protected voidcreateRepositoryNoVerify(String repoName, String type) protected SnapshotInfocreateSnapshot(String repositoryName, String snapshot, List<String> indices) protected SnapshotInfocreateSnapshot(String repositoryName, String snapshot, List<String> indices, List<String> featureStates) protected voiddeleteRepository(String repoName) protected voiddisableRepoConsistencyCheck(String reason) static voidfailReadsAllDataNodes(String repository) static voidforEachFileRecursively(Path path, CheckedBiConsumer<Path, BasicFileAttributes, IOException> forEach) protected longgetCountForIndex(String indexName) static longgetFailureCount(String repository) protected RepositoryDatagetRepositoryData(String repository) protected RepositoryDatagetRepositoryData(String repoName, IndexVersion version) static RepositoryDatagetRepositoryData(Repository repository) getRepositoryMetadata(String repo) static <T extends Repository>
TgetRepositoryOnMaster(String repositoryName) protected static <T extends Repository>
TgetRepositoryOnNode(String repositoryName, String nodeName) protected SnapshotInfogetSnapshot(String repository, String snapshot) protected voidindexRandomDocs(String index, int numdocs) protected static Settings.BuilderindexSettingsNoReplicas(int shards) protected StringinitWithSnapshotVersion(String repoName, Path repoPath, IndexVersion version) Workaround to simulate BwC situation: taking a snapshot without indices here so that we don't create any new version shard generations (the existence of which would short-circuit checks for the repo containing old version snapshots)static String[]protected voidmaybeInitWithOldSnapshotVersion(String repoName, Path repoPath) Randomly write an empty snapshot of an older version to an empty repository to simulate an older repository metadata format.protected Collection<Class<? extends Plugin>> Returns a collection of plugins that should be loaded on each node.protected SettingsnodeSettings(int nodeOrdinal, Settings otherSettings) This method is used to obtain settings for theNth node in the cluster.static Settings.BuilderRandomly either generates some random snapshot user metadata or returnsnull.protected static ThreadPoolStats.Statsprotected static Stringprotected ActionFuture<AcknowledgedResponse> startDeleteSnapshot(String repoName, String snapshotName) protected ActionFuture<AcknowledgedResponse> startDeleteSnapshots(String repoName, List<String> snapshotNames, String viaNode) protected ActionFuture<CreateSnapshotResponse> startFullSnapshot(String repoName, String snapshotName) protected ActionFuture<CreateSnapshotResponse> startFullSnapshot(String repoName, String snapshotName, boolean partial) static ActionFuture<CreateSnapshotResponse> startFullSnapshot(org.apache.logging.log4j.Logger logger, String repoName, String snapshotName, boolean partial) protected ActionFuture<CreateSnapshotResponse> startFullSnapshotBlockedOnDataNode(String snapshotName, String repoName, String dataNode) protected voidstatic voidunblockAllDataNodes(String repository) voidunblockNode(String repository, String node) protected static voidupdateClusterState(Function<ClusterState, ClusterState> updater) voidvoidwaitForBlock(String node, String repository) static voidwaitForBlockOnAnyDataNode(String repository) Methods inherited from class org.elasticsearch.test.ESIntegTestCase
addMockFSIndexStore, addMockHttpTransport, addMockInternalEngine, addMockTransportService, admin, afterClass, allowNodes, assertAllShardsOnNodes, assertResultsAndLogOnFailure, assertSortedSegments, autoManageVotingExclusions, awaitClusterState, awaitClusterState, awaitClusterState, beforeClass, beforeIndexDeletion, beforeInternal, buildTestCluster, cleanUpCluster, clearScroll, client, client, clients, cluster, clusterAdmin, clusterService, createIndex, createIndex, createIndex, createRestClient, createRestClient, createRestClient, createRestClient, dataNodeClient, disableAllocation, disableIndexBlock, doEnsureClusterStateConsistency, enableAllocation, enableBigArraysReleasedCheck, enableConcurrentSearch, enableIndexBlock, enableWarningsCheck, ensureClusterSizeConsistency, ensureClusterStateCanBeReadByNodeTool, ensureClusterStateConsistency, ensureFullyConnectedCluster, ensureGreen, ensureGreen, ensureRed, ensureSearchable, ensureStableCluster, ensureStableCluster, ensureStableCluster, ensureStableCluster, ensureYellow, ensureYellowAndNoInitializingShards, excludeTemplates, findTasks, findTasks, flush, flushAndRefresh, forbidPrivateIndexSettings, forceMerge, forceSingleDataPath, fullyAllocateCircuitBreakerOnNode, getClientWrapper, getClusterPendingTasks, getClusterPendingTasks, getDataStreamBackingIndexNames, getMockPlugins, getNodeId, getNumShards, getRestClient, index, index, index, index, indexDoc, indexExists, indexExists, indexRandom, indexRandom, indexRandom, indexRandom, indexRandom, indexRandom, indexSettings, indicesAdmin, inFipsJvm, internalCluster, isInternalCluster, isolateMasterDisruption, logClusterState, maximumNumberOfReplicas, maximumNumberOfShards, minimumNumberOfReplicas, minimumNumberOfShards, nodeConfigPath, numberOfReplicas, numberOfShards, prepareCreate, prepareCreate, prepareCreate, prepareCreate, prepareIndex, prepareSearch, randomRepoPath, randomRepoPath, refresh, refreshClusterInfo, resolveCustomDataPath, resolveIndex, restartNodesOnBrokenClusterState, routingKeyForShard, safeExecute, setClusterReadOnly, setDisruptionScheme, setRandomIndexSettings, setReplicaCount, setupSuiteScopeCluster, setupTestCluster, updateClusterSettings, updateIndexSettings, waitAndGetHealthNode, waitForDocs, waitForRelocation, waitForRelocation, waitNoPendingTasksOnAll, xContentRegistryMethods inherited from class org.elasticsearch.test.ESTestCase
after, afterIfFailed, afterIfSuccessful, allBreakersMemoryReleased, asInstanceOf, assertArrayEquals, assertBusy, assertBusy, assertCriticalWarnings, assertEquals, assertLeakDetected, assertSettingDeprecationsAndWarnings, assertThat, assertThat, assertWarnings, assertWarnings, before, between, buildEnvSettings, buildNewFakeTransportAddress, captureLoggingLevel, checkStaticState, compatibleMediaType, copyInstance, copyNamedWriteable, copyNamedWriteable, copyWriteable, copyWriteable, createDefaultIndexAnalyzers, createParser, createParser, createParser, createParser, createParser, createParser, createParserWithCompatibilityFor, createTestAnalysis, createTestAnalysis, createTestAnalysis, createThreadPool, ensureAllContextsReleased, ensureAllSearchContextsReleased, ensureCheckIndexPassed, ensureNoWarnings, ensureSupportedLocale, expectThrows, expectThrows, fail, fail, filteredWarnings, flushThreadPoolExecutor, frequently, generateRandomStringArray, generateRandomStringArray, getDataPath, getPortRange, getResourceDataPath, getSuiteFailureMarker, getTestTransportPlugin, getTestTransportType, getWorkerBasePort, indexSettings, indexSettings, initTestSeed, isTurkishLocale, iterations, maybeRestoreClassSecurityManager, maybeSet, maybeStashClassSecurityManager, mockScript, newEnvironment, newEnvironment, newLimitedBreaker, newNodeEnvironment, newNodeEnvironment, parserConfig, randomAlphanumericOfLength, randomAlphaOfLength, randomAlphaOfLengthBetween, randomAlphaOfLengthOrNull, randomArray, randomArray, randomBigInteger, randomBoolean, randomByte, randomByteArrayOfLength, randomByteBetween, randomBytesBetween, randomByteSizeValue, randomBytesReference, randomCompatibleMediaType, randomDateFormatterPattern, randomDouble, randomDoubleBetween, randomDoubles, randomDoubles, randomExecutor, randomFloat, randomFloatBetween, randomFloatOrNull, randomFrom, randomFrom, randomFrom, randomFrom, randomFrom, randomFrom, randomGeohash, randomIdentifier, randomInstantBetween, randomInt, randomInt, randomIntBetween, randomIntOrNull, randomInts, randomInts, randomIp, randomList, randomList, randomLong, randomLongBetween, randomLongOrNull, randomLongs, randomLongs, randomMap, randomMillisUpToYear9999, randomNegativeInt, randomNonEmptySubsetOf, randomNonNegativeByte, randomNonNegativeInt, randomNonNegativeIntOrNull, randomNonNegativeLong, randomNonNegativeLongOrNull, randomOptionalBoolean, randomPositiveTimeValue, randomRealisticUnicodeOfCodepointLength, randomRealisticUnicodeOfCodepointLengthBetween, randomRealisticUnicodeOfLength, randomRealisticUnicodeOfLengthBetween, randomSecretKey, randomSecureStringOfLength, randomSet, randomShort, randomSubsetOf, randomSubsetOf, randomSubsetOf, randomTimeValue, randomTimeValue, randomTimeValue, randomTimeZone, randomUnicodeOfCodepointLength, randomUnicodeOfCodepointLengthBetween, randomUnicodeOfLength, randomUnicodeOfLengthBetween, randomUnique, randomUnsignedLongBetween, randomUUID, randomValueOtherThan, randomValueOtherThanMany, randomVendorType, randomZone, removeHeaderWarningAppender, resetCheckIndexStatus, resetPortCounter, restoreContentType, restoreFileSystem, restoreLoggingLevel, runInParallel, safeAcquire, safeAcquire, safeAwait, safeAwait, safeAwait, safeAwait, safeAwait, safeAwaitAndUnwrapFailure, safeAwaitFailure, safeAwaitFailure, safeAwaitFailure, safeAwaitFailure, safeExecute, safeGet, safeGet, safeSleep, safeSleep, scaledRandomIntBetween, secureRandom, secureRandom, secureRandomFips, secureRandomFips, secureRandomNonFips, secureRandomNonFips, setContentType, setFileSystem, setHeaderWarningAppender, settings, shuffledList, shuffleMap, shuffleXContent, shuffleXContent, skipTestWaitingForLuceneFix, spinForAtLeastNMilliseconds, spinForAtLeastOneMillisecond, startInParallel, terminate, terminate, tmpPaths, toShuffledXContent, waitUntil, waitUntil, writableRegistryMethods inherited from class org.apache.lucene.tests.util.LuceneTestCase
addVirusChecker, assertDeletedDocsEquals, assertDocsAndPositionsEnumEquals, assertDocsEnumEquals, assertDocsSkippingEquals, assertDocValuesEquals, assertDocValuesEquals, assertDoubleUlpEquals, assertFieldInfosEquals, assertFloatUlpEquals, assertNormsEquals, assertPointsEquals, assertPositionsSkippingEquals, assertReaderEquals, assertReaderStatisticsEquals, assertStoredFieldEquals, assertStoredFieldsEquals, assertTermsEnumEquals, assertTermsEquals, assertTermsEquals, assertTermsStatisticsEquals, assertTermStatsEquals, assertTermVectorsEquals, asSet, assumeFalse, assumeNoException, assumeTrue, assumeWorkingMMapOnWindows, atLeast, atLeast, callStackContains, callStackContains, callStackContainsAnyOf, closeAfterSuite, closeAfterTest, collate, createTempDir, createTempDir, createTempFile, createTempFile, dumpArray, dumpIterator, ensureSaneIWCOnNightly, expectThrows, expectThrows, expectThrows, expectThrowsAnyOf, expectThrowsAnyOf, getDataInputStream, getJvmForkArguments, getOnlyLeafReader, getTestClass, getTestName, hasWorkingMMapOnWindows, isTestThread, localeForLanguageTag, maybeChangeLiveIndexWriterConfig, maybeWrapReader, newAlcoholicMergePolicy, newAlcoholicMergePolicy, newBytesRef, newBytesRef, newBytesRef, newBytesRef, newBytesRef, newBytesRef, newDirectory, newDirectory, newDirectory, newDirectory, newDirectory, newField, newField, newFSDirectory, newFSDirectory, newIndexWriterConfig, newIndexWriterConfig, newIndexWriterConfig, newIOContext, newIOContext, newLogMergePolicy, newLogMergePolicy, newLogMergePolicy, newLogMergePolicy, newLogMergePolicy, newMaybeVirusCheckingDirectory, newMaybeVirusCheckingFSDirectory, newMergePolicy, newMergePolicy, newMergePolicy, newMockDirectory, newMockDirectory, newMockDirectory, newMockFSDirectory, newMockFSDirectory, newSearcher, newSearcher, newSearcher, newSearcher, newSnapshotIndexWriterConfig, newStringField, newStringField, newStringField, newStringField, newTextField, newTextField, newTieredMergePolicy, newTieredMergePolicy, overrideDefaultQueryCache, overrideTestDefaultQueryCache, random, randomLocale, randomTimeZone, randomVectorFormat, rarely, rarely, replaceMaxFailureRule, resetDefaultQueryCache, restoreCPUCoreCount, restoreIndexWriterMaxDocs, runWithRestrictedPermissions, setIndexWriterMaxDocs, setUp, setupCPUCoreCount, setUpExecutorService, shutdownExecutorService, slowFileExists, tearDown, usually, usually, wrapReaderMethods inherited from class org.junit.Assert
assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertArrayEquals, assertEquals, assertEquals, assertEquals, assertEquals, assertEquals, assertEquals, assertEquals, assertEquals, assertEquals, assertEquals, assertEquals, assertEquals, assertFalse, assertFalse, assertNotEquals, assertNotEquals, assertNotEquals, assertNotEquals, assertNotEquals, assertNotEquals, assertNotEquals, assertNotEquals, assertNotNull, assertNotNull, assertNotSame, assertNotSame, assertNull, assertNull, assertSame, assertSame, assertThrows, assertThrows, assertTrue, assertTrue, fail, fail
-
Field Details
-
RANDOM_SNAPSHOT_NAME_PREFIX
- See Also:
-
OLD_VERSION_SNAPSHOT_PREFIX
- See Also:
-
LARGE_POOL_SIZE
protected static final int LARGE_POOL_SIZE- See Also:
-
LARGE_SNAPSHOT_POOL_SETTINGS
-
SMALL_SNAPSHOT_POOL_SETTINGS
-
SINGLE_SHARD_NO_REPLICA
-
-
Constructor Details
-
AbstractSnapshotIntegTestCase
public AbstractSnapshotIntegTestCase()
-
-
Method Details
-
nodeSettings
Description copied from class:ESIntegTestCaseThis method is used to obtain settings for theNth node in the cluster. Nodes in this cluster are associated with an ordinal number such that nodes can be started with specific configurations. This method might be called multiple times with the same ordinal and is expected to return the same value for each invocation. In other words subclasses must ensure this method is idempotent.- Overrides:
nodeSettingsin classESIntegTestCase
-
nodePlugins
Description copied from class:ESIntegTestCaseReturns a collection of plugins that should be loaded on each node.- Overrides:
nodePluginsin classESIntegTestCase
-
assertConsistentHistoryInLuceneIndex
- Throws:
Exception
-
verifyNoLeakedListeners
- Throws:
Exception
-
assertRepoConsistency
public void assertRepoConsistency() -
disableRepoConsistencyCheck
-
getRepositoryData
-
getRepositoryData
-
getRepositoryData
-
getFailureCount
-
assertFileCount
- Throws:
IOException
-
getAllFilesInDirectoryAndDescendants
- Throws:
IOException
-
stopNode
- Throws:
IOException
-
startDataNodeWithLargeSnapshotPool
-
waitForBlock
- Throws:
Exception
-
blockMasterFromFinalizingSnapshotOnIndexFile
-
blockMasterOnWriteIndexFile
-
blockMasterFromDeletingIndexNFile
-
blockMasterFromFinalizingSnapshotOnSnapFile
-
blockMasterOnAnyDataFile
-
blockMasterOnShardLevelSnapshotFile
-
getRepositoryOnMaster
-
getRepositoryOnNode
protected static <T extends Repository> T getRepositoryOnNode(String repositoryName, String nodeName) -
blockNodeWithIndex
-
blockNodeOnAnyFiles
-
blockDataNode
-
blockAndFailDataNode
-
blockAllDataNodes
-
unblockAllDataNodes
-
failReadsAllDataNodes
-
waitForBlockOnAnyDataNode
-
unblockNode
-
createRepository
protected void createRepository(String repoName, String type, Settings.Builder settings, boolean verify) -
createRepository
public static void createRepository(org.apache.logging.log4j.Logger logger, String repoName, String type, Settings.Builder settings, boolean verify) -
createRepository
-
createRepository
-
createRepository
-
createRepositoryNoVerify
-
createRepository
-
deleteRepository
-
randomRepositorySettings
-
indexSettingsNoReplicas
-
maybeInitWithOldSnapshotVersion
Randomly write an empty snapshot of an older version to an empty repository to simulate an older repository metadata format.- Throws:
Exception
-
initWithSnapshotVersion
protected String initWithSnapshotVersion(String repoName, Path repoPath, IndexVersion version) throws Exception Workaround to simulate BwC situation: taking a snapshot without indices here so that we don't create any new version shard generations (the existence of which would short-circuit checks for the repo containing old version snapshots)- Throws:
Exception
-
createFullSnapshot
-
createFullSnapshot
public static SnapshotInfo createFullSnapshot(org.apache.logging.log4j.Logger logger, String repoName, String snapshotName) -
createSnapshot
-
createSnapshot
-
createIndexWithRandomDocs
-
indexRandomDocs
-
getCountForIndex
-
assertDocCount
-
addBwCFailedSnapshot
protected void addBwCFailedSnapshot(String repoName, String snapshotName, Map<String, Object> metadata) throws ExceptionAdds a snapshot in stateSnapshotState.FAILEDto the given repository.- Parameters:
repoName- repository to add snapshot tosnapshotName- name for the new failed snapshotmetadata- snapshot metadata to write (as returned bySnapshotInfo.userMetadata())- Throws:
Exception
-
awaitNDeletionsInProgress
- Throws:
Exception
-
awaitNoMoreRunningOperations
- Throws:
Exception
-
awaitNoMoreRunningOperations
- Throws:
Exception
-
startFullSnapshotBlockedOnDataNode
protected ActionFuture<CreateSnapshotResponse> startFullSnapshotBlockedOnDataNode(String snapshotName, String repoName, String dataNode) throws Exception - Throws:
Exception
-
startFullSnapshot
protected ActionFuture<CreateSnapshotResponse> startFullSnapshot(String repoName, String snapshotName) -
startFullSnapshot
protected ActionFuture<CreateSnapshotResponse> startFullSnapshot(String repoName, String snapshotName, boolean partial) -
startFullSnapshot
public static ActionFuture<CreateSnapshotResponse> startFullSnapshot(org.apache.logging.log4j.Logger logger, String repoName, String snapshotName, boolean partial) -
awaitNumberOfSnapshotsInProgress
- Throws:
Exception
-
awaitNumberOfSnapshotsInProgress
public static void awaitNumberOfSnapshotsInProgress(org.apache.logging.log4j.Logger logger, int count) throws Exception - Throws:
Exception
-
assertSuccessful
protected SnapshotInfo assertSuccessful(ActionFuture<CreateSnapshotResponse> future) throws Exception - Throws:
Exception
-
assertSuccessful
public static SnapshotInfo assertSuccessful(org.apache.logging.log4j.Logger logger, ActionFuture<CreateSnapshotResponse> future) throws Exception - Throws:
Exception
-
createIndexWithContent
-
createIndexWithContent
-
startDeleteSnapshot
protected ActionFuture<AcknowledgedResponse> startDeleteSnapshot(String repoName, String snapshotName) -
startDeleteSnapshots
protected ActionFuture<AcknowledgedResponse> startDeleteSnapshots(String repoName, List<String> snapshotNames, String viaNode) -
updateClusterState
protected static void updateClusterState(Function<ClusterState, ClusterState> updater) throws Exception- Throws:
Exception
-
getSnapshot
-
snapshotThreadPoolStats
-
awaitMasterFinishRepoOperations
- Throws:
Exception
-
createNSnapshots
- Throws:
Exception
-
createNSnapshots
public static List<String> createNSnapshots(org.apache.logging.log4j.Logger logger, String repoName, int count) throws Exception - Throws:
Exception
-
forEachFileRecursively
public static void forEachFileRecursively(Path path, CheckedBiConsumer<Path, BasicFileAttributes, throws IOExceptionIOException> forEach) - Throws:
IOException
-
assertSnapshotListSorted
public static void assertSnapshotListSorted(List<SnapshotInfo> snapshotInfos, @Nullable SnapshotSortKey sort, SortOrder sortOrder) -
randomUserMetadata
Randomly either generates some random snapshot user metadata or returnsnull.- Returns:
- random snapshot user metadata or
null
-
matchAllPattern
-
getRepositoryMetadata
-