A B C D E F G H I J K L M N O P Q R S T U V W X Y 
All Classes All Packages

A

AbstractAsyncBulkByScrollActionTestCase<Request extends AbstractBulkByScrollRequest<Request>,​Response extends BulkByScrollResponse> - Class in org.elasticsearch.index.reindex
 
AbstractAsyncBulkByScrollActionTestCase() - Constructor for class org.elasticsearch.index.reindex.AbstractAsyncBulkByScrollActionTestCase
 
AbstractBootstrapCheckTestCase - Class in org.elasticsearch.test
 
AbstractBootstrapCheckTestCase() - Constructor for class org.elasticsearch.test.AbstractBootstrapCheckTestCase
 
AbstractBuilderTestCase - Class in org.elasticsearch.test
 
AbstractBuilderTestCase() - Constructor for class org.elasticsearch.test.AbstractBuilderTestCase
 
AbstractBytesReferenceTestCase - Class in org.elasticsearch.common.bytes
 
AbstractBytesReferenceTestCase() - Constructor for class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
AbstractDiffableSerializationTestCase<T extends Diffable<T> & ToXContent> - Class in org.elasticsearch.test
An abstract test case to ensure correct behavior of Diffable.
AbstractDiffableSerializationTestCase() - Constructor for class org.elasticsearch.test.AbstractDiffableSerializationTestCase
 
AbstractDiffableWireSerializationTestCase<T extends Diffable<T>> - Class in org.elasticsearch.test
An abstract test case to ensure correct behavior of Diffable.
AbstractDiffableWireSerializationTestCase() - Constructor for class org.elasticsearch.test.AbstractDiffableWireSerializationTestCase
 
AbstractEventExpectation(String, String, Level, String) - Constructor for class org.elasticsearch.test.MockLogAppender.AbstractEventExpectation
 
AbstractFullClusterRestartTestCase - Class in org.elasticsearch.upgrades
 
AbstractFullClusterRestartTestCase() - Constructor for class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
 
AbstractHttpFixture - Class in org.elasticsearch.test.fixture
Base class for test fixtures that requires a HttpServer to work.
AbstractHttpFixture(String) - Constructor for class org.elasticsearch.test.fixture.AbstractHttpFixture
 
AbstractHttpFixture.Request - Class in org.elasticsearch.test.fixture
Represents an HTTP Request.
AbstractHttpFixture.RequestHandler - Interface in org.elasticsearch.test.fixture
 
AbstractHttpFixture.Response - Class in org.elasticsearch.test.fixture
Represents an HTTP Response.
AbstractNumericFieldMapperTestCase - Class in org.elasticsearch.index.mapper
 
AbstractNumericFieldMapperTestCase() - Constructor for class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
AbstractNumericTestCase - Class in org.elasticsearch.search.aggregations.metrics
 
AbstractNumericTestCase() - Constructor for class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
AbstractQueryTestCase<QB extends AbstractQueryBuilder<QB>> - Class in org.elasticsearch.test
 
AbstractQueryTestCase() - Constructor for class org.elasticsearch.test.AbstractQueryTestCase
 
AbstractSerializingTestCase<T extends ToXContent & Writeable> - Class in org.elasticsearch.test
 
AbstractSerializingTestCase() - Constructor for class org.elasticsearch.test.AbstractSerializingTestCase
 
AbstractSimpleTransportTestCase - Class in org.elasticsearch.transport
 
AbstractSimpleTransportTestCase() - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
AbstractSimpleTransportTestCase.StringMessageRequest - Class in org.elasticsearch.transport
 
AbstractSimpleTransportTestCase.TestRequest - Class in org.elasticsearch.transport
 
AbstractSimpleTransportTestCase.Version0Request - Class in org.elasticsearch.transport
 
AbstractSimpleTransportTestCase.Version1Request - Class in org.elasticsearch.transport
 
AbstractStreamableTestCase<T extends Streamable> - Class in org.elasticsearch.test
 
AbstractStreamableTestCase() - Constructor for class org.elasticsearch.test.AbstractStreamableTestCase
 
AbstractStreamableXContentTestCase<T extends ToXContent & Streamable> - Class in org.elasticsearch.test
 
AbstractStreamableXContentTestCase() - Constructor for class org.elasticsearch.test.AbstractStreamableXContentTestCase
 
AbstractTermsTestCase - Class in org.elasticsearch.search.aggregations.bucket
 
AbstractTermsTestCase() - Constructor for class org.elasticsearch.search.aggregations.bucket.AbstractTermsTestCase
 
AbstractWireSerializingTestCase<T extends Writeable> - Class in org.elasticsearch.test
 
AbstractWireSerializingTestCase() - Constructor for class org.elasticsearch.test.AbstractWireSerializingTestCase
 
AbstractWireTestCase<T> - Class in org.elasticsearch.test
 
AbstractWireTestCase() - Constructor for class org.elasticsearch.test.AbstractWireTestCase
 
AbstractXContentTestCase<T extends ToXContent> - Class in org.elasticsearch.test
 
AbstractXContentTestCase() - Constructor for class org.elasticsearch.test.AbstractXContentTestCase
 
AbstractXContentTestCase.XContentTester<T> - Class in org.elasticsearch.test
Tests converting to and from xcontent.
accept(Executor) - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
 
accessed(long) - Method in class org.elasticsearch.test.TestSearchContext
 
action - Variable in class org.elasticsearch.test.transport.CapturingTransport.CapturedRequest
 
activeDisruption - Variable in class org.elasticsearch.test.disruption.NetworkDisruption
 
addBody(Map<String, Object>) - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
 
addCloseListener(ActionListener<Void>) - Method in class org.elasticsearch.test.transport.StubbableTransport.WrappedConnection
 
addCloseListener(ActionListener<Void>) - Method in class org.elasticsearch.transport.FakeTcpChannel
 
addCloseListener(ActionListener<Void>) - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
 
addConnectBehavior(TransportAddress, StubbableConnectionManager.GetConnectionBehavior) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
addConnectBehavior(TransportAddress, StubbableTransport.OpenConnectionBehavior) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a new connect behavior that is used for creating connections with the given delegate address.
addConnectBehavior(TransportService, StubbableTransport.OpenConnectionBehavior) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a new connect behavior that is used for creating connections with the given delegate service.
addConnectListener(ActionListener<Void>) - Method in class org.elasticsearch.transport.FakeTcpChannel
 
addConnectListener(ActionListener<Void>) - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
 
addExpectation(MockLogAppender.LoggingExpectation) - Method in class org.elasticsearch.test.MockLogAppender
 
addFailToSendNoConnectRule(TransportAddress) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a rule that will cause every send request to fail, and each new connect since the rule is added to fail as well.
addFailToSendNoConnectRule(TransportAddress, String...) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a rule that will cause matching operations to throw ConnectTransportExceptions
addFailToSendNoConnectRule(TransportAddress, Set<String>) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a rule that will cause matching operations to throw ConnectTransportExceptions
addFailToSendNoConnectRule(TransportService) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a rule that will cause every send request to fail, and each new connect since the rule is added to fail as well.
addFailToSendNoConnectRule(TransportService, String...) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a rule that will cause matching operations to throw ConnectTransportExceptions
addFailToSendNoConnectRule(TransportService, Set<String>) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a rule that will cause matching operations to throw ConnectTransportExceptions
addGetConnectionBehavior(TransportAddress, StubbableConnectionManager.GetConnectionBehavior) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a get connection behavior that is used for communication with the given delegate address.
addGetConnectionBehavior(StubbableConnectionManager.GetConnectionBehavior) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a get connection behavior that is the default get connection behavior.
addGetConnectionBehavior(TransportService, StubbableConnectionManager.GetConnectionBehavior) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a new get connection behavior that is used for communication with the given delegate service.
addHeaders(Map<String, String>) - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
 
additionalSettings() - Method in class org.elasticsearch.test.discovery.TestZenDiscovery.TestPlugin
 
additionalSettings() - Method in class org.elasticsearch.test.store.MockFSIndexStore.TestPlugin
 
addKnownAllocation(ShardRouting) - Method in class org.elasticsearch.test.gateway.TestGatewayAllocator
manually add a specific shard to the allocations the gateway keeps track of
addLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.test.transport.CapturingTransport
 
addLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.test.transport.StubbableTransport
 
addListener(MockTaskManagerListener) - Method in class org.elasticsearch.test.tasks.MockTaskManager
 
addListener(TransportConnectionListener) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
addMessageListener(TransportMessageListener) - Method in class org.elasticsearch.test.transport.CapturingTransport
 
addMessageListener(TransportMessageListener) - Method in class org.elasticsearch.test.transport.StubbableTransport
 
addMockTransportService() - Method in class org.elasticsearch.test.ESIntegTestCase
Iff this returns true mock transport implementations are used for the test runs.
addModifier(FieldTypeTestCase.Modifier) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
Add a mutation that will be tested for all expected semantics of equality and compatibility.
addNodeConnectedBehavior(TransportAddress, StubbableConnectionManager.NodeConnectedBehavior) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a node connected behavior that is used for the given delegate address.
addNodeConnectedBehavior(TransportAddress, StubbableConnectionManager.NodeConnectedBehavior) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
addNodeConnectedBehavior(StubbableConnectionManager.NodeConnectedBehavior) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a node connected behavior that is the default node connected behavior.
addNodeConnectedBehavior(TransportService, StubbableConnectionManager.NodeConnectedBehavior) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a node connected behavior that is used for the given delegate service.
addParam(String, String) - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
 
addRandomDocuments(String, int) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
addRandomField(Random, IngestDocument, Object) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
Adds a random non existing field to the provided document and associates it with the provided value.
addReplica() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
addReplica(IndexShard) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
addReplicaWithExistingPath(ShardPath, String) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
addRescore(RescoreContext) - Method in class org.elasticsearch.test.TestSearchContext
 
addressesFromString(String, int) - Method in class org.elasticsearch.test.transport.CapturingTransport
 
addressesFromString(String, int) - Method in class org.elasticsearch.test.transport.StubbableTransport
 
addRetentionLease(String, long, String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
addSearchExt(SearchExtBuilder) - Method in class org.elasticsearch.test.TestSearchContext
 
addSecretInput(String) - Method in class org.elasticsearch.cli.MockTerminal
Adds an an input that will be return from MockTerminal.readText(String).
addSendBehavior(TransportAddress, StubbableTransport.SendRequestBehavior) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a new send behavior that is used for communication with the given delegate address.
addSendBehavior(StubbableTransport.SendRequestBehavior) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a send behavior that is the default send behavior.
addSendBehavior(TransportService, StubbableTransport.SendRequestBehavior) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a new send behavior that is used for communication with the given delegate service.
addSet(String, String) - Method in class org.elasticsearch.test.rest.yaml.section.SetSection
 
addSet(String, String) - Method in class org.elasticsearch.test.rest.yaml.section.TransformAndSetSection
 
addTestZenDiscovery() - Method in class org.elasticsearch.test.ESIntegTestCase
Iff this returns true test zen discovery implementations is used for the test runs.
addTextInput(String) - Method in class org.elasticsearch.cli.MockTerminal
Adds an an input that will be return from MockTerminal.readText(String).
addTracer(MockTransportService.Tracer) - Method in class org.elasticsearch.test.transport.MockTransportService
 
addUnresponsiveRule(TransportAddress) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a rule that will cause ignores each send request, simulating an unresponsive node and failing to connect once the rule was added.
addUnresponsiveRule(TransportAddress, TimeValue) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a rule that will cause ignores each send request, simulating an unresponsive node and failing to connect once the rule was added.
addUnresponsiveRule(TransportService) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a rule that will cause ignores each send request, simulating an unresponsive node and failing to connect once the rule was added.
addUnresponsiveRule(TransportService, TimeValue) - Method in class org.elasticsearch.test.transport.MockTransportService
Adds a rule that will cause ignores each send request, simulating an unresponsive node and failing to connect once the rule was added.
admin() - Method in class org.elasticsearch.test.ESIntegTestCase
Returns a random admin client.
adminClient() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
Get the client used for test administrative actions.
advanceTime() - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
Advance the current time to the time of the next deferred task, and update the sets of deferred and runnable tasks accordingly.
after() - Method in class org.elasticsearch.test.ESTestCase
 
afterClass() - Static method in class org.elasticsearch.test.AbstractBuilderTestCase
 
afterClass() - Static method in class org.elasticsearch.test.ESIntegTestCase
 
afterCreationCheck(Repository) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
afterIfFailed(List<Throwable>) - Method in class org.elasticsearch.test.ESTestCase
Called when a test fails, supplying the errors it generated.
afterIfSuccessful() - Method in class org.elasticsearch.test.ESTestCase
called after a test is finished, but only if successful
afterIndexCreated(IndexService) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
afterIndexRemoved(Index, IndexSettings, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
afterIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
afterIndexShardCreated(IndexShard) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
afterIndexShardDeleted(ShardId, Settings) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
afterIndexShardStarted(IndexShard) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
afterInternal(boolean) - Method in class org.elasticsearch.test.ESIntegTestCase
 
afterTest() - Method in class org.elasticsearch.test.AbstractBuilderTestCase
 
afterTest() - Method in class org.elasticsearch.test.ExternalTestCluster
 
afterTest() - Method in class org.elasticsearch.test.InternalTestCluster
 
afterTest() - Method in class org.elasticsearch.test.TestCluster
This method should be executed during tear down, after each test (but after assertAfterTest)
aggregations() - Method in class org.elasticsearch.test.TestSearchContext
 
aggregations(SearchContextAggregations) - Method in class org.elasticsearch.test.TestSearchContext
 
AggregatorTestCase - Class in org.elasticsearch.search.aggregations
Base class for testing Aggregator implementations.
AggregatorTestCase() - Constructor for class org.elasticsearch.search.aggregations.AggregatorTestCase
 
aliasExists(String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
aliasExists(String, String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
aliasFilter() - Method in class org.elasticsearch.test.TestSearchContext
 
allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.DelayedShardsMockGatewayAllocator
 
allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.test.gateway.NoopGatewayAllocator
 
allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.test.gateway.TestGatewayAllocator
 
allocationId - Variable in class org.elasticsearch.index.engine.EngineTestCase
 
allowNodes(String, int) - Method in class org.elasticsearch.test.ESIntegTestCase
Restricts the given index to be allocated on n nodes using the allocation deciders.
allowShardFailures() - Method in class org.elasticsearch.index.shard.IndexShardTestCase
by default, tests will fail if any shard created by this class fails.
allReleasedVersions() - Static method in class org.elasticsearch.test.VersionUtils
Returns an immutable, sorted list containing all released versions.
allUnreleasedVersions() - Static method in class org.elasticsearch.test.VersionUtils
Returns an immutable, sorted list containing all unreleased versions.
allVersions() - Static method in class org.elasticsearch.test.VersionUtils
Returns an immutable, sorted list containing all versions, both released and unreleased.
AnalysisFactoryTestCase - Class in org.elasticsearch.indices.analysis
Alerts us if new analysis components are added to Lucene, so we don't miss them.
AnalysisFactoryTestCase(AnalysisPlugin) - Constructor for class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
 
AnalysisFactoryTestCase.MovedToAnalysisCommon - Class in org.elasticsearch.indices.analysis
Marker class for components that have moved to the analysis-common modules.
AnalysisTestsHelper - Class in org.elasticsearch.index.analysis
 
AnalysisTestsHelper() - Constructor for class org.elasticsearch.index.analysis.AnalysisTestsHelper
 
ApiCallSection - Class in org.elasticsearch.test.rest.yaml.section
Represents a test fragment that contains the information needed to call an api
ApiCallSection(String) - Constructor for class org.elasticsearch.test.rest.yaml.section.ApiCallSection
 
append(LogEvent) - Method in class org.elasticsearch.test.MockLogAppender
 
appendAllOpts(Description) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
 
appendClientYamlSuiteProperties() - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
 
appendDocs(int) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
appendEnvironmentSettings() - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
 
appendESProperties() - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
 
appendOpt(String, String) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
Append a single VM option.
appendProperties(String...) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
 
applyDisruption(MockTransportService, MockTransportService) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDelay
 
applyDisruption(MockTransportService, MockTransportService) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDisconnect
 
applyDisruption(MockTransportService, MockTransportService) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkLinkDisruptionType
Applies network disruption for requests send from the node represented by the source transport service to the node represented by the target transport service.
applyDisruption(MockTransportService, MockTransportService) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkUnresponsive
 
applyFailedShards(RoutingAllocation, List<FailedShard>) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.DelayedShardsMockGatewayAllocator
 
applyFailedShards(RoutingAllocation, List<FailedShard>) - Method in class org.elasticsearch.test.gateway.NoopGatewayAllocator
 
applyFailedShards(RoutingAllocation, List<FailedShard>) - Method in class org.elasticsearch.test.gateway.TestGatewayAllocator
 
applyOperation(Engine, Engine.Operation) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
applyOperations(Engine, List<Engine.Operation>) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
applyStartedShards(RoutingAllocation, List<ShardRouting>) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.DelayedShardsMockGatewayAllocator
 
applyStartedShards(RoutingAllocation, List<ShardRouting>) - Method in class org.elasticsearch.test.gateway.NoopGatewayAllocator
 
applyStartedShards(RoutingAllocation, List<ShardRouting>) - Method in class org.elasticsearch.test.gateway.TestGatewayAllocator
 
applyStartedShardsUntilNoChange(ClusterState, AllocationService) - Method in class org.elasticsearch.cluster.ESAllocationTestCase
 
applyToCluster(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.NetworkDisruption
 
applyToCluster(InternalTestCluster) - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
 
applyToCluster(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.SingleNodeDisruption
 
applyToNode(String, InternalTestCluster) - Method in class org.elasticsearch.test.disruption.NetworkDisruption
 
applyToNode(String, InternalTestCluster) - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
 
applyToNode(String, InternalTestCluster) - Method in class org.elasticsearch.test.disruption.SingleNodeDisruption
 
areAllSupported(List<String>) - Static method in class org.elasticsearch.test.rest.yaml.Features
Tells whether all the features provided as argument are supported
assertAcked(CreateIndexResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Assert that an index creation was fully acknowledged, meaning that both the index creation cluster state update was successful and that the requisite number of shard copies were started before returning.
assertAcked(DeleteIndexRequestBuilder) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertAcked(AcknowledgedRequestBuilder<?, ?, ?>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertAcked(AcknowledgedResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
AssertActionNamePlugin() - Constructor for class org.elasticsearch.test.ESIntegTestCase.AssertActionNamePlugin
 
assertAfterTest() - Method in class org.elasticsearch.test.InternalTestCluster
 
assertAfterTest() - Method in class org.elasticsearch.test.TestCluster
This method checks all the things that need to be checked after each test
assertAliasesExist(AliasesExistResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Assert that aliases exist
assertAliasesMissing(AliasesExistResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Assert that aliases are missing
assertAllEqual(int) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
assertAllExpectationsMatched() - Method in class org.elasticsearch.test.MockLogAppender
 
assertAllIndicesRemovedAndDeletionCompleted(Iterable<IndicesService>) - Method in class org.elasticsearch.test.ESTestCase
 
assertAllShardsOnNodes(String, String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Asserts that all shards are allocated on nodes matching the given node pattern.
assertAllSuccessful(SearchResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertAllSuccessful(BroadcastResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertArrayEquals(StackTraceElement[], StackTraceElement[]) - Static method in class org.elasticsearch.test.ESTestCase
Compares two stack traces, ignoring module (which is not yet serialized)
assertBlocked(ActionRequestBuilder) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Executes the request and fails if the request has not been blocked.
assertBlocked(ActionRequestBuilder, Integer) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Executes the request and fails if the request has not been blocked by a specific ClusterBlock.
assertBlocked(ActionRequestBuilder, ClusterBlock) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Executes the request and fails if the request has not been blocked by a specific ClusterBlock.
assertBlocked(BroadcastResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Checks that all shard requests of a replicated broadcast request failed due to a cluster block
assertBooleanSubQuery(Query, Class<T>, int) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertBucket(MultiBucketsAggregation.Bucket, MultiBucketsAggregation.Bucket, boolean) - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
assertBusy(CheckedRunnable<Exception>) - Static method in class org.elasticsearch.test.ESTestCase
Runs the code block for 10 seconds waiting for no assertion to trip.
assertBusy(CheckedRunnable<Exception>, long, TimeUnit) - Static method in class org.elasticsearch.test.ESTestCase
Runs the code block for the provided interval, waiting for no assertions to trip.
assertCompatible(String, MappedFieldType, MappedFieldType, boolean) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
 
assertConcreteMappingsOnAll(String, String, String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Waits until mappings for the provided fields exist on all nodes.
assertConsistentHistoryBetweenTranslogAndLucene(IndexShard) - Static method in class org.elasticsearch.index.shard.IndexShardTestCase
 
assertConsistentHistoryBetweenTranslogAndLuceneIndex() - Method in class org.elasticsearch.test.InternalTestCluster
Asserts that the document history in Lucene index is consistent with Translog's on every index shard of the cluster.
assertConsistentHistoryBetweenTranslogAndLuceneIndex(Engine, MapperService) - Static method in class org.elasticsearch.index.engine.EngineTestCase
Asserts the provided engine has a consistent document history between translog and Lucene index.
assertDiffApplication(T, T, Diff<T>) - Static method in class org.elasticsearch.test.DiffableTestUtils
Asserts that changes are applied correctly, i.e.
assertDirectoryExists(Path) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Check if a directory exists
assertDisjunctionSubQuery(Query, Class<T>, int) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertDocCount(IndexShard, int) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
assertDocs(IndexShard, String...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
assertEqualInstances(T, T) - Method in class org.elasticsearch.test.AbstractWireTestCase
 
assertEqualInstances(T, T) - Method in class org.elasticsearch.test.AbstractXContentTestCase
 
assertEquals(StackTraceElement, StackTraceElement) - Static method in class org.elasticsearch.test.ESTestCase
Compares two stack trace elements, ignoring module (which is not yet serialized)
assertEqualsConsumer(BiConsumer<T, T>) - Method in class org.elasticsearch.test.AbstractXContentTestCase.XContentTester
 
assertEqualsWithErrorMessageFromXContent(T, T) - Static method in class org.elasticsearch.test.ESTestCase
Assert that two objects are equals, calling ToXContent.toXContent(XContentBuilder, ToXContent.Params) to print out their differences if they aren't equal.
assertExists(GetResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertFailures(SearchRequestBuilder, RestStatus, Matcher<String>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertFailures(SearchResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertFieldTypeEquals(String, MappedFieldType, MappedFieldType) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
 
assertFieldTypeNotEquals(String, MappedFieldType, MappedFieldType) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
 
assertFifthHit(SearchResponse, Matcher<SearchHit>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertFileExists(Path) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Check if a file exists
assertFileNotExists(Path) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Check if a file does not exist
assertFirstHit(SearchResponse, Matcher<SearchHit>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertFourthHit(SearchResponse, Matcher<SearchHit>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertFromXContent(T, ParsedAggregation) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
 
assertFromXContent(T, ParsedAggregation) - Method in class org.elasticsearch.test.InternalAggregationTestCase
 
assertFromXContent(T, ParsedAggregation) - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
assertHeaders(RestClient, Map<String, String>) - Method in class org.elasticsearch.client.RestClientBuilderTestCase
Checks the given rest client has the provided default headers.
assertHighlight(SearchResponse, int, String, int, int, Matcher<String>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertHighlight(SearchResponse, int, String, int, Matcher<String>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertHighlight(SearchHit, String, int, int, Matcher<String>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertHighlight(SearchHit, String, int, Matcher<String>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertHitCount(SearchResponse, long) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertIndexTemplateExists(GetIndexTemplatesResponse, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Assert that an index template exists
assertIndexTemplateMissing(GetIndexTemplatesResponse, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Assert that an index template is missing
assertIngestDocument(IngestDocument, IngestDocument) - Static method in class org.elasticsearch.ingest.IngestDocumentMatcher
Helper method to assert the equivalence between two IngestDocuments.
assertInstanceBinding(Module, Class<T>, Predicate<T>) - Method in class org.elasticsearch.common.inject.ModuleTestCase
Configures the module, and ensures an instance is bound to the "to" class, and the provided tester returns true on the instance.
Assertion - Class in org.elasticsearch.test.rest.yaml.section
Base class for executable sections that hold assertions
Assertion(XContentLocation, String, Object) - Constructor for class org.elasticsearch.test.rest.yaml.section.Assertion
 
assertMappingOnMaster(String, String, String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Waits for the given mapping type to exists on the master node.
assertMatched() - Method in interface org.elasticsearch.test.MockLogAppender.LoggingExpectation
 
assertMatched() - Method in class org.elasticsearch.test.MockLogAppender.PatternSeenEventExcpectation
 
assertMatched() - Method in class org.elasticsearch.test.MockLogAppender.SeenEventExpectation
 
assertMatched() - Method in class org.elasticsearch.test.MockLogAppender.UnseenEventExpectation
 
assertMaxSeqNoInCommitUserData(Engine) - Static method in class org.elasticsearch.index.engine.EngineTestCase
Asserts that the max_seq_no stored in the commit's user_data is never smaller than seq_no of any document in the commit.
assertMultiBucketConsumer(Aggregation, MultiBucketConsumerService.MultiBucketConsumer) - Static method in class org.elasticsearch.test.InternalAggregationTestCase
 
assertMultiBucketsAggregation(MultiBucketsAggregation, MultiBucketsAggregation, boolean) - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
assertNoFailures() - Method in class org.elasticsearch.test.BackgroundIndexer
 
assertNoFailures(BulkResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertNoFailures(SearchResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertNoFailures(BroadcastResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertNoInFlightContext() - Static method in class org.elasticsearch.search.MockSearchService
Throw an AssertionError if there are still in-flight contexts.
assertNoPendingHandshakes(Transport) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
assertNoSearchHits(SearchResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertNotCompatible(String, MappedFieldType, MappedFieldType, boolean, String...) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
 
assertNotHighlighted(SearchResponse, int, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertNoTimeout(ClusterHealthRequestBuilder) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertNoTimeout(ClusterHealthResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertNumHandshakes(long, Transport) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
assertOK(Response) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
assertOpsOnReplica(List<Engine.Operation>, InternalEngine, boolean, Logger) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
assertOrderedSearchHits(SearchResponse, String...) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertParsedQuery(String, QueryBuilder) - Method in class org.elasticsearch.test.AbstractQueryTestCase
Parses the query provided as string argument and compares it with the expected result provided as argument as a QueryBuilder
assertPathHasBeenCleared(Path) - Method in class org.elasticsearch.test.ESTestCase
Asserts that there are no files in the specified path
assertReduced(T, List<T>) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
 
assertReduced(T, List<T>) - Method in class org.elasticsearch.test.InternalAggregationTestCase
 
assertResultsAndLogOnFailure(long, SearchResponse) - Method in class org.elasticsearch.test.ESIntegTestCase
Ensures the result counts are as expected, and logs the results if different
assertSameDocIdsOnShards() - Method in class org.elasticsearch.test.InternalTestCluster
Asserts that all shards with the same shardId should have document Ids.
assertSearchHit(SearchResponse, int, Matcher<SearchHit>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertSearchHits(SearchResponse, String...) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertSearchResponse(SearchRequestBuilder) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Applies basic assertions on the SearchResponse.
assertSearchResponse(SearchResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Applies basic assertions on the SearchResponse.
assertSecondHit(SearchResponse, Matcher<SearchHit>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertSeqNos() - Method in class org.elasticsearch.test.InternalTestCluster
 
assertSerialization(QueryBuilder) - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
assertSerialization(QueryBuilder, Version) - Method in class org.elasticsearch.test.AbstractQueryTestCase
Serialize the given query builder and asserts that both are equal
assertSerialization(T) - Method in class org.elasticsearch.test.AbstractWireTestCase
Serialize the given instance and asserts that both are equal
assertSerialization(T, NamedWriteableRegistry, Writeable.Reader<T>) - Static method in class org.elasticsearch.test.DiffableTestUtils
Asserts that testInstance can be correctly.
assertSerialization(T, Version) - Method in class org.elasticsearch.test.AbstractWireTestCase
 
assertSettingDeprecationsAndWarnings(String[], String...) - Method in class org.elasticsearch.test.ESTestCase
 
assertSettingDeprecationsAndWarnings(Setting<?>[], String...) - Method in class org.elasticsearch.test.ESTestCase
Convenience method to assert warnings for settings deprecations and general deprecation warnings.
assertSortedSegments(String, Sort) - Method in class org.elasticsearch.test.ESIntegTestCase
Asserts that all segments are sorted with the provided Sort.
assertSortValues(SearchResponse, Object[]...) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertSuccessfulRestore(RestoreSnapshotRequestBuilder) - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
assertSuccessfulRestore(RestoreSnapshotResponse) - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
assertSuccessfulSnapshot(CreateSnapshotRequestBuilder) - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
assertSuccessfulSnapshot(CreateSnapshotResponse) - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
assertSuggestion(Suggest, int, int, String, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertSuggestion(Suggest, int, String, int, String...) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Assert suggestion returns size suggestions and the first are the provided text.
assertSuggestion(Suggest, int, String, String...) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Assert suggestion returns exactly the provided text.
assertSuggestionPhraseCollateMatchExists(Suggest, String, int) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertSuggestionSize(Suggest, int, int, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertTermOrBoostQuery(Query, String, String, float) - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
assertTermQuery(Query, String, String) - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
assertThirdHit(SearchResponse, Matcher<SearchHit>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertThrows(ActionFuture, Class<E>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Run future.actionGet() and check that it throws an exception of the right type
assertThrows(ActionFuture, Class<E>, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Run future.actionGet() and check that it throws an exception of the right type
assertThrows(ActionFuture, Class<E>, RestStatus) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Run future.actionGet() and check that it throws an exception of the right type, with a given RestStatus
assertThrows(ActionFuture, Class<E>, RestStatus, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Run future.actionGet() and check that it throws an exception of the right type, optionally checking the exception's rest status
assertThrows(ActionFuture, RestStatus) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertThrows(ActionFuture, RestStatus, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertThrows(ActionRequestBuilder<?, ?, ?>, Class<E>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Run the request from a given builder and check that it throws an exception of the right type
assertThrows(ActionRequestBuilder<?, ?, ?>, Class<E>, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Run the request from a given builder and check that it throws an exception of the right type
assertThrows(ActionRequestBuilder<?, ?, ?>, Class<E>, RestStatus) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Run the request from a given builder and check that it throws an exception of the right type, with a given RestStatus
assertThrows(ActionRequestBuilder<?, ?, ?>, RestStatus) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertThrows(ActionRequestBuilder<?, ?, ?>, RestStatus, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
assertToXContentEquivalence() - Method in class org.elasticsearch.test.AbstractSerializingTestCase
Whether or not to assert equivalence of the XContent of the test instance and the instance parsed from the XContent of the test instance.
assertToXContentEquivalence() - Method in class org.elasticsearch.test.AbstractXContentTestCase
 
assertToXContentEquivalence(boolean) - Method in class org.elasticsearch.test.AbstractXContentTestCase.XContentTester
 
assertToXContentEquivalent(BytesReference, BytesReference, XContentType) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Asserts that the provided BytesReferences created through ToXContent.toXContent(XContentBuilder, ToXContent.Params) hold the same content.
assertVisibleCount(Engine, int) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
assertVisibleCount(Engine, int, boolean) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
assertVisibleCount(InternalEngine, int) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
assertVisibleCount(InternalEngine, int, boolean) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
assertWarnings(String...) - Method in class org.elasticsearch.test.ESTestCase
 
asyncRecoverReplica(IndexShard, BiFunction<IndexShard, DiscoveryNode, RecoveryTarget>) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
autoMinMasterNodes() - Method in annotation type org.elasticsearch.test.ESIntegTestCase.ClusterScope
The cluster automatically manages the ElectMasterService.DISCOVERY_ZEN_MINIMUM_MASTER_NODES_SETTING by default as nodes are started and stopped.
await() - Method in class org.elasticsearch.test.rest.FakeRestChannel
 
awaitBusy(BooleanSupplier) - Static method in class org.elasticsearch.test.ESTestCase
 
awaitBusy(BooleanSupplier, long, TimeUnit) - Static method in class org.elasticsearch.test.ESTestCase
 
awaitLatch(CountDownLatch, long, TimeUnit) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
Wait for a latch to countdown and provide a useful error message if it does not Often latches are called as assertTrue(latch.await(1, TimeUnit.SECONDS)); In case of a failure this will just throw an assertion error without any further message

B

B_1 - Static variable in class org.elasticsearch.index.engine.EngineTestCase
 
B_2 - Static variable in class org.elasticsearch.index.engine.EngineTestCase
 
B_3 - Static variable in class org.elasticsearch.index.engine.EngineTestCase
 
BackgroundIndexer - Class in org.elasticsearch.test
 
BackgroundIndexer(String, String, Client) - Constructor for class org.elasticsearch.test.BackgroundIndexer
Start indexing in the background using a random number of threads.
BackgroundIndexer(String, String, Client, int) - Constructor for class org.elasticsearch.test.BackgroundIndexer
Start indexing in the background using a random number of threads.
BackgroundIndexer(String, String, Client, int, int) - Constructor for class org.elasticsearch.test.BackgroundIndexer
Start indexing in the background using a given number of threads.
BackgroundIndexer(String, String, Client, int, int, boolean, Random) - Constructor for class org.elasticsearch.test.BackgroundIndexer
Start indexing in the background using a given number of threads.
BaseAggregationTestCase<AB extends AbstractAggregationBuilder<AB>> - Class in org.elasticsearch.search.aggregations
 
BaseAggregationTestCase() - Constructor for class org.elasticsearch.search.aggregations.BaseAggregationTestCase
 
before() - Method in class org.elasticsearch.test.ESTestCase
 
beforeClass() - Static method in class org.elasticsearch.test.AbstractBuilderTestCase
 
beforeClass() - Static method in class org.elasticsearch.test.ESIntegTestCase
 
beforeIndexAddedToCluster(Index, Settings) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
beforeIndexCreated(Index, Settings) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
beforeIndexDeletion() - Method in class org.elasticsearch.test.ESIntegTestCase
 
beforeIndexDeletion() - Method in class org.elasticsearch.test.InternalTestCluster
 
beforeIndexDeletion() - Method in class org.elasticsearch.test.TestCluster
Assertions that should run before the cluster is wiped should be called in this method
beforeIndexRemoved(IndexService, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
beforeIndexShardCreated(ShardId, Settings) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
beforeIndexShardDeleted(ShardId, Settings) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
beforeInternal() - Method in class org.elasticsearch.test.ESIntegTestCase
 
beforeTest() - Method in class org.elasticsearch.test.AbstractBuilderTestCase
 
beforeTest(Random, double) - Method in class org.elasticsearch.test.InternalTestCluster
 
beforeTest(Random, double) - Method in class org.elasticsearch.test.TestCluster
This method should be executed before each test to reset the cluster to its initial state.
between(int, int) - Static method in class org.elasticsearch.test.ESTestCase
bigarrays - Variable in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
bigArrays() - Method in class org.elasticsearch.test.TestSearchContext
 
BinaryDocValues - org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
 
bind(String, InetSocketAddress) - Method in class org.elasticsearch.transport.MockTcpTransport
 
bitsetFilterCache() - Method in class org.elasticsearch.test.TestSearchContext
 
BlockClusterStateProcessing - Class in org.elasticsearch.test.disruption
 
BlockClusterStateProcessing(String, Random) - Constructor for class org.elasticsearch.test.disruption.BlockClusterStateProcessing
 
BlockClusterStateProcessing(Random) - Constructor for class org.elasticsearch.test.disruption.BlockClusterStateProcessing
 
BlockMasterServiceOnMaster - Class in org.elasticsearch.test.disruption
 
BlockMasterServiceOnMaster(Random) - Constructor for class org.elasticsearch.test.disruption.BlockMasterServiceOnMaster
 
BOOLEAN_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
BootstrapForTesting - Class in org.elasticsearch.bootstrap
Initializes natives and installs test security manager (init'd early by base classes to ensure it happens regardless of which test case happens to be first, test ordering, etc).
BootstrapForTesting() - Constructor for class org.elasticsearch.bootstrap.BootstrapForTesting
 
boundAddress() - Method in class org.elasticsearch.test.transport.CapturingTransport
 
boundAddress() - Method in class org.elasticsearch.test.transport.StubbableTransport
 
Bridge(String, Set<String>, Set<String>) - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.Bridge
 
build() - Method in class org.elasticsearch.test.rest.FakeRestRequest.Builder
 
build(Settings, Version, ClusterSettings, boolean) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
build(Settings, Version, ClusterSettings, boolean, TransportInterceptor) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
buildClient(Settings, HttpHost[]) - Method in class org.elasticsearch.test.rest.ESRestTestCase
 
Builder(NamedXContentRegistry) - Constructor for class org.elasticsearch.test.rest.FakeRestRequest.Builder
 
builderGeneratesCacheableQueries() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Whether the queries produced by this builder are expected to be cacheable.
buildFilteredQuery(Query) - Method in class org.elasticsearch.test.TestSearchContext
 
buildHttpHost(String, int) - Method in class org.elasticsearch.test.rest.ESRestTestCase
Construct an HttpHost from the given host and port
buildIndexMetaData(int) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
 
buildIndexMetaData(int, Map<String, String>) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
 
buildIndexMetaData(int, Settings, Map<String, String>) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
 
buildNewFakeTransportAddress() - Static method in class org.elasticsearch.test.ESTestCase
Generates a new transport address using TransportAddress.META_ADDRESS with an incrementing port number.
buildService(String, Version, ClusterSettings) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
buildService(String, Version, ClusterSettings, Settings) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
buildTestCluster(ESIntegTestCase.Scope, long) - Method in class org.elasticsearch.test.ESIntegTestCase
 
BusyMasterServiceDisruption - Class in org.elasticsearch.test.disruption
 
BusyMasterServiceDisruption(Random, Priority) - Constructor for class org.elasticsearch.test.disruption.BusyMasterServiceDisruption
 
bytePage(boolean) - Method in class org.elasticsearch.common.util.MockPageCacheRecycler
 
bytesArray(String) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 

C

callApi(String, Map<String, String>, List<Map<String, Object>>, Map<String, String>) - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestExecutionContext
Calls an elasticsearch api with the parameters and request body provided as arguments.
callApi(String, Map<String, String>, List<Map<String, Object>>, Map<String, String>, NodeSelector) - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestExecutionContext
Calls an elasticsearch api with the parameters and request body provided as arguments.
callApi(String, Map<String, String>, HttpEntity, Map<String, String>, NodeSelector) - Method in class org.elasticsearch.test.rest.yaml.ClientYamlDocsTestClient
 
callApi(String, Map<String, String>, HttpEntity, Map<String, String>, NodeSelector) - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestClient
Calls an api with the provided parameters and body
canAddField(String, IngestDocument) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
Checks whether the provided field name can be safely added to the provided document.
canAllocate(RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.TestAllocateDecision
 
canAllocate(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.TestAllocateDecision
 
canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.TestAllocateDecision
 
capturedRequests() - Method in class org.elasticsearch.test.transport.CapturingTransport
returns all requests captured so far.
capturedRequestsByTargetNode() - Method in class org.elasticsearch.test.transport.CapturingTransport
returns all requests captured so far, grouped by target node.
capturedResponse() - Method in class org.elasticsearch.test.rest.FakeRestChannel
 
CapturingTransport - Class in org.elasticsearch.test.transport
A transport class that doesn't send anything but rather captures all requests for inspection from tests
CapturingTransport() - Constructor for class org.elasticsearch.test.transport.CapturingTransport
 
CapturingTransport.CapturedRequest - Class in org.elasticsearch.test.transport
 
changeNameOrBoost(QB) - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
channelsPerNodeConnection() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
charFilter - Variable in class org.elasticsearch.test.ESTestCase.TestAnalysis
 
checkEqualsAndHashCode(T, EqualsHashCodeTestUtils.CopyFunction<T>) - Static method in class org.elasticsearch.test.EqualsHashCodeTestUtils
Perform common equality and hashCode checks on the input object
checkEqualsAndHashCode(T, EqualsHashCodeTestUtils.CopyFunction<T>, EqualsHashCodeTestUtils.MutateFunction<T>) - Static method in class org.elasticsearch.test.EqualsHashCodeTestUtils
Perform common equality and hashCode checks on the input object
checkGeneratedJson(String, QueryBuilder) - Static method in class org.elasticsearch.test.AbstractQueryTestCase
Call this method to check a valid json string representing the query under test against it's generated json.
checkIndex(Logger, Store, ShardId) - Static method in class org.elasticsearch.test.store.MockFSDirectoryService
 
checkIndexFailed - Static variable in class org.elasticsearch.test.ESTestCase
MockFSDirectoryService sets this:
checkStaticState(boolean) - Static method in class org.elasticsearch.test.ESTestCase
 
CHUNK_SIZE_SETTING - Static variable in class org.elasticsearch.node.RecoverySettingsChunkSizePlugin
The chunk size.
cleanUpCluster() - Method in class org.elasticsearch.test.ESIntegTestCase
 
cleanUpCluster() - Method in class org.elasticsearch.test.rest.ESRestTestCase
Clean up after the test case.
clear() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestExecutionContext
Clears the last obtained response and the stashed fields
clear() - Method in class org.elasticsearch.test.rest.yaml.Stash
Clears the previously stashed values
clear() - Method in class org.elasticsearch.test.transport.CapturingTransport
clears captured requests
clearAllRules() - Method in class org.elasticsearch.test.transport.MockTransportService
Clears all the registered rules.
clearBehavior(TransportAddress) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
clearBehaviors() - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
clearCallback() - Method in interface org.elasticsearch.test.transport.StubbableTransport.SendRequestBehavior
 
clearData(String) - Method in class org.elasticsearch.test.InternalTestCluster.RestartCallback
If this returns true all data for the node with the given node name will be cleared including gateways and all index data.
clearDisruptionScheme() - Method in class org.elasticsearch.test.ESIntegTestCase
 
clearDisruptionScheme() - Method in class org.elasticsearch.test.InternalTestCluster
 
clearDisruptionScheme(boolean) - Method in class org.elasticsearch.test.InternalTestCluster
 
clearRule(TransportAddress) - Method in class org.elasticsearch.test.transport.MockTransportService
Clears the rule associated with the provided delegate address.
clearRule(TransportService) - Method in class org.elasticsearch.test.transport.MockTransportService
Clears the rule associated with the provided delegate service.
clearScroll(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Clears the given scroll Ids
clearTracers() - Method in class org.elasticsearch.test.transport.MockTransportService
 
client() - Static method in class org.elasticsearch.test.ESIntegTestCase
 
client() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
Returns a client to the single-node cluster.
client() - Method in class org.elasticsearch.test.ExternalTestCluster
 
client() - Method in class org.elasticsearch.test.InternalTestCluster
 
client() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
Get the client used for ordinary api calls while writing a test
client() - Method in class org.elasticsearch.test.TestCluster
Returns a client connected to any node in the cluster
client(String) - Static method in class org.elasticsearch.test.ESIntegTestCase
 
client(String) - Method in class org.elasticsearch.test.InternalTestCluster
Returns a node client to a given node.
client(Predicate<Settings>) - Method in class org.elasticsearch.test.InternalTestCluster
Returns a random node that applies to the given predicate.
CLIENT_PATH_PREFIX - Static variable in class org.elasticsearch.test.rest.ESRestTestCase
 
CLIENT_SOCKET_TIMEOUT - Static variable in class org.elasticsearch.test.rest.ESRestTestCase
 
clients() - Static method in class org.elasticsearch.test.ESIntegTestCase
 
ClientYamlDocsTestClient - Class in org.elasticsearch.test.rest.yaml
Used to execute REST requests according to the docs snippets that need to be tests.
ClientYamlDocsTestClient(ClientYamlSuiteRestSpec, RestClient, List<HttpHost>, Version, CheckedSupplier<RestClientBuilder, IOException>) - Constructor for class org.elasticsearch.test.rest.yaml.ClientYamlDocsTestClient
 
ClientYamlSuiteRestApi - Class in org.elasticsearch.test.rest.yaml.restspec
Specification of an Elasticsearch endpoint used by the YAML specs to generate REST requests.
ClientYamlSuiteRestApi.Body - Enum in org.elasticsearch.test.rest.yaml.restspec
 
ClientYamlSuiteRestApiParser - Class in org.elasticsearch.test.rest.yaml.restspec
ClientYamlSuiteRestApiParser() - Constructor for class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApiParser
 
ClientYamlSuiteRestPath - Class in org.elasticsearch.test.rest.yaml.restspec
 
ClientYamlSuiteRestPath(String) - Constructor for class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestPath
 
ClientYamlSuiteRestPath(List<String>) - Constructor for class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestPath
 
ClientYamlSuiteRestSpec - Class in org.elasticsearch.test.rest.yaml.restspec
Holds the specification used to turn do actions in the YAML suite into REST api calls.
ClientYamlTestCandidate - Class in org.elasticsearch.test.rest.yaml
Wraps ClientYamlTestSections ready to be run.
ClientYamlTestCandidate(ClientYamlTestSuite, ClientYamlTestSection) - Constructor for class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
 
ClientYamlTestClient - Class in org.elasticsearch.test.rest.yaml
Used by ESClientYamlSuiteTestCase to execute REST requests according to the tests written in yaml suite files.
ClientYamlTestExecutionContext - Class in org.elasticsearch.test.rest.yaml
Execution context passed across the REST tests.
ClientYamlTestResponse - Class in org.elasticsearch.test.rest.yaml
Response obtained from a REST call, eagerly reads the response body into a string for later optional parsing.
ClientYamlTestResponse(Response) - Constructor for class org.elasticsearch.test.rest.yaml.ClientYamlTestResponse
 
ClientYamlTestResponseException - Exception in org.elasticsearch.test.rest.yaml
Exception obtained from a REST call in case the response code indicated an error.
ClientYamlTestResponseException(ResponseException) - Constructor for exception org.elasticsearch.test.rest.yaml.ClientYamlTestResponseException
 
ClientYamlTestSection - Class in org.elasticsearch.test.rest.yaml.section
Represents a test section, which is composed of a skip section and multiple executable sections.
ClientYamlTestSuite - Class in org.elasticsearch.test.rest.yaml.section
Holds a REST test suite loaded from a specific yaml file.
clone() - Method in class org.elasticsearch.common.settings.MockSecureSettings
 
clone() - Method in class org.elasticsearch.index.mapper.MockFieldMapper.FakeFieldType
 
close() - Method in class org.elasticsearch.common.settings.MockSecureSettings
 
close() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
close() - Method in class org.elasticsearch.test.BackgroundIndexer
 
close() - Method in class org.elasticsearch.test.client.NoOpClient
 
close() - Method in class org.elasticsearch.test.discovery.MockZenPing
 
close() - Method in class org.elasticsearch.test.ExternalTestCluster
 
close() - Method in class org.elasticsearch.test.InternalTestCluster
 
close() - Method in class org.elasticsearch.test.PosixPermissionsResetter
 
close() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestClient
 
close() - Method in class org.elasticsearch.test.TestCluster
Closes the current cluster
close() - Method in class org.elasticsearch.test.transport.CapturingTransport
 
close() - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
close() - Method in class org.elasticsearch.test.transport.StubbableTransport
 
close() - Method in class org.elasticsearch.test.transport.StubbableTransport.WrappedConnection
 
close() - Method in class org.elasticsearch.transport.FakeTcpChannel
 
close() - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
 
closeClient() - Static method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
 
closeClients() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
closeIndex(String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
closeInternal() - Method in class org.elasticsearch.test.DummyShardLock
 
closeNonSharedNodes(boolean) - Method in class org.elasticsearch.test.InternalTestCluster
 
closeShard(IndexShard, boolean) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
closeShards(Iterable<IndexShard>) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
closeShards(IndexShard...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
cluster - Variable in class org.elasticsearch.test.disruption.NetworkDisruption
 
cluster - Variable in class org.elasticsearch.test.disruption.SingleNodeDisruption
 
cluster() - Static method in class org.elasticsearch.test.ESIntegTestCase
 
clusterName(String, long) - Static method in class org.elasticsearch.test.InternalTestCluster
 
clusterService() - Method in class org.elasticsearch.test.ESIntegTestCase
 
clusterService() - Method in class org.elasticsearch.test.InternalTestCluster
Returns a reference to a random node's ClusterService
clusterService(String) - Method in class org.elasticsearch.test.InternalTestCluster
Returns a reference to a node's ClusterService.
ClusterServiceUtils - Class in org.elasticsearch.test
 
ClusterServiceUtils() - Constructor for class org.elasticsearch.test.ClusterServiceUtils
 
codecName - Variable in class org.elasticsearch.index.engine.EngineTestCase
 
collapse() - Method in class org.elasticsearch.test.TestSearchContext
 
collapse(CollapseContext) - Method in class org.elasticsearch.test.TestSearchContext
 
CollectionAssertions - Class in org.elasticsearch.test.hamcrest
Assertions for easier handling of our custom collections, for example ImmutableOpenMap
CollectionAssertions() - Constructor for class org.elasticsearch.test.hamcrest.CollectionAssertions
 
CollectionMatchers - Class in org.elasticsearch.test.hamcrest
Matchers for easier handling of our custom collections, for example ImmutableOpenMap
CollectionMatchers() - Constructor for class org.elasticsearch.test.hamcrest.CollectionMatchers
 
CollectionMatchers.ImmutableOpenMapHasAllKeysMatcher - Class in org.elasticsearch.test.hamcrest
 
CollectionMatchers.ImmutableOpenMapHasKeyMatcher - Class in org.elasticsearch.test.hamcrest
 
command - Variable in class org.elasticsearch.cli.CommandTestCase
The last command that was executed.
CommandTestCase - Class in org.elasticsearch.cli
A base test case for cli tools.
CommandTestCase() - Constructor for class org.elasticsearch.cli.CommandTestCase
 
compare(String, Object, Object) - Method in class org.elasticsearch.test.NotEqualMessageBuilder
Compare two values.
compareLists(List<Object>, List<Object>) - Method in class org.elasticsearch.test.NotEqualMessageBuilder
Compare two lists.
compareMaps(Map<String, Object>, Map<String, Object>) - Method in class org.elasticsearch.test.NotEqualMessageBuilder
Compare two maps.
compareTo(ClientYamlTestSection) - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSection
 
compatible(String...) - Method in class org.elasticsearch.test.rest.ESRestTestCase.VersionSensitiveWarningsHandler
Adds to the set of warnings that are permissible (but not required) when running in mixed-version clusters or those that differ in version from the test client.
compatibleFutureVersion(Version) - Static method in class org.elasticsearch.test.VersionUtils
returns the first future compatible version
compile(String, String, ScriptContext<T>, Map<String, String>) - Method in class org.elasticsearch.script.MockScriptEngine
 
compile(Function<Map<String, Object>, Object>, Map<String, String>) - Method in interface org.elasticsearch.script.MockScriptEngine.ContextCompiler
 
compile(Script, ScriptContext<FactoryType>) - Method in class org.elasticsearch.ingest.TestTemplateService
 
concurrentlyApplyOps(List<Engine.Operation>, InternalEngine) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
config(IndexSettings, Store, Path, MergePolicy, ReferenceManager.RefreshListener) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
config(IndexSettings, Store, Path, MergePolicy, ReferenceManager.RefreshListener, ReferenceManager.RefreshListener, Sort, LongSupplier, Supplier<RetentionLeases>, CircuitBreakerService) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
config(IndexSettings, Store, Path, MergePolicy, ReferenceManager.RefreshListener, ReferenceManager.RefreshListener, Sort, LongSupplier, CircuitBreakerService) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
config(IndexSettings, Store, Path, MergePolicy, ReferenceManager.RefreshListener, Sort, LongSupplier) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
config(IndexSettings, Store, Path, MergePolicy, ReferenceManager.RefreshListener, Sort, LongSupplier, Supplier<RetentionLeases>) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
configure() - Method in class org.elasticsearch.test.IndexSettingsModule
 
configureClient(RestClientBuilder, Settings) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
connectionManager() - Method in class org.elasticsearch.test.transport.MockTransportService
 
connectToNode(DiscoveryNode, ConnectionProfile, CheckedBiConsumer<Transport.Connection, ConnectionProfile, IOException>) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
ContainsAssertion - Class in org.elasticsearch.test.rest.yaml.section
 
ContainsAssertion(XContentLocation, String, Object) - Constructor for class org.elasticsearch.test.rest.yaml.section.ContainsAssertion
 
containsStashedValue(Object) - Method in class org.elasticsearch.test.rest.yaml.Stash
Tells whether a particular key needs to be looked up in the stash based on its name.
contentType() - Method in class org.elasticsearch.index.mapper.MockFieldMapper
 
contentType(String) - Static method in class org.elasticsearch.test.fixture.AbstractHttpFixture
 
continueIndexing() - Method in class org.elasticsearch.test.BackgroundIndexer
Continue indexing after it has paused.
continueIndexing(int) - Method in class org.elasticsearch.test.BackgroundIndexer
Continue indexing after it has paused.
controller() - Method in class org.elasticsearch.test.rest.RestActionTestCase
convertToMap(ToXContent) - Static method in class org.elasticsearch.test.XContentTestUtils
 
coordOnlyNodeClient() - Method in class org.elasticsearch.test.InternalTestCluster
Returns a client to a coordinating only node
copy(EngineConfig, LongSupplier) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
copy(EngineConfig, Analyzer) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
copy(EngineConfig, MergePolicy) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
copy(T) - Method in interface org.elasticsearch.test.EqualsHashCodeTestUtils.CopyFunction
 
copyAggregation(AB) - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
 
copyIndex(Logger, Path, String, Path...) - Static method in class org.elasticsearch.test.OldIndexUtils
 
copyIndexRequest(IndexRequest) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
 
copyInstance(T) - Method in class org.elasticsearch.test.AbstractWireTestCase
 
copyInstance(T, NamedWriteableRegistry, Writeable.Reader<T>) - Static method in class org.elasticsearch.test.DiffableTestUtils
Simulates sending diffs over the wire
copyInstance(T, NamedWriteableRegistry, Writeable.Writer<T>, Writeable.Reader<T>, Version) - Static method in class org.elasticsearch.test.ESTestCase
 
copyInstance(T, Version) - Method in class org.elasticsearch.test.AbstractStreamableTestCase
 
copyInstance(T, Version) - Method in class org.elasticsearch.test.AbstractWireSerializingTestCase
 
copyInstance(T, Version) - Method in class org.elasticsearch.test.AbstractWireTestCase
 
copyStreamable(T, NamedWriteableRegistry, Supplier<T>, Version) - Static method in class org.elasticsearch.test.ESTestCase
Create a copy of an original Streamable object by running it through a BytesStreamOutput and reading it in again using a provided Writeable.Reader.
copyToBytesFromClasspath(String) - Static method in class org.elasticsearch.test.StreamsUtils
 
copyToStringFromClasspath(ClassLoader, String) - Static method in class org.elasticsearch.test.StreamsUtils
 
copyToStringFromClasspath(String) - Static method in class org.elasticsearch.test.StreamsUtils
 
copyWriteable(T, NamedWriteableRegistry, Writeable.Reader<T>) - Static method in class org.elasticsearch.test.ESTestCase
Create a copy of an original Writeable object by running it through a BytesStreamOutput and reading it in again using a provided Writeable.Reader.
copyWriteable(T, NamedWriteableRegistry, Writeable.Reader<T>, Version) - Static method in class org.elasticsearch.test.ESTestCase
Same as ESTestCase.copyWriteable(Writeable, NamedWriteableRegistry, Writeable.Reader) but also allows to provide a Version argument which will be used to write and read back the object.
corruptFile(Random, Path...) - Static method in class org.elasticsearch.test.CorruptionUtils
Corrupts a random file at a random position
corruptIndex(Random, Path, boolean) - Static method in class org.elasticsearch.test.CorruptionUtils
 
CorruptionUtils - Class in org.elasticsearch.test
 
crash() - Method in class org.elasticsearch.test.store.MockFSDirectoryService.ElasticsearchMockDirectoryWrapper
 
CRASH_INDEX_SETTING - Static variable in class org.elasticsearch.test.store.MockFSDirectoryService
 
create(Map<String, Processor.Factory>, String, Map<String, Object>) - Method in class org.elasticsearch.ingest.TestProcessor.Factory
 
create(TokenStream) - Method in class org.elasticsearch.index.analysis.MyFilterTokenFilterFactory
 
createAggregator(Query, AggregationBuilder, IndexSearcher, IndexSettings, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
 
createAggregator(Query, AggregationBuilder, IndexSearcher, IndexSettings, MultiBucketConsumerService.MultiBucketConsumer, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
 
createAggregator(Query, AggregationBuilder, IndexSearcher, MultiBucketConsumerService.MultiBucketConsumer, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
 
createAggregator(AggregationBuilder, IndexSearcher, IndexSettings, MultiBucketConsumerService.MultiBucketConsumer, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
 
createAggregator(AggregationBuilder, IndexSearcher, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
 
createAggregatorFactory(Query, AggregationBuilder, IndexSearcher, IndexSettings, MultiBucketConsumerService.MultiBucketConsumer, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
Create a factory for the given aggregation builder.
createAggregatorFactory(AggregationBuilder, IndexSearcher, IndexSettings, MultiBucketConsumerService.MultiBucketConsumer, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
 
createAggregatorFactory(AggregationBuilder, IndexSearcher, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
 
createAllocationService() - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
createAllocationService(Settings) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
createAllocationService(Settings, Random) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
createAllocationService(Settings, ClusterInfoService) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
createAllocationService(Settings, ClusterSettings, Random) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
createAllocationService(Settings, GatewayAllocator) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
createAndCheckTestRepository(String) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
createBigArrays(PageCacheRecycler, CircuitBreakerService) - Method in class org.elasticsearch.node.MockNode
 
createBlankInstance() - Method in class org.elasticsearch.test.AbstractStreamableTestCase
Creates an empty instance to use when deserialising the Streamable.
createCapturingTransportService(Settings, ThreadPool, TransportInterceptor, Function<BoundTransportAddress, DiscoveryNode>, ClusterSettings, Set<String>) - Method in class org.elasticsearch.test.transport.CapturingTransport
 
createClusterService(ClusterState, ThreadPool) - Static method in class org.elasticsearch.test.ClusterServiceUtils
 
createClusterService(ThreadPool) - Static method in class org.elasticsearch.test.ClusterServiceUtils
 
createClusterService(ThreadPool, DiscoveryNode) - Static method in class org.elasticsearch.test.ClusterServiceUtils
 
createClusterService(ThreadPool, DiscoveryNode, ClusterSettings) - Static method in class org.elasticsearch.test.ClusterServiceUtils
 
createClusterStatePublisher(ClusterApplier) - Static method in class org.elasticsearch.test.ClusterServiceUtils
 
createDefaultFieldType() - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
Create a default constructed fieldtype
createEngine(EngineConfig) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createEngine(EngineTestCase.IndexWriterFactory, BiFunction<Long, Long, LocalCheckpointTracker>, ToLongBiFunction<Engine, Engine.Operation>, EngineConfig) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createEngine(IndexSettings, Store, Path, MergePolicy) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createEngine(IndexSettings, Store, Path, MergePolicy, EngineTestCase.IndexWriterFactory) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createEngine(IndexSettings, Store, Path, MergePolicy, EngineTestCase.IndexWriterFactory, BiFunction<Long, Long, LocalCheckpointTracker>, LongSupplier) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createEngine(IndexSettings, Store, Path, MergePolicy, EngineTestCase.IndexWriterFactory, BiFunction<Long, Long, LocalCheckpointTracker>, LongSupplier, ToLongBiFunction<Engine, Engine.Operation>) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createEngine(IndexSettings, Store, Path, MergePolicy, EngineTestCase.IndexWriterFactory, BiFunction<Long, Long, LocalCheckpointTracker>, ToLongBiFunction<Engine, Engine.Operation>, Sort, LongSupplier) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createEngine(Store, Path) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createEngine(Store, Path, BiFunction<Long, Long, LocalCheckpointTracker>) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createEngine(Store, Path, BiFunction<Long, Long, LocalCheckpointTracker>, ToLongBiFunction<Engine, Engine.Operation>) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createEngine(Store, Path, LongSupplier) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createFilterScript(Map<String, Object>, SearchLookup) - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
 
createFromResponse(Response) - Static method in class org.elasticsearch.test.rest.yaml.ObjectPath
 
createFromXContent(XContent, BytesReference) - Static method in class org.elasticsearch.test.rest.yaml.ObjectPath
 
createGroup(int) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
 
createGroup(int, Settings) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
 
createGuiceModules() - Method in class org.elasticsearch.test.MockIndexEventListener.TestPlugin
 
createIndex(String) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
Create a new index on the singleton node with empty index settings.
createIndex(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Creates one or more indices and asserts that the indices are acknowledged.
createIndex(String, CreateIndexRequestBuilder) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
 
createIndex(String, Settings) - Method in class org.elasticsearch.test.ESIntegTestCase
creates an index with the given setting
createIndex(String, Settings) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
Create a new index on the singleton node with the provided index settings.
createIndex(String, Settings) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
createIndex(String, Settings, String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
createIndex(String, Settings, String, Object...) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
Create a new index on the singleton node with the provided index settings.
createIndex(String, Settings, String, String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
createIndex(String, Settings, String, XContentBuilder) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
Create a new index on the singleton node with the provided index settings.
createIndexSettings() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
 
createInternalEngine(EngineTestCase.IndexWriterFactory, BiFunction<Long, Long, LocalCheckpointTracker>, ToLongBiFunction<Engine, Engine.Operation>, EngineConfig) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
createMapperService(String) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
createMasterService(ThreadPool, ClusterState) - Static method in class org.elasticsearch.test.ClusterServiceUtils
 
createMasterService(ThreadPool, DiscoveryNode) - Static method in class org.elasticsearch.test.ClusterServiceUtils
 
createMetricAggCombineScript(Map<String, Object>, Object) - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
 
createMetricAggInitScript(Map<String, Object>, Object) - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
 
createMetricAggMapScript(Map<String, Object>, Object, SearchLookup) - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
 
createMetricAggReduceScript(Map<String, Object>, List<Object>) - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
 
createMovingFunctionScript() - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
 
createNewService(Settings, Transport, Version, ThreadPool, ClusterSettings, Set<String>) - Static method in class org.elasticsearch.test.transport.MockTransportService
 
createNewService(Settings, Transport, Version, ThreadPool, ClusterSettings, Set<String>, TransportInterceptor) - Static method in class org.elasticsearch.test.transport.MockTransportService
 
createNewService(Settings, Version, ThreadPool, ClusterSettings) - Static method in class org.elasticsearch.test.transport.MockTransportService
 
createParameters() - Static method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
Create parameters for this parameterized test.
createParameters(NamedXContentRegistry) - Static method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
Create parameters for this parameterized test.
createParsedDoc(String, String) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
createParsedDoc(String, String, boolean) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
createParser(XContentBuilder) - Method in class org.elasticsearch.test.ESTestCase
Create a new XContentParser.
createParser(XContent, byte[]) - Method in class org.elasticsearch.test.ESTestCase
Create a new XContentParser.
createParser(XContent, InputStream) - Method in class org.elasticsearch.test.ESTestCase
Create a new XContentParser.
createParser(XContent, String) - Method in class org.elasticsearch.test.ESTestCase
Create a new XContentParser.
createParser(XContent, BytesReference) - Method in class org.elasticsearch.test.ESTestCase
Create a new XContentParser.
createRestClient(List<NodeInfo>, RestClientBuilder.HttpClientConfigCallback, String) - Static method in class org.elasticsearch.test.ESIntegTestCase
 
createRestClient(RestClientBuilder.HttpClientConfigCallback) - Static method in class org.elasticsearch.test.ESIntegTestCase
 
createRestClient(RestClientBuilder.HttpClientConfigCallback, String) - Static method in class org.elasticsearch.test.ESIntegTestCase
 
createSearchContext(IndexSearcher, IndexSettings) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
 
createSearchContext(IndexService) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
Create a new search context.
createSearchScript(Map<String, Object>, SearchLookup) - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
 
createShardContext() - Static method in class org.elasticsearch.test.AbstractBuilderTestCase
 
createShardContext(IndexReader) - Static method in class org.elasticsearch.test.AbstractBuilderTestCase
 
createSimilarityScript() - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
 
createSimilarityWeightScript() - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
 
createStore() - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createStore(Directory) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createStore(IndexSettings, Directory) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createStore(IndexSettings, ShardPath) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
createStore(ShardId, IndexSettings, Directory) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
createTaskManager(Settings, ThreadPool, Set<String>) - Method in class org.elasticsearch.test.transport.MockTransportService
 
createTestAggregatorBuilder() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
 
createTestAnalysis(Index, Settings, Settings, AnalysisPlugin...) - Static method in class org.elasticsearch.test.ESTestCase
Creates an TestAnalysis with all the default analyzers configured.
createTestAnalysis(Index, Settings, AnalysisPlugin...) - Static method in class org.elasticsearch.test.ESTestCase
Creates an TestAnalysis with all the default analyzers configured.
createTestAnalysis(IndexSettings, Settings, AnalysisPlugin...) - Static method in class org.elasticsearch.test.ESTestCase
Creates an TestAnalysis with all the default analyzers configured.
createTestAnalysisFromClassPath(Path, String, AnalysisPlugin...) - Static method in class org.elasticsearch.index.analysis.AnalysisTestsHelper
 
createTestAnalysisFromSettings(Settings, Path, AnalysisPlugin...) - Static method in class org.elasticsearch.index.analysis.AnalysisTestsHelper
 
createTestAnalysisFromSettings(Settings, AnalysisPlugin...) - Static method in class org.elasticsearch.index.analysis.AnalysisTestsHelper
 
createTestContext(Settings, MetaData) - Method in class org.elasticsearch.test.AbstractBootstrapCheckTestCase
 
createTestIndexSettings() - Method in class org.elasticsearch.test.AbstractBuilderTestCase
 
createTestInstance() - Method in class org.elasticsearch.test.AbstractWireTestCase
Creates a random test instance to use in the tests.
createTestInstance() - Method in class org.elasticsearch.test.AbstractXContentTestCase
Creates a random test instance to use in the tests.
createTestInstance() - Method in class org.elasticsearch.test.InternalAggregationTestCase
 
createTestInstance(String, long, InternalAggregations, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
 
createTestInstance(String, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
 
createTestInstance(String, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.test.InternalAggregationTestCase
 
createTestInstance(String, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
createTestInstance(String, List<PipelineAggregator>, Map<String, Object>, InternalAggregations) - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
createTestQueryBuilder() - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
createTestQueryBuilder(boolean, boolean) - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
createTestRepository(String, boolean) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
createTranslog(Path, LongSupplier) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createTranslog(LongSupplier) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createTranslogDeletionPolicy() - Static method in class org.elasticsearch.index.translog.TranslogDeletionPolicies
 
createTranslogDeletionPolicy(IndexSettings) - Static method in class org.elasticsearch.index.translog.TranslogDeletionPolicies
 
createTranslogHandler(IndexSettings) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
createUniqueRandomName() - Static method in class org.elasticsearch.test.AbstractBuilderTestCase
make sure query names are unique by suffixing them with increasing counter
createUnmappedInstance(String) - Method in class org.elasticsearch.test.InternalAggregationTestCase
Return an instance on an unmapped field.
createUnmappedInstance(String, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.test.InternalAggregationTestCase
Return an instance on an unmapped field.
createWriter(Directory, IndexWriterConfig) - Method in interface org.elasticsearch.index.engine.EngineTestCase.IndexWriterFactory
 
createXContextTestInstance(XContentType) - Method in class org.elasticsearch.test.AbstractSerializingTestCase
Creates a random instance to use in the xcontent tests.
createXContextTestInstance(XContentType) - Method in class org.elasticsearch.test.AbstractStreamableXContentTestCase
Creates a random instance to use in the xcontent tests.
current(String...) - Method in class org.elasticsearch.test.rest.ESRestTestCase.VersionSensitiveWarningsHandler
Adds to the set of warnings that are all required in responses if the cluster is formed from nodes all running the exact same version as the client.
currentClusterStateVersion - Static variable in class org.elasticsearch.index.shard.IndexShardTestCase
 
currentNanoTime() - Method in class org.elasticsearch.cluster.ESAllocationTestCase.MockAllocationService
 

D

dataCopies - Variable in class org.elasticsearch.test.ESIntegTestCase.NumShards
 
dataNodeClient() - Static method in class org.elasticsearch.test.ESIntegTestCase
 
dataNodeClient() - Method in class org.elasticsearch.test.InternalTestCluster
Returns a node client to a data node in the cluster.
DATE_ALIAS_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
DATE_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
DATE_RANGE_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
DEFAULT_DELAY_MAX - Static variable in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDelay
 
DEFAULT_DELAY_MIN - Static variable in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDelay
 
DEFAULT_EXECUTABLE_CONTEXTS - Static variable in interface org.elasticsearch.test.rest.yaml.section.ExecutableSection
Default list of ExecutableSections available for tests.
DEFAULT_HIGH_NUM_MASTER_NODES - Static variable in class org.elasticsearch.test.InternalTestCluster
 
DEFAULT_LOW_NUM_MASTER_NODES - Static variable in class org.elasticsearch.test.InternalTestCluster
 
DEFAULT_MAX_BUCKETS - Static variable in class org.elasticsearch.test.InternalAggregationTestCase
 
DEFAULT_MAX_NUM_SHARDS - Static variable in class org.elasticsearch.test.ESIntegTestCase
Default maximum number of shards for an index
DEFAULT_MIN_NUM_SHARDS - Static variable in class org.elasticsearch.test.ESIntegTestCase
Default minimum number of shards for an index
defaultSettings - Variable in class org.elasticsearch.index.engine.EngineTestCase
 
DelayedShardsMockGatewayAllocator() - Constructor for class org.elasticsearch.cluster.ESAllocationTestCase.DelayedShardsMockGatewayAllocator
 
delete(DeleteRequest) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
deleteDoc(IndexShard, String, String) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
deleteIndex(String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
deleteSnapshot(SnapshotId, long) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
deprecationLogger - Variable in class org.elasticsearch.test.ESTestCase
 
describeMismatchSafely(ImmutableOpenMap, Description) - Method in class org.elasticsearch.test.hamcrest.CollectionMatchers.ImmutableOpenMapHasAllKeysMatcher
 
describeMismatchSafely(ImmutableOpenMap, Description) - Method in class org.elasticsearch.test.hamcrest.CollectionMatchers.ImmutableOpenMapHasKeyMatcher
 
describeMismatchSafely(SearchHit, Description) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasIdMatcher
 
describeMismatchSafely(SearchHit, Description) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasIndexMatcher
 
describeMismatchSafely(SearchHit, Description) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasScoreMatcher
 
describeMismatchSafely(SearchHit, Description) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasTypeMatcher
 
describeTo(Description) - Method in class org.elasticsearch.test.hamcrest.CollectionMatchers.ImmutableOpenMapHasAllKeysMatcher
 
describeTo(Description) - Method in class org.elasticsearch.test.hamcrest.CollectionMatchers.ImmutableOpenMapHasKeyMatcher
 
describeTo(Description) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasIdMatcher
 
describeTo(Description) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasIndexMatcher
 
describeTo(Description) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasScoreMatcher
 
describeTo(Description) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasTypeMatcher
 
describeTo(Description) - Method in class org.elasticsearch.test.hamcrest.RegexMatcher
 
DeterministicTaskQueue - Class in org.elasticsearch.cluster.coordination
 
DeterministicTaskQueue(Settings, Random) - Constructor for class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
dfsResult() - Method in class org.elasticsearch.test.TestSearchContext
 
DiffableTestUtils - Class in org.elasticsearch.test
Utilities that simplify testing of diffable classes
differenceBetweenMapsIgnoringArrayOrder(Map<String, Object>, Map<String, Object>) - Static method in class org.elasticsearch.test.XContentTestUtils
Compares two maps generated from XContentObjects.
diffReader() - Method in class org.elasticsearch.test.AbstractDiffableSerializationTestCase
 
diffReader() - Method in class org.elasticsearch.test.AbstractDiffableWireSerializationTestCase
 
DirectoryReaderWrapper(DirectoryReader, FilterDirectoryReader.SubReaderWrapper) - Constructor for class org.elasticsearch.test.engine.MockEngineSupport.DirectoryReaderWrapper
 
DISABLE_FLUSH_ON_CLOSE - Static variable in class org.elasticsearch.test.engine.MockEngineSupport
Allows tests to prevent an engine from being flushed on close ie.
disableAllocation(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Syntactic sugar for disabling allocation for indices
disableIndexBlock(String, String) - Static method in class org.elasticsearch.test.ESIntegTestCase
Disables an index block for the specified index
disconnectFromNode(DiscoveryNode) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
diskUsageFunction - Variable in class org.elasticsearch.cluster.MockInternalClusterInfoService
 
dispatchBadRequest(RestRequest, RestChannel, ThreadContext, Throwable) - Method in class org.elasticsearch.http.NullDispatcher
 
dispatchRequest(RestRequest) - Method in class org.elasticsearch.test.rest.RestActionTestCase
Sends the given request to the test controller in RestActionTestCase.controller().
dispatchRequest(RestRequest, RestChannel, ThreadContext) - Method in class org.elasticsearch.http.NullDispatcher
 
disrupt(String, String) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.Bridge
 
disrupt(String, String) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.DisruptedLinks
Returns true iff network should be disrupted between the two nodes
disrupt(String, String) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.IsolateAllNodes
 
disrupt(String, String) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
 
DisruptedLinks(Set<String>...) - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.DisruptedLinks
 
disruptedNode - Variable in class org.elasticsearch.test.disruption.LongGCDisruption
 
disruptedNode - Variable in class org.elasticsearch.test.disruption.SingleNodeDisruption
 
doAfterNodes(int, Client) - Method in class org.elasticsearch.test.InternalTestCluster.RestartCallback
Executed for each node before the n + 1 node is restarted.
doAssert(Object, Object) - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
Executes the assertion comparing the actual value (parsed from the response) with the expected one
doAssert(Object, Object) - Method in class org.elasticsearch.test.rest.yaml.section.ContainsAssertion
 
doAssert(Object, Object) - Method in class org.elasticsearch.test.rest.yaml.section.GreaterThanAssertion
 
doAssert(Object, Object) - Method in class org.elasticsearch.test.rest.yaml.section.GreaterThanEqualToAssertion
 
doAssert(Object, Object) - Method in class org.elasticsearch.test.rest.yaml.section.IsFalseAssertion
 
doAssert(Object, Object) - Method in class org.elasticsearch.test.rest.yaml.section.IsTrueAssertion
 
doAssert(Object, Object) - Method in class org.elasticsearch.test.rest.yaml.section.LengthAssertion
 
doAssert(Object, Object) - Method in class org.elasticsearch.test.rest.yaml.section.LessThanAssertion
 
doAssert(Object, Object) - Method in class org.elasticsearch.test.rest.yaml.section.LessThanOrEqualToAssertion
 
doAssert(Object, Object) - Method in class org.elasticsearch.test.rest.yaml.section.MatchAssertion
 
doAssertLuceneQuery(QB, Query, SearchContext) - Method in class org.elasticsearch.test.AbstractQueryTestCase
Checks the result of QueryBuilder.toQuery(QueryShardContext) given the original QueryBuilder and QueryShardContext.
DocIdSeqNoAndTerm - Class in org.elasticsearch.index.engine
A tuple of document id, sequence number and primary term of a document
DocIdSeqNoAndTerm(String, long, long) - Constructor for class org.elasticsearch.index.engine.DocIdSeqNoAndTerm
 
docIdsToLoad() - Method in class org.elasticsearch.test.TestSearchContext
 
docIdsToLoad(int[], int, int) - Method in class org.elasticsearch.test.TestSearchContext
 
docIdsToLoadFrom() - Method in class org.elasticsearch.test.TestSearchContext
 
docIdsToLoadSize() - Method in class org.elasticsearch.test.TestSearchContext
 
doClose() - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
doClose() - Method in class org.elasticsearch.test.TestSearchContext
 
doClose() - Method in class org.elasticsearch.test.transport.MockTransportService
 
doCreateTestQueryBuilder() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Create the query that is being tested
DocsAndPositionsEnum - org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
 
DocsEnum - org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
 
docValueFieldsContext() - Method in class org.elasticsearch.test.TestSearchContext
 
docValueFieldsContext(DocValueFieldsContext) - Method in class org.elasticsearch.test.TestSearchContext
 
doExecute(Action<Request, Response, RequestBuilder>, Request, ActionListener<Response>) - Method in class org.elasticsearch.test.client.NoOpClient
 
doParseInstance(XContentParser) - Method in class org.elasticsearch.test.AbstractSerializingTestCase
Parses to a new instance using the provided XContentParser
doParseInstance(XContentParser) - Method in class org.elasticsearch.test.AbstractStreamableXContentTestCase
Parses to a new instance using the provided XContentParser
doParseInstance(XContentParser) - Method in class org.elasticsearch.test.AbstractXContentTestCase
Parses to a new instance using the provided XContentParser
DoSection - Class in org.elasticsearch.test.rest.yaml.section
Represents a do section: - do: catch: missing headers: Authorization: Basic user:pass Content-Type: application/json warnings: - Stuff is deprecated, yo - Don't use deprecated stuff - Please, stop.
DoSection(XContentLocation) - Constructor for class org.elasticsearch.test.rest.yaml.section.DoSection
 
doStart() - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
doStart() - Method in class org.elasticsearch.transport.MockTcpTransport
 
doStop() - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
doTestCoerce(String) - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
doTestDecimalCoerce(String) - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
doTestDefaults(String) - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
doTestNoDocValues(String) - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
doTestNotIndexed(String) - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
doTestNullValue(String) - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
doTestStore(String) - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
DOUBLE_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
doWrapDirectoryReader(DirectoryReader) - Method in class org.elasticsearch.test.FieldMaskingReader
 
DummyShardLock - Class in org.elasticsearch.test
 
DummyShardLock(ShardId) - Constructor for class org.elasticsearch.test.DummyShardLock
 

E

ElasticsearchAssertions - Class in org.elasticsearch.test.hamcrest
 
ElasticsearchAssertions() - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
ElasticsearchMatchers - Class in org.elasticsearch.test.hamcrest
 
ElasticsearchMatchers() - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchMatchers
 
ElasticsearchMatchers.HasPropertyLambdaMatcher<T,​V> - Class in org.elasticsearch.test.hamcrest
 
ElasticsearchMatchers.SearchHitHasIdMatcher - Class in org.elasticsearch.test.hamcrest
 
ElasticsearchMatchers.SearchHitHasIndexMatcher - Class in org.elasticsearch.test.hamcrest
 
ElasticsearchMatchers.SearchHitHasScoreMatcher - Class in org.elasticsearch.test.hamcrest
 
ElasticsearchMatchers.SearchHitHasTypeMatcher - Class in org.elasticsearch.test.hamcrest
 
ElasticsearchMockDirectoryWrapper(Random, Directory, boolean) - Constructor for class org.elasticsearch.test.store.MockFSDirectoryService.ElasticsearchMockDirectoryWrapper
 
EMPTY - Static variable in class org.elasticsearch.test.NodeConfigurationSource
 
EMPTY - Static variable in class org.elasticsearch.test.rest.yaml.section.SetupSection
 
EMPTY - Static variable in class org.elasticsearch.test.rest.yaml.section.SkipSection
 
EMPTY - Static variable in class org.elasticsearch.test.rest.yaml.section.TeardownSection
 
EMPTY - Static variable in class org.elasticsearch.test.rest.yaml.Stash
 
EMPTY_BYTE - Static variable in class org.elasticsearch.test.fixture.AbstractHttpFixture
 
EMPTY_CALLBACK - Static variable in class org.elasticsearch.test.InternalTestCluster
 
EMPTY_EVENT_LISTENER - Static variable in class org.elasticsearch.index.shard.IndexShardTestCase
 
emptyContext - Variable in class org.elasticsearch.test.AbstractBootstrapCheckTestCase
 
enableAllocation(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Syntactic sugar for enabling allocation for indices
enableIndexBlock(String, String) - Static method in class org.elasticsearch.test.ESIntegTestCase
Enables an index block for the specified index
enableJodaDeprecationWarningsCheck() - Method in class org.elasticsearch.test.ESTestCase
 
enableWarningsCheck() - Method in class org.elasticsearch.test.ESIntegTestCase
 
enableWarningsCheck() - Method in class org.elasticsearch.test.ESTestCase
Whether or not we check after each test whether it has left warnings behind.
endVerification(String) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
engine - Variable in class org.elasticsearch.index.engine.EngineTestCase
 
EngineTestCase - Class in org.elasticsearch.index.engine
 
EngineTestCase() - Constructor for class org.elasticsearch.index.engine.EngineTestCase
 
EngineTestCase.IndexWriterFactory - Interface in org.elasticsearch.index.engine
 
EngineTestCase.PrimaryTermSupplier - Class in org.elasticsearch.index.engine
 
ensureAllArraysAreReleased() - Static method in class org.elasticsearch.common.util.MockBigArrays
 
ensureAllPagesAreReleased() - Static method in class org.elasticsearch.common.util.MockPageCacheRecycler
 
ensureAllSearchContextsReleased() - Method in class org.elasticsearch.test.ESTestCase
 
ensureAtLeastNumDataNodes(int) - Method in class org.elasticsearch.test.InternalTestCluster
Ensures that at least n data nodes are present in the cluster.
ensureAtMostNumDataNodes(int) - Method in class org.elasticsearch.test.InternalTestCluster
Ensures that at most n are up and running.
ensureCheckIndexPassed() - Method in class org.elasticsearch.test.ESTestCase
 
ensureClusterSizeConsistency() - Method in class org.elasticsearch.test.ESIntegTestCase
 
ensureClusterStateConsistency() - Method in class org.elasticsearch.test.ESIntegTestCase
Verifies that all nodes that have the same version of the cluster state as master have same cluster state
ensureEstimatedStats() - Method in class org.elasticsearch.test.ExternalTestCluster
 
ensureEstimatedStats() - Method in class org.elasticsearch.test.InternalTestCluster
 
ensureEstimatedStats() - Method in class org.elasticsearch.test.TestCluster
Ensures that any breaker statistics are reset to 0.
ensureFullyConnectedCluster() - Method in class org.elasticsearch.test.ESIntegTestCase
Ensures that all nodes in the cluster are connected to each other.
ensureFullyConnectedCluster(InternalTestCluster) - Static method in class org.elasticsearch.test.disruption.NetworkDisruption
Ensures that all nodes in the cluster are connected to each other.
ensureGreen(String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
checks that the specific index is green.
ensureGreen(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Ensures the cluster has a green state via the cluster health API.
ensureGreen(String...) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
Ensures the cluster has a green state via the cluster health API.
ensureGreen(TimeValue, String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Ensures the cluster has a green state via the cluster health API.
ensureGreen(TimeValue, String...) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
Ensures the cluster has a green state via the cluster health API.
ensureHealth(String, Consumer<Request>) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
ensureHealth(Consumer<Request>) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
ensureHealth(RestClient, String, Consumer<Request>) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
ensureHealthy(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.NetworkDisruption
ensures the cluster is healthy after the disruption
ensureInitialized() - Static method in class org.elasticsearch.bootstrap.BootstrapForTesting
 
ensureNodeCount(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.NetworkDisruption
 
ensureNodeCount(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.SingleNodeDisruption
 
ensureNoInitializingShards() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
waits until all shard initialization is completed.
ensureSearchable(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Ensures the cluster is in a searchable state for the given indices.
ensureStableCluster(int) - Method in class org.elasticsearch.test.ESIntegTestCase
 
ensureStableCluster(int, String) - Method in class org.elasticsearch.test.ESIntegTestCase
 
ensureStableCluster(int, TimeValue) - Method in class org.elasticsearch.test.ESIntegTestCase
 
ensureStableCluster(int, TimeValue, boolean, String) - Method in class org.elasticsearch.test.ESIntegTestCase
 
ensureSupportedLocale() - Static method in class org.elasticsearch.test.ESTestCase
 
ensureYellow(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Ensures the cluster has a yellow state via the cluster health API.
ensureYellowAndNoInitializingShards(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Ensures the cluster has a yellow state via the cluster health API and ensures the that cluster has no initializing shards for the given indices
entityAsMap(Response) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
Convert the entity from a Response into a map of maps.
equals(Object) - Method in class org.elasticsearch.index.engine.DocIdSeqNoAndTerm
 
equals(Object) - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSection
 
equals(Object) - Method in class org.elasticsearch.test.TestCustomMetaData
 
EqualsHashCodeTestUtils - Class in org.elasticsearch.test
Utility class that encapsulates standard checks and assertions around testing the equals() and hashCode() methods of objects that implement them.
EqualsHashCodeTestUtils() - Constructor for class org.elasticsearch.test.EqualsHashCodeTestUtils
 
EqualsHashCodeTestUtils.CopyFunction<T> - Interface in org.elasticsearch.test
A function that makes a copy of its input argument
EqualsHashCodeTestUtils.MutateFunction<T> - Interface in org.elasticsearch.test
A function that creates a copy of its input argument that is different from its input in exactly one aspect (e.g.
errors() - Method in class org.elasticsearch.test.rest.FakeRestChannel
 
ESAllocationTestCase - Class in org.elasticsearch.cluster
 
ESAllocationTestCase() - Constructor for class org.elasticsearch.cluster.ESAllocationTestCase
 
ESAllocationTestCase.DelayedShardsMockGatewayAllocator - Class in org.elasticsearch.cluster
Mocks behavior in ReplicaShardAllocator to remove delayed shards from list of unassigned shards so they don't get reassigned yet.
ESAllocationTestCase.MockAllocationService - Class in org.elasticsearch.cluster
A lock AllocationService allowing tests to override time
ESAllocationTestCase.TestAllocateDecision - Class in org.elasticsearch.cluster
 
EsBaseDirectoryTestCase - Class in org.elasticsearch.index.store
Extends Lucene's BaseDirectoryTestCase with ES test behavior.
EsBaseDirectoryTestCase() - Constructor for class org.elasticsearch.index.store.EsBaseDirectoryTestCase
 
ESBlobStoreContainerTestCase - Class in org.elasticsearch.repositories
Generic test case for blob store container implementation.
ESBlobStoreContainerTestCase() - Constructor for class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
 
ESBlobStoreRepositoryIntegTestCase - Class in org.elasticsearch.repositories.blobstore
Basic integration tests for blob-based repository validation.
ESBlobStoreRepositoryIntegTestCase() - Constructor for class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
ESBlobStoreTestCase - Class in org.elasticsearch.repositories
Generic test case for blob store implementation.
ESBlobStoreTestCase() - Constructor for class org.elasticsearch.repositories.ESBlobStoreTestCase
 
ESClientYamlSuiteTestCase - Class in org.elasticsearch.test.rest.yaml
Runs a suite of yaml tests shared with all the official Elasticsearch clients against against an elasticsearch cluster.
ESClientYamlSuiteTestCase(ClientYamlTestCandidate) - Constructor for class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
 
ESIndexLevelReplicationTestCase - Class in org.elasticsearch.index.replication
 
ESIndexLevelReplicationTestCase() - Constructor for class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
 
ESIndexLevelReplicationTestCase.ReplicationAction<Request extends ReplicationRequest<Request>,​ReplicaRequest extends ReplicationRequest<ReplicaRequest>,​Response extends ReplicationResponse> - Class in org.elasticsearch.index.replication
 
ESIndexLevelReplicationTestCase.ReplicationAction.PrimaryResult - Class in org.elasticsearch.index.replication
 
ESIndexLevelReplicationTestCase.ReplicationGroup - Class in org.elasticsearch.index.replication
 
ESIntegTestCase - Class in org.elasticsearch.test
ESIntegTestCase is an abstract base class to run integration tests against a JVM private Elasticsearch Cluster.
ESIntegTestCase() - Constructor for class org.elasticsearch.test.ESIntegTestCase
 
ESIntegTestCase.AssertActionNamePlugin - Class in org.elasticsearch.test
 
ESIntegTestCase.ClusterScope - Annotation Type in org.elasticsearch.test
Defines a cluster scope for a ESIntegTestCase subclass.
ESIntegTestCase.NumShards - Class in org.elasticsearch.test
 
ESIntegTestCase.Scope - Enum in org.elasticsearch.test
The scope of a test cluster used together with ESIntegTestCase.ClusterScope annotations on ESIntegTestCase subclasses.
ESIntegTestCase.SuiteScopeTestCase - Annotation Type in org.elasticsearch.test
If a test is annotated with ESIntegTestCase.SuiteScopeTestCase the checks and modifications that are applied to the used test cluster are only done after all tests of this class are executed.
ESIntegTestCase.TestSeedPlugin - Class in org.elasticsearch.test
 
ESIntegTestCase.ThirdParty - Annotation Type in org.elasticsearch.test
Annotation for third-party integration tests.
ESRestTestCase - Class in org.elasticsearch.test.rest
Superclass for tests that interact with an external test cluster using Elasticsearch's RestClient.
ESRestTestCase() - Constructor for class org.elasticsearch.test.rest.ESRestTestCase
 
ESRestTestCase.VersionSensitiveWarningsHandler - Class in org.elasticsearch.test.rest
Helper class to check warnings in REST responses with sensitivity to versions used in the target cluster.
ESSingleNodeTestCase - Class in org.elasticsearch.test
A test that keep a singleton node started for all tests that can be used to get references to Guice injectors in unit tests.
ESSingleNodeTestCase() - Constructor for class org.elasticsearch.test.ESSingleNodeTestCase
 
ESTestCase - Class in org.elasticsearch.test
Base testcase for randomized unit testing with Elasticsearch
ESTestCase() - Constructor for class org.elasticsearch.test.ESTestCase
 
ESTestCase.GeohashGenerator - Class in org.elasticsearch.test
 
ESTestCase.TestAnalysis - Class in org.elasticsearch.test
This cute helper class just holds all analysis building blocks that are used to build IndexAnalyzers.
ESTokenStreamTestCase - Class in org.elasticsearch.test
 
ESTokenStreamTestCase() - Constructor for class org.elasticsearch.test.ESTokenStreamTestCase
 
esVersion() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestExecutionContext
Returns the current es version as a string
evaluate(Object, String) - Static method in class org.elasticsearch.test.rest.yaml.ObjectPath
A utility method that creates an ObjectPath via ObjectPath(Object) returns the result of calling ObjectPath.evaluate(String) on it.
evaluate(String) - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestResponse
Parses the response body and extracts a specific value from it (identified by the provided path)
evaluate(String) - Method in class org.elasticsearch.test.rest.yaml.ObjectPath
Returns the object corresponding to the provided path if present, null otherwise
evaluate(String, Stash) - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestResponse
Parses the response body and extracts a specific value from it (identified by the provided path)
evaluate(String, Stash) - Method in class org.elasticsearch.test.rest.yaml.ObjectPath
Returns the object corresponding to the provided path if present, null otherwise
ExceptionSeenEventExpectation(String, String, Level, String, Class<? extends Exception>, String) - Constructor for class org.elasticsearch.test.MockLogAppender.ExceptionSeenEventExpectation
 
excludePathsFromXContentInsertion() - Method in class org.elasticsearch.test.InternalAggregationTestCase
Overwrite this in your test if other than the basic xContent paths should be excluded during insertion of random fields
excludeTemplates() - Method in class org.elasticsearch.test.ESIntegTestCase
 
ExecutableSection - Interface in org.elasticsearch.test.rest.yaml.section
Represents a test fragment that can be executed (e.g.
execute() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationAction
 
execute() - Method in class org.elasticsearch.ingest.TestTemplateService.MockTemplateScript
 
execute() - Method in class org.elasticsearch.script.MockScriptEngine.MockMetricAggCombineScript
 
execute() - Method in class org.elasticsearch.script.MockScriptEngine.MockMetricAggInitScript
 
execute() - Method in class org.elasticsearch.script.MockScriptEngine.MockMetricAggReduceScript
 
execute(double, ScriptedSimilarity.Query, ScriptedSimilarity.Field, ScriptedSimilarity.Term, ScriptedSimilarity.Doc) - Method in class org.elasticsearch.script.MockScriptEngine.MockSimilarityScript
 
execute(String...) - Method in class org.elasticsearch.cli.CommandTestCase
Runs the command with the given args.
execute(Map<String, Object>, double[]) - Method in class org.elasticsearch.script.MockScriptEngine.MockMovingFunctionScript
 
execute(ScriptedSimilarity.Query, ScriptedSimilarity.Field, ScriptedSimilarity.Term) - Method in class org.elasticsearch.script.MockScriptEngine.MockSimilarityWeightScript
 
execute(IngestDocument) - Method in class org.elasticsearch.ingest.TestProcessor
 
execute(ClientYamlTestExecutionContext) - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
 
execute(ClientYamlTestExecutionContext) - Method in class org.elasticsearch.test.rest.yaml.section.DoSection
 
execute(ClientYamlTestExecutionContext) - Method in interface org.elasticsearch.test.rest.yaml.section.ExecutableSection
Executes the section passing in the execution context
execute(ClientYamlTestExecutionContext) - Method in class org.elasticsearch.test.rest.yaml.section.SetSection
 
execute(ClientYamlTestExecutionContext) - Method in class org.elasticsearch.test.rest.yaml.section.TransformAndSetSection
 
executeGet(GetRequest) - Method in class org.elasticsearch.test.AbstractBuilderTestCase
Override this to handle Client.get(GetRequest) calls from parsers / builders
executeMultiTermVectors(MultiTermVectorsRequest) - Method in class org.elasticsearch.test.AbstractBuilderTestCase
Override this to handle Client.get(GetRequest) calls from parsers / builders
executeRetentionLeasesSyncRequestOnReplica(RetentionLeaseSyncAction.Request, IndexShard) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
existsQuery(QueryShardContext) - Method in class org.elasticsearch.index.mapper.MockFieldMapper.FakeFieldType
 
expectedFieldName(String) - Static method in class org.elasticsearch.test.AbstractBuilderTestCase
 
expectedTimeToHeal() - Method in class org.elasticsearch.test.disruption.BlockClusterStateProcessing
 
expectedTimeToHeal() - Method in class org.elasticsearch.test.disruption.BlockMasterServiceOnMaster
 
expectedTimeToHeal() - Method in class org.elasticsearch.test.disruption.BusyMasterServiceDisruption
 
expectedTimeToHeal() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
 
expectedTimeToHeal() - Method in class org.elasticsearch.test.disruption.NetworkDisruption
 
expectedTimeToHeal() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDelay
 
expectedTimeToHeal() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkLinkDisruptionType
Returns expected time to heal after disruption has been removed.
expectedTimeToHeal() - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
 
expectedTimeToHeal() - Method in class org.elasticsearch.test.disruption.SlowClusterStateProcessing
 
expectVersionSpecificWarnings(Consumer<ESRestTestCase.VersionSensitiveWarningsHandler>) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
expectWarnings(String...) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
Creates request options designed to be used when making a call that can return warnings, for example a deprecated request.
explain() - Method in class org.elasticsearch.test.TestSearchContext
 
explain(boolean) - Method in class org.elasticsearch.test.TestSearchContext
 
EXTERNAL_CLUSTER_PREFIX - Static variable in class org.elasticsearch.test.ExternalTestCluster
 
externalClusterClientSettings() - Method in class org.elasticsearch.test.ESIntegTestCase
 
ExternalTestCluster - Class in org.elasticsearch.test
External cluster to run the tests against.
ExternalTestCluster(Path, Settings, Collection<Class<? extends Plugin>>, TransportAddress...) - Constructor for class org.elasticsearch.test.ExternalTestCluster
 
extraAssertReduced(T, List<T>) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
 
extractTransportAddresses(TransportService) - Static method in class org.elasticsearch.test.transport.MockTransportService
 

F

Factory() - Constructor for class org.elasticsearch.ingest.TestProcessor.Factory
 
Factory(String) - Constructor for class org.elasticsearch.ingest.TestTemplateService.MockTemplateScript.Factory
 
failOnShardFailures() - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
failureAndSuccessEvents - Variable in class org.elasticsearch.test.ESTestCase
 
FakeFieldType() - Constructor for class org.elasticsearch.index.mapper.MockFieldMapper.FakeFieldType
 
FakeFieldType(MockFieldMapper.FakeFieldType) - Constructor for class org.elasticsearch.index.mapper.MockFieldMapper.FakeFieldType
 
FakeRestChannel - Class in org.elasticsearch.test.rest
 
FakeRestChannel(RestRequest, boolean, int) - Constructor for class org.elasticsearch.test.rest.FakeRestChannel
 
FakeRestRequest - Class in org.elasticsearch.test.rest
 
FakeRestRequest() - Constructor for class org.elasticsearch.test.rest.FakeRestRequest
 
FakeRestRequest.Builder - Class in org.elasticsearch.test.rest
 
FakeTcpChannel - Class in org.elasticsearch.transport
 
FakeTcpChannel() - Constructor for class org.elasticsearch.transport.FakeTcpChannel
 
FakeTcpChannel(boolean) - Constructor for class org.elasticsearch.transport.FakeTcpChannel
 
FakeTcpChannel(boolean, String, AtomicReference<BytesReference>) - Constructor for class org.elasticsearch.transport.FakeTcpChannel
 
FakeTcpChannel(boolean, InetSocketAddress, InetSocketAddress, String, AtomicReference<BytesReference>) - Constructor for class org.elasticsearch.transport.FakeTcpChannel
 
FakeTcpChannel(boolean, AtomicReference<BytesReference>) - Constructor for class org.elasticsearch.transport.FakeTcpChannel
 
Features - Class in org.elasticsearch.test.rest.yaml
Allows to register additional features supported by the tests runner.
featureValueOf(T) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.HasPropertyLambdaMatcher
 
fetchPhase() - Method in class org.elasticsearch.test.TestSearchContext
 
fetchResult() - Method in class org.elasticsearch.test.TestSearchContext
 
fetchSourceContext() - Method in class org.elasticsearch.test.TestSearchContext
 
fetchSourceContext(FetchSourceContext) - Method in class org.elasticsearch.test.TestSearchContext
 
fieldFromSource(String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
FieldMaskingReader - Class in org.elasticsearch.test
 
FieldMaskingReader(String, DirectoryReader) - Constructor for class org.elasticsearch.test.FieldMaskingReader
 
Fields - org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
 
FieldTypeTestCase - Class in org.elasticsearch.index.mapper
Base test case for subclasses of MappedFieldType
FieldTypeTestCase() - Constructor for class org.elasticsearch.index.mapper.FieldTypeTestCase
 
FieldTypeTestCase.Modifier - Class in org.elasticsearch.index.mapper
Abstraction for mutating a property of a MappedFieldType
finalizeSnapshot(SnapshotId, List<IndexId>, long, String, int, List<SnapshotShardFailure>, long, boolean) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
flush() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
flush(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Flush some or all indices in the cluster.
flushAndRefresh(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Flushes and refreshes all indices in the cluster
flushOrClose(MockEngineSupport.CloseAction) - Method in class org.elasticsearch.test.engine.MockEngineSupport
Returns the CloseAction to execute on the actual engine.
flushShard(IndexShard) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
flushShard(IndexShard, boolean) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
forbidPrivateIndexSettings() - Method in class org.elasticsearch.test.ESIntegTestCase
 
forbidPrivateIndexSettings() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
 
forceMerge() - Method in class org.elasticsearch.test.ESIntegTestCase
Waits for all relocations and force merge all indices in the cluster to 1 segment.
format(LogEvent, StringBuilder) - Method in class org.elasticsearch.common.logging.TestThreadInfoPatternConverter
 
formatShardStatus(SearchResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
formatShardStatus(BroadcastResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
frequently() - Static method in class org.elasticsearch.test.ESTestCase
The exact opposite of LuceneTestCase.rarely().
from() - Method in class org.elasticsearch.test.TestSearchContext
 
from(int) - Method in class org.elasticsearch.test.TestSearchContext
 
fromXContent(Function<String, MetaData.Custom>, XContentParser) - Static method in class org.elasticsearch.test.TestCustomMetaData
 
fullRestart() - Method in class org.elasticsearch.test.InternalTestCluster
Restarts all nodes in the cluster.
fullRestart(InternalTestCluster.RestartCallback) - Method in class org.elasticsearch.test.InternalTestCluster
Restarts all nodes in the cluster.

G

generateHistoryOnReplica(int, boolean, boolean, boolean) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
generateNewSeqNo(Engine) - Static method in class org.elasticsearch.index.engine.EngineTestCase
Generate a new sequence number and return it.
generateRandomNames(int) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
generateRandomStringArray(int, int, boolean) - Static method in class org.elasticsearch.test.ESTestCase
 
generateRandomStringArray(int, int, boolean, boolean) - Static method in class org.elasticsearch.test.ESTestCase
 
generateSingleDocHistory(boolean, VersionType, boolean, long, int, int, String) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
GEO_POINT_ALIAS_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
GEO_POINT_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
GEO_SHAPE_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
GeohashGenerator() - Constructor for class org.elasticsearch.test.ESTestCase.GeohashGenerator
 
get() - Method in class org.elasticsearch.index.engine.EngineTestCase.PrimaryTermSupplier
 
get(String, String, String) - Method in class org.elasticsearch.test.ESIntegTestCase
Syntactic sugar for:
getActualValue(ClientYamlTestExecutionContext) - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
 
getAdminExecutionContext() - Method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
 
getAlias(String, String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
getAlternateVersions() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Returns alternate string representation of the query that need to be tested as they are never used as output of ToXContent.toXContent(XContentBuilder, ToXContent.Params).
getApi() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
 
getApi() - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
 
getApi() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
 
getApi(String) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestSpec
 
getApiCallSection() - Method in class org.elasticsearch.test.rest.yaml.section.DoSection
 
getApis() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestSpec
 
getAsLong() - Method in class org.elasticsearch.index.engine.EngineTestCase.PrimaryTermSupplier
 
getAsMap(String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
getAutoManageMinMasterNode() - Method in class org.elasticsearch.test.InternalTestCluster
returns true if the ElectMasterService.DISCOVERY_ZEN_MINIMUM_MASTER_NODES_SETTING setting is auto managed by this cluster
getBinaryDocValues(String) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
 
getBlockDetectionIntervalInMillis() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
 
getBodies() - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
 
getBody() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Request
 
getBody() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Response
 
getBody() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestResponse
Returns the body properly parsed depending on the content type.
getBodyAsString() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestResponse
Returns the body as a string
getBridgeNode() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.Bridge
 
getBwcIndicesPath() - Method in class org.elasticsearch.test.ESTestCase
 
getCacheKey() - Method in class org.elasticsearch.test.transport.StubbableTransport.WrappedConnection
 
getCapturedRequestsAndClear() - Method in class org.elasticsearch.test.transport.CapturingTransport
Returns all requests captured so far.
getCapturedRequestsByTargetNodeAndClear() - Method in class org.elasticsearch.test.transport.CapturingTransport
Returns all requests captured so far, grouped by target node.
getCatch() - Method in class org.elasticsearch.test.rest.yaml.section.DoSection
 
getCatNodesVersionMasterRequestOptions() - Method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
 
getChannelStats() - Method in class org.elasticsearch.transport.FakeTcpChannel
 
getChannelStats() - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
 
getCharFilters() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
 
getClasspathPlugins() - Method in class org.elasticsearch.node.MockNode
The classpath plugins this node was constructed with.
getClient() - Method in class org.elasticsearch.test.BackgroundIndexer
 
getClientBuilderWithSniffedHosts() - Method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
Sniff the cluster for host metadata and return a RestClientBuilder for a client with that metadata.
getClients() - Method in class org.elasticsearch.test.ExternalTestCluster
 
getClients() - Method in class org.elasticsearch.test.InternalTestCluster
 
getClients() - Method in class org.elasticsearch.test.TestCluster
Returns an Iterable over all clients in this test cluster
getClientWrapper() - Method in class org.elasticsearch.test.ESIntegTestCase
Returns a function that allows to wrap / filter all clients that are exposed by the test cluster.
getClusterHosts() - Method in class org.elasticsearch.test.rest.ESRestTestCase
Get the list of hosts in the cluster.
getClusterInfo() - Method in class org.elasticsearch.cluster.MockInternalClusterInfoService
 
getClusterName() - Method in class org.elasticsearch.test.ExternalTestCluster
 
getClusterName() - Method in class org.elasticsearch.test.InternalTestCluster
 
getClusterName() - Method in class org.elasticsearch.test.TestCluster
Returns the cluster name
getConnection() - Method in class org.elasticsearch.test.transport.StubbableTransport.WrappedConnection
 
getConnection(DiscoveryNode) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
getConnection(ConnectionManager, DiscoveryNode) - Method in interface org.elasticsearch.test.transport.StubbableConnectionManager.GetConnectionBehavior
 
getContentType() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Request
 
getContentType() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Response
 
getCopyPermissions() - Method in class org.elasticsearch.test.PosixPermissionsResetter
 
getCoreCacheHelper() - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
 
getCurrentMasterNodeInstance(Class<T>) - Method in class org.elasticsearch.test.InternalTestCluster
 
getCurrentTimeMillis() - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
getCurrentTypes() - Static method in class org.elasticsearch.test.AbstractBuilderTestCase
 
getData() - Method in class org.elasticsearch.test.TestCustomMetaData
 
getDataNodeInstance(Class<T>) - Method in class org.elasticsearch.test.InternalTestCluster
 
getDataNodeInstances(Class<T>) - Method in class org.elasticsearch.test.InternalTestCluster
Returns an Iterable to all instances for the given class >T< across all data nodes in the cluster.
getDataOrMasterNodeInstances(Class<T>) - Method in class org.elasticsearch.test.InternalTestCluster
Returns an Iterable to all instances for the given class >T< across all data and master nodes in the cluster.
getDataPath(String) - Method in class org.elasticsearch.test.ESTestCase
Returns a Path pointing to the class path relative resource given as the first argument.
getDefaultNamedXContents() - Static method in class org.elasticsearch.test.InternalAggregationTestCase
 
getDefaultSettings() - Method in class org.elasticsearch.test.InternalTestCluster
 
getDiscoveryNode(String) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
 
getDiscoveryTypes(ThreadPool, TransportService, NamedWriteableRegistry, MasterService, ClusterApplier, ClusterSettings, UnicastHostsProvider, AllocationService) - Method in class org.elasticsearch.test.discovery.TestZenDiscovery.TestPlugin
 
getDisruptedLinks() - Method in class org.elasticsearch.test.disruption.NetworkDisruption
 
getDocIdAndSeqNos(IndexShard) - Static method in class org.elasticsearch.index.shard.IndexShardTestCase
 
getDocIds(Engine, boolean) - Static method in class org.elasticsearch.index.engine.EngineTestCase
Gets a collection of tuples of docId, sequence number, and primary term of all live documents in the provided engine.
getDoSections() - Method in class org.elasticsearch.test.rest.yaml.section.TeardownSection
 
getEngine(IndexShard) - Static method in class org.elasticsearch.index.shard.IndexShardTestCase
Helper method to access (package-protected) engine from tests
getEngineFactory(ShardRouting) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
getEngineFactory(IndexSettings) - Method in class org.elasticsearch.index.MockEngineFactoryPlugin
 
getEsVersion() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestClient
 
getExecutableSections() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSection
 
getExecutableSections() - Method in class org.elasticsearch.test.rest.yaml.section.SetupSection
 
getExecutionDelayVariabilityMillis() - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
getExecutorService() - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
getExecutorService(Function<Runnable, Runnable>) - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
getExpectedParsedValue(XContentType, Object) - Static method in class org.elasticsearch.test.RandomObjects
Converts the provided field value to its corresponding expected value once printed out via ToXContent.toXContent(XContentBuilder, ToXContent.Params) and parsed back via XContentParser.objectText().
getExpectedValue() - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
 
getFailures() - Method in class org.elasticsearch.test.BackgroundIndexer
 
getFakeDiscoNode(String) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
getFeatures() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
 
getField() - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
 
getFieldAliases(MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
Allows subclasses to provide alternate names for the provided field type, which can be useful when testing aggregations on field aliases.
getFieldFilter() - Method in class org.elasticsearch.index.mapper.MockFieldFilterPlugin
 
getFile(String) - Method in class org.elasticsearch.common.settings.MockSecureSettings
 
getFinalPaths(Map<String, String>) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
Finds the best matching rest path given the current parameters and replaces placeholders with their corresponding values received as arguments
getFirstVersion() - Static method in class org.elasticsearch.test.VersionUtils
Returns the oldest released Version
getForField(MappedFieldType) - Method in class org.elasticsearch.test.TestSearchContext
 
getHeader(String) - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Request
 
getHeaders() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Request
 
getHeaders() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Response
 
getHeaders() - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
 
getId() - Method in class org.elasticsearch.index.engine.DocIdSeqNoAndTerm
 
getId() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Request
 
getIds() - Method in class org.elasticsearch.test.BackgroundIndexer
Returns the ID set of all documents indexed by this indexer run
getIndex() - Static method in class org.elasticsearch.test.AbstractBuilderTestCase
 
getIndexDir(Logger, String, String, Path) - Static method in class org.elasticsearch.test.OldIndexUtils
 
getIndexSettings(String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
getIndexStoreFactories() - Method in class org.elasticsearch.test.store.MockFSIndexStore.TestPlugin
 
getInstance(Class<T>) - Method in class org.elasticsearch.test.InternalTestCluster
Returns a reference to a random nodes instances of the given class >T<
getInstance(Class<T>, String) - Method in class org.elasticsearch.test.InternalTestCluster
Returns a reference to the given nodes instances of the given class >T<
getInstanceFromNode(Class<T>) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
Get an instance for a particular class using the injector of the singleton node.
getInstances(Class<T>) - Method in class org.elasticsearch.test.InternalTestCluster
Returns an Iterable to all instances for the given class >T< across all nodes in the cluster.
getInvokedCounter() - Method in class org.elasticsearch.ingest.TestProcessor
 
getLatestDeferredExecutionTime() - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
getListenerCaptor() - Method in class org.elasticsearch.transport.FakeTcpChannel
 
getLocalAddress() - Method in class org.elasticsearch.transport.FakeTcpChannel
 
getLocalAddress() - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
 
getLocalAddresses() - Method in class org.elasticsearch.test.transport.CapturingTransport
 
getLocalAddresses() - Method in class org.elasticsearch.test.transport.StubbableTransport
 
getLocalDiscoNode() - Method in class org.elasticsearch.test.transport.MockTransportService
 
getLocalEphemeral() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
getLocation() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
 
getLocation() - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
 
getLocation() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSection
 
getLocation() - Method in class org.elasticsearch.test.rest.yaml.section.DoSection
 
getLocation() - Method in interface org.elasticsearch.test.rest.yaml.section.ExecutableSection
Get the location in the test that this was defined.
getLocation() - Method in class org.elasticsearch.test.rest.yaml.section.SetSection
 
getLocation() - Method in class org.elasticsearch.test.rest.yaml.section.TransformAndSetSection
 
getLowerVersion() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
 
getMajoritySide() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
 
getMapping() - Method in class org.elasticsearch.test.AbstractBuilderTestCase
 
getMasterName() - Method in class org.elasticsearch.test.InternalTestCluster
Returns the name of the current master node in the cluster.
getMasterName(String) - Method in class org.elasticsearch.test.InternalTestCluster
Returns the name of the current master node in the cluster and executes the request via the node specified in the viaNode parameter.
getMessageCaptor() - Method in class org.elasticsearch.transport.FakeTcpChannel
 
getMetadata() - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
getMethod() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Request
 
getMethods() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
 
getMinoritySide() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
 
getMockPlugins() - Method in class org.elasticsearch.test.ESIntegTestCase
Return the mock plugins the cluster should use
getName() - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
 
getName() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
 
getName() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
 
getName() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSection
 
getName() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
 
getNamedWriteableRegistry() - Method in class org.elasticsearch.test.AbstractWireTestCase
Get the NamedWriteableRegistry to use when de-serializing the object.
getNamedWriteableRegistry() - Method in class org.elasticsearch.test.ExternalTestCluster
 
getNamedWriteableRegistry() - Method in class org.elasticsearch.test.InternalAggregationTestCase
 
getNamedWriteableRegistry() - Method in class org.elasticsearch.test.InternalTestCluster
 
getNamedWriteableRegistry() - Method in class org.elasticsearch.test.TestCluster
Returns this clusters NamedWriteableRegistry this is needed to deserialize binary content from this cluster that might include custom named writeables
getNamedWriteableRegistry() - Method in class org.elasticsearch.transport.MockTransportClient
 
getNamedXContents() - Method in class org.elasticsearch.test.InternalAggregationTestCase
 
getNetworkLinkDisruptionType() - Method in class org.elasticsearch.test.disruption.NetworkDisruption
 
getNode() - Method in class org.elasticsearch.test.transport.StubbableTransport.WrappedConnection
 
getNodeConfigSource() - Method in class org.elasticsearch.test.ESIntegTestCase
 
getNodeNames() - Method in class org.elasticsearch.test.InternalTestCluster
 
getNodeSelector() - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
Selects the node on which to run this request.
getNodesSideOne() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.Bridge
 
getNodesSideOne() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
 
getNodesSideTwo() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.Bridge
 
getNodesSideTwo() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
 
getNormValues(String) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
 
getNumericDocValues(String) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
 
getNumPages(BytesReference) - Static method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
getNumShards(String) - Method in class org.elasticsearch.test.ESIntegTestCase
 
getObjectMapper(String) - Method in class org.elasticsearch.test.TestSearchContext
 
getObjectsHoldingArbitraryContent() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Returns a set of object names that won't trigger any exception (uncluding their children) when testing that unknown objects cause parse exceptions through AbstractQueryTestCase.testUnknownObjectException().
getOldClusterVersion() - Method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
 
getOriginalTransport() - Method in class org.elasticsearch.test.transport.MockTransportService
 
getOriginNanoTime() - Method in class org.elasticsearch.test.TestSearchContext
 
getOutput() - Method in class org.elasticsearch.cli.MockTerminal
Returns all output written to this terminal.
getParam(String) - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Request
 
getParameters() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Request
 
getParams() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
Gets all parameters supported by the api.
getParams() - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
 
getPath() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Request
 
getPath() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
 
getPathParts() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
Gets all path parts supported by the api.
getPathParts() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestPath
 
getPaths() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
 
getPendingDeletions() - Method in class org.elasticsearch.test.store.MockFSDirectoryService.ElasticsearchMockDirectoryWrapper
 
getPerTestTransportClientRatio() - Method in class org.elasticsearch.test.ESIntegTestCase
Returns the transport client ratio from the class level annotation or via System.getProperty(String) if available.
getPlugins() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
getPlugins() - Method in class org.elasticsearch.test.AbstractBuilderTestCase
 
getPlugins() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
The plugin classes that should be added to the node.
getPlugins() - Method in class org.elasticsearch.test.InternalTestCluster
 
getPreConfiguredCharFilters() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
 
getPreConfiguredTokenFilters() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
Map containing pre-configured token filters that should be available after installing this plugin.
getPreConfiguredTokenizers() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
Map containing pre-configured tokenizers that should be available after installing this plugin.
getPreviousMinorVersion() - Static method in class org.elasticsearch.test.VersionUtils
Returns the released Version before the Version.CURRENT where the minor version is less than the currents minor version.
getPreviousVersion() - Static method in class org.elasticsearch.test.VersionUtils
Get the released version before Version.CURRENT.
getPreviousVersion(Version) - Static method in class org.elasticsearch.test.VersionUtils
Get the released version before version.
getPrimary() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
getPrimaryNode() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
getPrimaryTerm() - Method in class org.elasticsearch.index.engine.DocIdSeqNoAndTerm
 
getProcessors(Processor.Parameters) - Method in class org.elasticsearch.ingest.IngestTestPlugin
 
getProfile() - Method in class org.elasticsearch.transport.FakeTcpChannel
 
getProfile() - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
 
getProfilers() - Method in class org.elasticsearch.test.TestSearchContext
 
getProtocol() - Method in class org.elasticsearch.test.rest.ESRestTestCase
Override this to switch to testing https.
getQueryShardContext() - Method in class org.elasticsearch.test.TestSearchContext
 
getRandomFieldName() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
Helper method to return a mapped or a random field
getRandomFieldsExcludeFilter() - Method in class org.elasticsearch.test.AbstractSerializingTestCase
Returns a predicate that given the field name indicates whether the field has to be excluded from random fields insertion or not
getRandomFieldsExcludeFilter() - Method in class org.elasticsearch.test.AbstractStreamableXContentTestCase
Returns a predicate that given the field name indicates whether the field has to be excluded from random fields insertion or not
getRandomFieldsExcludeFilter() - Method in class org.elasticsearch.test.AbstractXContentTestCase
Returns a predicate that given the field name indicates whether the field has to be excluded from random fields insertion or not
getRandomQueryText() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
 
getRandomRewriteMethod() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
Helper method to return a random rewrite method
getRandomValueForFieldName(String) - Static method in class org.elasticsearch.test.AbstractQueryTestCase
getReaderCacheHelper() - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
 
getReaderCacheHelper() - Method in class org.elasticsearch.test.FieldMaskingReader
 
getReaderWrapperClass() - Method in class org.elasticsearch.index.MockEngineFactoryPlugin
 
getReason() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
 
getReasonPhrase() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestResponse
 
getRecoveredTypes() - Method in class org.elasticsearch.index.engine.TranslogHandler
Returns the recovered types modifying the mapping during the recovery
getRemoteAddress() - Method in class org.elasticsearch.test.rest.FakeRestRequest
 
getRemoteAddress() - Method in class org.elasticsearch.transport.FakeTcpChannel
 
getRemoteAddress() - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
 
getReplicas() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
getReplicationTracker(IndexShard) - Static method in class org.elasticsearch.index.shard.IndexShardTestCase
 
getRepositoryData() - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
getRequestHandler(String) - Method in class org.elasticsearch.test.transport.CapturingTransport
 
getRequestHandler(String) - Method in class org.elasticsearch.test.transport.StubbableTransport
 
getResponseException() - Method in exception org.elasticsearch.test.rest.yaml.ClientYamlTestResponseException
Exposes the origina ResponseException.
getResponseHandlers() - Method in class org.elasticsearch.test.transport.CapturingTransport
 
getResponseHandlers() - Method in class org.elasticsearch.test.transport.StubbableTransport
 
getRestClient() - Static method in class org.elasticsearch.test.ESIntegTestCase
Returns an instance of RestClient pointing to the current test cluster.
getRestClient(NodeSelector) - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestClient
 
getRestoreThrottleTimeInNanos() - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
getRestTestResponse() - Method in exception org.elasticsearch.test.rest.yaml.ClientYamlTestResponseException
Exposes the obtained response body
getScriptEngine(Settings, Collection<ScriptContext<?>>) - Method in class org.elasticsearch.script.MockScriptPlugin
 
getSearchContext(String[], QueryShardContext) - Static method in class org.elasticsearch.test.AbstractBuilderTestCase
 
getSearchExt(String) - Method in class org.elasticsearch.test.TestSearchContext
 
getSeqNo() - Method in class org.elasticsearch.index.engine.DocIdSeqNoAndTerm
 
getSettingNames() - Method in class org.elasticsearch.common.settings.MockSecureSettings
 
getSettings() - Method in class org.elasticsearch.index.MockEngineFactoryPlugin
 
getSettings() - Method in class org.elasticsearch.node.RecoverySettingsChunkSizePlugin
 
getSettings() - Method in class org.elasticsearch.test.discovery.TestZenDiscovery.TestPlugin
 
getSettings() - Method in class org.elasticsearch.test.ESIntegTestCase.TestSeedPlugin
 
getSettings() - Method in class org.elasticsearch.test.InternalSettingsPlugin
 
getSettings() - Method in class org.elasticsearch.test.MockIndexEventListener.TestPlugin
 
getSettings() - Static method in class org.elasticsearch.test.OldIndexUtils
 
getSettings() - Method in class org.elasticsearch.test.store.MockFSIndexStore.TestPlugin
 
getSettings() - Method in class org.elasticsearch.test.transport.MockTransportService.TestPlugin
 
getSetupSection() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
 
getSetupSection() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
 
getShardDocUIDs(IndexShard) - Static method in class org.elasticsearch.index.shard.IndexShardTestCase
 
getShardSnapshotStatus(SnapshotId, Version, IndexId, ShardId) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
getShuffleFieldsExceptions() - Method in class org.elasticsearch.test.AbstractSerializingTestCase
Fields that have to be ignored when shuffling as part of testFromXContent
getShuffleFieldsExceptions() - Method in class org.elasticsearch.test.AbstractStreamableXContentTestCase
Fields that have to be ignored when shuffling as part of testFromXContent
getShuffleFieldsExceptions() - Method in class org.elasticsearch.test.AbstractXContentTestCase
Fields that have to be ignored when shuffling as part of testFromXContent
getSinglePageOrNull(BytesReference) - Static method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
getSkipMessage(String) - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
 
getSkipSection() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSection
 
getSkipSection() - Method in class org.elasticsearch.test.rest.yaml.section.SetupSection
 
getSkipSection() - Method in class org.elasticsearch.test.rest.yaml.section.TeardownSection
 
getSnapshotGlobalMetaData(SnapshotId) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
getSnapshotIndexMetaData(SnapshotId, IndexId) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
getSnapshotInfo(SnapshotId) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
getSnapshotThrottleTimeInNanos() - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
getSortedDocValues(String) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
 
getSortedSetDocValues(String) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
 
getStash() - Method in class org.elasticsearch.test.rest.yaml.section.SetSection
 
getStash() - Method in class org.elasticsearch.test.rest.yaml.section.TransformAndSetSection
 
getStats() - Method in class org.elasticsearch.test.transport.CapturingTransport
 
getStats() - Method in class org.elasticsearch.test.transport.StubbableTransport
 
getStatus() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Response
 
getStatusCode() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestResponse
 
getString(String) - Method in class org.elasticsearch.common.settings.MockSecureSettings
 
getSuiteFailureMarker() - Static method in class org.elasticsearch.test.ESTestCase
Returns the suite failure marker: internal use only!
getSuitePath() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
 
getSupportedMethods(Set<String>) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
Returns the supported http methods given the rest parameters provided
getSuspendingTimeoutInMillis() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
 
getTag() - Method in class org.elasticsearch.ingest.TestProcessor
 
getTask() - Method in class org.elasticsearch.test.TestSearchContext
 
getTeardownSection() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
 
getTeardownSection() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
 
getTermVectors(int) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
 
getTestPath() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
 
getTestSection() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
 
getTestSections() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
 
getTestTransportPlugin() - Static method in class org.elasticsearch.test.ESTestCase
 
getTestTransportType() - Static method in class org.elasticsearch.test.ESTestCase
 
getThreadPool() - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
getThreadPool(Function<Runnable, Runnable>) - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
getTokenFilters() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
 
getTokenizers() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
 
getTokenizers() - Method in class org.elasticsearch.test.MockKeywordPlugin
 
getToXContentParams() - Method in class org.elasticsearch.test.AbstractSerializingTestCase
Params that have to be provided when calling calling ToXContent.toXContent(XContentBuilder, ToXContent.Params)
getToXContentParams() - Method in class org.elasticsearch.test.AbstractStreamableXContentTestCase
Params that have to be provided when calling calling ToXContent.toXContent(XContentBuilder, ToXContent.Params)
getToXContentParams() - Method in class org.elasticsearch.test.AbstractXContentTestCase
Params that have to be provided when calling ToXContent.toXContent(XContentBuilder, ToXContent.Params)
getTranslog(Engine) - Static method in class org.elasticsearch.index.engine.EngineTestCase
Exposes a translog associated with the given engine for testing purpose.
getTranslog(IndexShard) - Static method in class org.elasticsearch.index.shard.IndexShardTestCase
 
getTransportInterceptors(NamedWriteableRegistry, ThreadContext) - Method in class org.elasticsearch.test.ESIntegTestCase.AssertActionNamePlugin
 
getTransports(Settings, ThreadPool, PageCacheRecycler, CircuitBreakerService, NamedWriteableRegistry, NetworkService) - Method in class org.elasticsearch.transport.MockTcpTransportPlugin
 
getType() - Method in class org.elasticsearch.ingest.TestProcessor
 
getType() - Method in class org.elasticsearch.script.MockScriptEngine
 
getUnsafeClasses() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
 
getUpperVersion() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
 
getValue(String) - Method in class org.elasticsearch.test.rest.yaml.Stash
Retrieves a value from the current stash.
getVersion() - Method in class org.elasticsearch.test.transport.StubbableTransport.WrappedConnection
 
getWarningHeaders() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestResponse
Get a list of all of the values of all warning headers returned in the response.
getWriter() - Method in class org.elasticsearch.cli.MockTerminal
 
getZenPing() - Method in class org.elasticsearch.test.discovery.TestZenDiscovery
 
GradleMessageBuilder(StringBuilder) - Constructor for class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
 
GreaterThanAssertion - Class in org.elasticsearch.test.rest.yaml.section
Represents a gt assert section:
GreaterThanAssertion(XContentLocation, String, Object) - Constructor for class org.elasticsearch.test.rest.yaml.section.GreaterThanAssertion
 
GreaterThanEqualToAssertion - Class in org.elasticsearch.test.rest.yaml.section
Represents a gte assert section: - gte: { fields._ttl: 0 }
GreaterThanEqualToAssertion(XContentLocation, String, Object) - Constructor for class org.elasticsearch.test.rest.yaml.section.GreaterThanEqualToAssertion
 
groupStats() - Method in class org.elasticsearch.test.TestSearchContext
 
groupStats(List<String>) - Method in class org.elasticsearch.test.TestSearchContext
 

H

handle(AbstractHttpFixture.Request) - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture
 
handle(AbstractHttpFixture.Request) - Method in interface org.elasticsearch.test.fixture.AbstractHttpFixture.RequestHandler
 
handleError(long, TransportException) - Method in class org.elasticsearch.test.transport.CapturingTransport
simulate an error for the given requestId, unlike CapturingTransport.handleLocalError(long, Throwable) and CapturingTransport.handleRemoteError(long, Throwable), the provided exception will not be wrapped but will be delivered to the transport layer as is
handleLocalError(long, Throwable) - Method in class org.elasticsearch.test.transport.CapturingTransport
simulate a local error for the given requestId, will be wrapped by a SendRequestTransportException
handleRemoteError(long, Throwable) - Method in class org.elasticsearch.test.transport.CapturingTransport
simulate a remote error for the given requestId, will be wrapped by a RemoteTransportException
handleResponse(long, Response) - Method in class org.elasticsearch.test.transport.CapturingTransport
simulate a response for the given requestId
hasAllKeys(String...) - Static method in class org.elasticsearch.test.hamcrest.CollectionAssertions
 
hasBody() - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
 
hasContent() - Method in class org.elasticsearch.test.rest.FakeRestRequest
 
hasDeferredTasks() - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
hasFetchSourceContext() - Method in class org.elasticsearch.test.TestSearchContext
 
hashCode() - Method in class org.elasticsearch.index.engine.DocIdSeqNoAndTerm
 
hashCode() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSection
 
hashCode() - Method in class org.elasticsearch.test.TestCustomMetaData
 
hasId(String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
hasIndex(String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
hasKey(String) - Static method in class org.elasticsearch.test.hamcrest.CollectionAssertions
 
hasProperty(Function<? super T, ? extends V>, Matcher<V>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
hasProperty(Function<? super T, ? extends V>, Matcher<V>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.HasPropertyLambdaMatcher
 
hasRunnableTasks() - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
hasScore(float) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
hasScriptFields() - Method in class org.elasticsearch.test.TestSearchContext
 
hasSnapshottedCommits(Engine) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
hasStoredFields() - Method in class org.elasticsearch.test.TestSearchContext
 
hasStoredFieldsContext() - Method in class org.elasticsearch.test.TestSearchContext
 
hasType(String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
 
hasXPack() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
Does any node in the cluster being tested have x-pack installed?
highlight() - Method in class org.elasticsearch.test.TestSearchContext
 
highlight(SearchContextHighlight) - Method in class org.elasticsearch.test.TestSearchContext
 
httpAddresses() - Method in class org.elasticsearch.test.ExternalTestCluster
 
httpAddresses() - Method in class org.elasticsearch.test.InternalTestCluster
 
httpAddresses() - Method in class org.elasticsearch.test.TestCluster
Returns the http addresses of the nodes within the cluster.

I

id() - Method in class org.elasticsearch.test.TestSearchContext
 
ignoreExternalCluster() - Method in class org.elasticsearch.test.ESIntegTestCase
 
ImmutableOpenMapHasAllKeysMatcher(String...) - Constructor for class org.elasticsearch.test.hamcrest.CollectionMatchers.ImmutableOpenMapHasAllKeysMatcher
 
ImmutableOpenMapHasKeyMatcher(String) - Constructor for class org.elasticsearch.test.hamcrest.CollectionMatchers.ImmutableOpenMapHasKeyMatcher
 
implementationClass() - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
 
implementationClass() - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
in() - Method in class org.elasticsearch.test.client.RandomizingClient
 
incompatibleFutureVersion(Version) - Static method in class org.elasticsearch.test.VersionUtils
returns the first future incompatible version
index - Variable in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
 
index(String, String, String, Object...) - Method in class org.elasticsearch.test.ESIntegTestCase
Syntactic sugar for:
index(String, String, String, String) - Method in class org.elasticsearch.test.ESIntegTestCase
Syntactic sugar for:
index(String, String, String, Map<String, Object>) - Method in class org.elasticsearch.test.ESIntegTestCase
Syntactic sugar for:
index(String, String, String, XContentBuilder) - Method in class org.elasticsearch.test.ESIntegTestCase
Syntactic sugar for:
index(String, String, XContentBuilder) - Method in class org.elasticsearch.test.ESIntegTestCase
Syntactic sugar for:
index(IndexRequest) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
INDEX_CHECK_INDEX_ON_CLOSE_SETTING - Static variable in class org.elasticsearch.test.store.MockFSIndexStore
 
INDEX_CREATION_DATE_SETTING - Static variable in class org.elasticsearch.test.InternalSettingsPlugin
 
INDEX_FAIL - Static variable in class org.elasticsearch.test.MockIndexEventListener.TestPlugin
For tests to pass in to fail on listener invocation
INDEX_SETTINGS - Static variable in class org.elasticsearch.index.engine.EngineTestCase
 
INDEX_TEST_SEED_SETTING - Static variable in class org.elasticsearch.test.ESIntegTestCase
Key used to retrieve the index random seed from the index settings on a running node.
indexAnalyzers - Variable in class org.elasticsearch.test.ESTestCase.TestAnalysis
 
indexDoc(IndexShard, String, String) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
indexDoc(IndexShard, String, String, String) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
indexDoc(IndexShard, String, String, String, XContentType, String, String) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
indexDocs(int) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
indexExists(String) - Method in class org.elasticsearch.test.ESIntegTestCase
Returns true iff the given index exists otherwise false
indexExists(String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
indexForDoc(ParsedDocument) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
indexMapping - Variable in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
 
indexRandom(boolean, boolean, boolean, List<IndexRequestBuilder>) - Method in class org.elasticsearch.test.ESIntegTestCase
Indexes the given IndexRequestBuilder instances randomly.
indexRandom(boolean, boolean, List<IndexRequestBuilder>) - Method in class org.elasticsearch.test.ESIntegTestCase
Indexes the given IndexRequestBuilder instances randomly.
indexRandom(boolean, boolean, IndexRequestBuilder...) - Method in class org.elasticsearch.test.ESIntegTestCase
 
indexRandom(boolean, List<IndexRequestBuilder>) - Method in class org.elasticsearch.test.ESIntegTestCase
Indexes the given IndexRequestBuilder instances randomly.
indexRandom(boolean, IndexRequestBuilder...) - Method in class org.elasticsearch.test.ESIntegTestCase
Convenience method that forwards to ESIntegTestCase.indexRandom(boolean, List).
indexService - Variable in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
indexSettings() - Method in class org.elasticsearch.index.engine.EngineTestCase
 
indexSettings() - Static method in class org.elasticsearch.test.AbstractBuilderTestCase
 
indexSettings() - Method in class org.elasticsearch.test.ESIntegTestCase
Returns a settings object used in ESIntegTestCase.createIndex(String...) and ESIntegTestCase.prepareCreate(String) and friends.
IndexSettingsModule - Class in org.elasticsearch.test
 
IndexSettingsModule(Index, Settings) - Constructor for class org.elasticsearch.test.IndexSettingsModule
 
indexShard() - Method in class org.elasticsearch.test.TestSearchContext
 
indexShardStateChanged(IndexShard, IndexShardState, IndexShardState, String) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
IndexShardTestCase - Class in org.elasticsearch.index.shard
A base class for unit tests that need to create and shutdown IndexShard instances easily, containing utilities for shard creation and recoveries.
IndexShardTestCase() - Constructor for class org.elasticsearch.index.shard.IndexShardTestCase
 
inFipsJvm() - Static method in class org.elasticsearch.test.ESIntegTestCase
 
inFipsJvm() - Static method in class org.elasticsearch.test.ESTestCase
 
IngestDocumentMatcher - Class in org.elasticsearch.ingest
 
IngestDocumentMatcher() - Constructor for class org.elasticsearch.ingest.IngestDocumentMatcher
 
IngestTestPlugin - Class in org.elasticsearch.ingest
Adds an ingest processor to be used in tests.
IngestTestPlugin() - Constructor for class org.elasticsearch.ingest.IngestTestPlugin
 
initAndResetContext() - Method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
 
initClient() - Method in class org.elasticsearch.test.rest.ESRestTestCase
 
initClientYamlTestClient(ClientYamlSuiteRestSpec, RestClient, List<HttpHost>, Version) - Method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
 
initialize(ShardRouting, String) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
 
initialize(ShardRouting, String, long) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
 
initializeAdditionalMappings(MapperService) - Method in class org.elasticsearch.test.AbstractBuilderTestCase
 
initializeSnapshot(SnapshotId, List<IndexId>, MetaData) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
initiateChannel(DiscoveryNode) - Method in class org.elasticsearch.transport.MockTcpTransport
 
initWithSameId(ShardRouting, RecoverySource) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
 
innerContent() - Method in class org.elasticsearch.test.rest.FakeRestRequest
 
innerMatch(LogEvent) - Method in class org.elasticsearch.test.MockLogAppender.AbstractEventExpectation
 
innerMatch(LogEvent) - Method in class org.elasticsearch.test.MockLogAppender.ExceptionSeenEventExpectation
 
insertIntoXContent(XContent, BytesReference, List<String>, Supplier<String>, Supplier<Object>) - Static method in class org.elasticsearch.test.XContentTestUtils
Inserts key/value pairs into xContent passed in as BytesReference and returns a new XContentBuilder The paths argument uses dot separated fieldnames and numbers for array indices, similar to what we do in ObjectPath.
insertRandomFields(XContentType, BytesReference, Predicate<String>, Random) - Static method in class org.elasticsearch.test.XContentTestUtils
This method takes the input xContent data and adds a random field value, inner object or array into each json object.
installMock(FileSystem) - Static method in class org.elasticsearch.common.io.PathUtilsForTesting
Installs a mock filesystem for testing
instance() - Static method in class org.elasticsearch.ingest.TestTemplateService
 
instance(boolean) - Static method in class org.elasticsearch.ingest.TestTemplateService
 
INSTANCE - Static variable in class org.elasticsearch.test.gateway.NoopGatewayAllocator
 
instanceReader() - Method in class org.elasticsearch.test.AbstractStreamableTestCase
 
instanceReader() - Method in class org.elasticsearch.test.AbstractWireTestCase
Returns a Writeable.Reader that can be used to de-serialize the instance
INT_ALIAS_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
INT_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
INT_RANGE_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
IntermittentLongGCDisruption - Class in org.elasticsearch.test.disruption
Simulates irregular long gc intervals.
IntermittentLongGCDisruption(Random, String, long, long, long, long) - Constructor for class org.elasticsearch.test.disruption.IntermittentLongGCDisruption
 
InternalAggregationTestCase<T extends InternalAggregation> - Class in org.elasticsearch.test
 
InternalAggregationTestCase() - Constructor for class org.elasticsearch.test.InternalAggregationTestCase
 
internalCluster() - Static method in class org.elasticsearch.test.ESIntegTestCase
 
InternalMultiBucketAggregationTestCase<T extends InternalAggregation & MultiBucketsAggregation> - Class in org.elasticsearch.test
 
InternalMultiBucketAggregationTestCase() - Constructor for class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
InternalSettingsPlugin - Class in org.elasticsearch.test
 
InternalSettingsPlugin() - Constructor for class org.elasticsearch.test.InternalSettingsPlugin
 
InternalSingleBucketAggregationTestCase<T extends InternalSingleBucketAggregation> - Class in org.elasticsearch.search.aggregations
 
InternalSingleBucketAggregationTestCase() - Constructor for class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
 
InternalTestCluster - Class in org.elasticsearch.test
InternalTestCluster manages a set of JVM private nodes and allows convenient access to them.
InternalTestCluster(long, Path, boolean, boolean, int, int, String, NodeConfigurationSource, int, boolean, String, Collection<Class<? extends Plugin>>, Function<Client, Client>) - Constructor for class org.elasticsearch.test.InternalTestCluster
 
InternalTestCluster(long, Path, boolean, boolean, int, int, String, NodeConfigurationSource, int, boolean, String, Collection<Class<? extends Plugin>>, Function<Client, Client>, boolean) - Constructor for class org.elasticsearch.test.InternalTestCluster
 
InternalTestCluster.RestartCallback - Class in org.elasticsearch.test
An abstract class that is called during InternalTestCluster.rollingRestart(InternalTestCluster.RestartCallback) and / or InternalTestCluster.fullRestart(InternalTestCluster.RestartCallback) to execute actions at certain stages of the restart.
intersect(CompiledAutomaton, BytesRef) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.ThrowingTerms
 
Intersect - org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
 
intPage(boolean) - Method in class org.elasticsearch.common.util.MockPageCacheRecycler
 
IP_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
 
isBlockDetectionSupported() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
 
isBodyRequired() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
 
isBodySupported() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
 
isCacheable(QB) - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
isCancelled() - Method in class org.elasticsearch.test.TestSearchContext
 
isClientParameter(String) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestSpec
Returns whether the provided parameter is one of those parameters that are supported by the Elasticsearch language clients, meaning that they influence the client behaviour and don't get sent to Elasticsearch
isClosed() - Method in class org.elasticsearch.test.transport.StubbableTransport.WrappedConnection
 
isDisruptedNodeThread(String) - Method in class org.elasticsearch.test.disruption.LongGCDisruption
 
isEmpty() - Method in class org.elasticsearch.test.rest.yaml.section.SetupSection
 
isEmpty() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
 
isEmpty() - Method in class org.elasticsearch.test.rest.yaml.section.TeardownSection
 
isError() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestResponse
 
IsFalseAssertion - Class in org.elasticsearch.test.rest.yaml.section
Represents an is_false assert section: - is_false: get.fields.bar
IsFalseAssertion(XContentLocation, String) - Constructor for class org.elasticsearch.test.rest.yaml.section.IsFalseAssertion
 
isFlushOnCloseDisabled() - Method in class org.elasticsearch.test.engine.MockEngineSupport
 
isGlobalParameter(String) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestSpec
Returns whether the provided parameter is one of those parameters that are supported by all Elasticsearch api
isInternalCluster() - Static method in class org.elasticsearch.test.ESIntegTestCase
 
isLoaded() - Method in class org.elasticsearch.common.settings.MockSecureSettings
 
IsolateAllNodes(Set<String>) - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.IsolateAllNodes
 
isOpen() - Method in class org.elasticsearch.transport.FakeTcpChannel
 
isOpen() - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
 
isReadOnly() - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
isRunningAgainstOldCluster() - Method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
 
isServerChannel() - Method in class org.elasticsearch.transport.FakeTcpChannel
 
isServerChannel() - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
 
isSingleType() - Static method in class org.elasticsearch.test.AbstractBuilderTestCase
 
isTextField(String) - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
IsTrueAssertion - Class in org.elasticsearch.test.rest.yaml.section
Represents an is_true assert section: - is_true: get.fields.bar
IsTrueAssertion(XContentLocation, String) - Constructor for class org.elasticsearch.test.rest.yaml.section.IsTrueAssertion
 
isVersionCheck() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
 
iterations(int, int) - Static method in class org.elasticsearch.test.ESTestCase
Returns a "scaled" number of iterations for loops which can have a variable iteration count.
iterator() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
iterator() - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.ThrowingTerms
 

J

JAVA_TIMEZONE_IDS - Static variable in class org.elasticsearch.test.ESTestCase
 
JAVA_ZONE_IDS - Static variable in class org.elasticsearch.test.ESTestCase
 
JODA_TIMEZONE_IDS - Static variable in class org.elasticsearch.test.ESTestCase
 
JSON_CONTENT_TYPE - Static variable in class org.elasticsearch.test.fixture.AbstractHttpFixture
 

K

keepAlive() - Method in class org.elasticsearch.test.TestSearchContext
 
keepAlive(long) - Method in class org.elasticsearch.test.TestSearchContext
 

L

lastAccessTime() - Method in class org.elasticsearch.test.TestSearchContext
 
LengthAssertion - Class in org.elasticsearch.test.rest.yaml.section
Represents a length assert section:
LengthAssertion(XContentLocation, String, Object) - Constructor for class org.elasticsearch.test.rest.yaml.section.LengthAssertion
 
LessThanAssertion - Class in org.elasticsearch.test.rest.yaml.section
Represents a lt assert section: - lt: { fields._ttl: 20000}
LessThanAssertion(XContentLocation, String, Object) - Constructor for class org.elasticsearch.test.rest.yaml.section.LessThanAssertion
 
LessThanOrEqualToAssertion - Class in org.elasticsearch.test.rest.yaml.section
Represents a lte assert section: - lte: { fields._ttl: 0 }
LessThanOrEqualToAssertion(XContentLocation, String, Object) - Constructor for class org.elasticsearch.test.rest.yaml.section.LessThanOrEqualToAssertion
 
level - Variable in class org.elasticsearch.test.MockLogAppender.AbstractEventExpectation
 
level - Variable in class org.elasticsearch.test.MockLogAppender.PatternSeenEventExcpectation
 
lifecycleState() - Method in class org.elasticsearch.test.transport.CapturingTransport
 
lifecycleState() - Method in class org.elasticsearch.test.transport.StubbableTransport
 
listen() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture
Opens a HttpServer and start listening on a random port.
listener() - Method in class org.elasticsearch.index.reindex.AbstractAsyncBulkByScrollActionTestCase
 
load(String) - Static method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestSpec
Parses the complete set of REST spec available under the provided directories
loadDataFilesList(String, Path) - Static method in class org.elasticsearch.test.OldIndexUtils
 
logClusterState() - Method in class org.elasticsearch.test.ESIntegTestCase
Prints the current cluster state as debug logging.
logger - Variable in class org.elasticsearch.index.store.EsBaseDirectoryTestCase
 
logger - Variable in class org.elasticsearch.test.disruption.SingleNodeDisruption
 
logger - Variable in class org.elasticsearch.test.ESTestCase
 
logger - Variable in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter
 
logger - Variable in class org.elasticsearch.test.MockLogAppender.AbstractEventExpectation
 
logger - Variable in class org.elasticsearch.test.MockLogAppender.PatternSeenEventExcpectation
 
logger - Variable in class org.elasticsearch.test.TestCluster
 
LoggingListener - Class in org.elasticsearch.test.junit.listeners
A RunListener that allows changing the log level for a specific test method.
LoggingListener() - Constructor for class org.elasticsearch.test.junit.listeners.LoggingListener
 
logMemoryStats() - Method in class org.elasticsearch.test.ESIntegTestCase
Prints current memory stats as info logging.
logSegmentsState(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Prints the segments info for the given indices as debug logging.
LongGCDisruption - Class in org.elasticsearch.test.disruption
Suspends all threads on the specified node in order to simulate a long gc.
LongGCDisruption(Random, String) - Constructor for class org.elasticsearch.test.disruption.LongGCDisruption
 
longPage(boolean) - Method in class org.elasticsearch.common.util.MockPageCacheRecycler
 
lowLevelCancellation() - Method in class org.elasticsearch.test.TestSearchContext
 

M

makeTestChanges(T) - Method in class org.elasticsearch.test.AbstractDiffableSerializationTestCase
Introduces random changes into the test object
makeTestChanges(T) - Method in class org.elasticsearch.test.AbstractDiffableWireSerializationTestCase
Introduces random changes into the test object
MAPPED_FIELD_NAMES - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
MAPPED_LEAF_FIELD_NAMES - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
mapperService() - Method in class org.elasticsearch.test.TestSearchContext
 
mapperServiceMock() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
sub-tests that need a more complex mock can overwrite this
MapperTestUtils - Class in org.elasticsearch.index
 
MapperTestUtils() - Constructor for class org.elasticsearch.index.MapperTestUtils
 
mappingUpdate - Variable in class org.elasticsearch.index.engine.TranslogHandler
 
MASTER_DATA_ROLES - Static variable in class org.elasticsearch.cluster.ESAllocationTestCase
 
masterClient() - Method in class org.elasticsearch.test.InternalTestCluster
Returns a node client to the current master node.
match(LogEvent) - Method in class org.elasticsearch.test.MockLogAppender.AbstractEventExpectation
 
match(LogEvent) - Method in interface org.elasticsearch.test.MockLogAppender.LoggingExpectation
 
match(LogEvent) - Method in class org.elasticsearch.test.MockLogAppender.PatternSeenEventExcpectation
 
MatchAssertion - Class in org.elasticsearch.test.rest.yaml.section
Represents a match assert section: - match: { get.fields._routing: "5" }
MatchAssertion(XContentLocation, String, Object) - Constructor for class org.elasticsearch.test.rest.yaml.section.MatchAssertion
 
matches(String) - Static method in class org.elasticsearch.test.hamcrest.RegexMatcher
 
matches(String, int) - Static method in class org.elasticsearch.test.hamcrest.RegexMatcher
 
matches(Set<String>) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestPath
 
matchesSafely(String) - Method in class org.elasticsearch.test.hamcrest.RegexMatcher
 
matchesSafely(ImmutableOpenMap) - Method in class org.elasticsearch.test.hamcrest.CollectionMatchers.ImmutableOpenMapHasAllKeysMatcher
 
matchesSafely(ImmutableOpenMap) - Method in class org.elasticsearch.test.hamcrest.CollectionMatchers.ImmutableOpenMapHasKeyMatcher
 
matchesSafely(SearchHit) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasIdMatcher
 
matchesSafely(SearchHit) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasIndexMatcher
 
matchesSafely(SearchHit) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasScoreMatcher
 
matchesSafely(SearchHit) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasTypeMatcher
 
maxCompatibleVersion(Version) - Static method in class org.elasticsearch.test.VersionUtils
Returns the maximum Version that is compatible with the given version.
maximumNumberOfReplicas() - Method in class org.elasticsearch.test.ESIntegTestCase
 
maximumNumberOfShards() - Method in class org.elasticsearch.test.ESIntegTestCase
 
maxNumberOfBuckets() - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
maxNumDataNodes() - Method in annotation type org.elasticsearch.test.ESIntegTestCase.ClusterScope
Returns the maximum number of data nodes in the cluster.
maxValue - Static variable in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
maxValues - Static variable in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
maybeOverrideConnectionProfile(ConnectionProfile) - Method in class org.elasticsearch.transport.MockTcpTransport
 
maybeSet(Consumer<T>, T) - Static method in class org.elasticsearch.test.ESTestCase
helper to randomly perform on consumer with value
maybeThrow(ThrowingLeafReaderWrapper.Flags) - Method in interface org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Thrower
Maybe throws an exception ;)
maybeWrapReaderEs(DirectoryReader) - Static method in class org.elasticsearch.search.aggregations.AggregatorTestCase
Added to randomly run with more assertions on the index reader level, like LuceneTestCase.wrapReader(IndexReader), which can't be used because it also wraps in the IndexReader with other implementations that we can't handle.
merge(MockSecureSettings) - Method in class org.elasticsearch.common.settings.MockSecureSettings
Merge the given secure settings into this one.
MERGE_ENABLED - Static variable in class org.elasticsearch.test.InternalSettingsPlugin
 
message - Variable in class org.elasticsearch.test.MockLogAppender.AbstractEventExpectation
 
method() - Method in class org.elasticsearch.test.rest.FakeRestRequest
 
minimumNumberOfReplicas() - Method in class org.elasticsearch.test.ESIntegTestCase
 
minimumNumberOfShards() - Method in class org.elasticsearch.test.ESIntegTestCase
 
minimumScore() - Method in class org.elasticsearch.test.TestSearchContext
 
minimumScore(float) - Method in class org.elasticsearch.test.TestSearchContext
 
minNumberOfBuckets() - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
minNumDataNodes() - Method in annotation type org.elasticsearch.test.ESIntegTestCase.ClusterScope
Returns the minimum number of data nodes in the cluster.
minValue - Static variable in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
minValues - Static variable in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
MOCK_TCP_TRANSPORT_NAME - Static variable in class org.elasticsearch.transport.MockTcpTransportPlugin
 
MockAllocationService(AllocationDeciders, GatewayAllocator, ShardsAllocator, ClusterInfoService) - Constructor for class org.elasticsearch.cluster.ESAllocationTestCase.MockAllocationService
 
MockBigArrays - Class in org.elasticsearch.common.util
 
MockBigArrays(PageCacheRecycler, CircuitBreakerService) - Constructor for class org.elasticsearch.common.util.MockBigArrays
 
MockCompiledScript(String, Map<String, String>, String, Function<Map<String, Object>, Object>) - Constructor for class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
 
MockContext(Random, boolean, Class<? extends FilterDirectoryReader>, Settings) - Constructor for class org.elasticsearch.test.engine.MockEngineSupport.MockContext
 
MockEngineFactory - Class in org.elasticsearch.test.engine
 
MockEngineFactory(Class<? extends FilterDirectoryReader>) - Constructor for class org.elasticsearch.test.engine.MockEngineFactory
 
MockEngineFactoryPlugin - Class in org.elasticsearch.index
A plugin to use MockEngineFactory.
MockEngineFactoryPlugin() - Constructor for class org.elasticsearch.index.MockEngineFactoryPlugin
 
MockEngineSupport - Class in org.elasticsearch.test.engine
Support class to build MockEngines like MockInternalEngine since they need to subclass the actual engine
MockEngineSupport(EngineConfig, Class<? extends FilterDirectoryReader>) - Constructor for class org.elasticsearch.test.engine.MockEngineSupport
 
MockEngineSupport.DirectoryReaderWrapper - Class in org.elasticsearch.test.engine
 
MockEngineSupport.MockContext - Class in org.elasticsearch.test.engine
 
MockFieldFilterPlugin - Class in org.elasticsearch.index.mapper
 
MockFieldFilterPlugin() - Constructor for class org.elasticsearch.index.mapper.MockFieldFilterPlugin
 
MockFieldMapper - Class in org.elasticsearch.index.mapper
 
MockFieldMapper(String) - Constructor for class org.elasticsearch.index.mapper.MockFieldMapper
 
MockFieldMapper(String, MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.MockFieldMapper
 
MockFieldMapper.FakeFieldType - Class in org.elasticsearch.index.mapper
 
MockFilterScript(SearchLookup, Map<String, Object>, Function<Map<String, Object>, Object>) - Constructor for class org.elasticsearch.script.MockScriptEngine.MockFilterScript
 
MockFSDirectoryService - Class in org.elasticsearch.test.store
 
MockFSDirectoryService(IndexSettings, ShardPath) - Constructor for class org.elasticsearch.test.store.MockFSDirectoryService
 
MockFSDirectoryService.ElasticsearchMockDirectoryWrapper - Class in org.elasticsearch.test.store
 
MockFSIndexStore - Class in org.elasticsearch.test.store
 
MockFSIndexStore.TestPlugin - Class in org.elasticsearch.test.store
 
MockIndexEventListener - Class in org.elasticsearch.test
This is a testing plugin that registers a generic MockIndexEventListener.TestEventListener as a node level service as well as a listener on every index.
MockIndexEventListener() - Constructor for class org.elasticsearch.test.MockIndexEventListener
 
MockIndexEventListener.TestEventListener - Class in org.elasticsearch.test
 
MockIndexEventListener.TestPlugin - Class in org.elasticsearch.test
 
mockInlineScript(String) - Static method in class org.elasticsearch.script.MockScriptEngine
 
MockInternalClusterInfoService - Class in org.elasticsearch.cluster
 
MockInternalClusterInfoService(Settings, ClusterService, ThreadPool, NodeClient, Consumer<ClusterInfo>) - Constructor for class org.elasticsearch.cluster.MockInternalClusterInfoService
 
MockInternalClusterInfoService.TestPlugin - Class in org.elasticsearch.cluster
This is a marker plugin used to trigger MockNode to use this mock info service.
MockKeywordPlugin - Class in org.elasticsearch.test
Some tests rely on the keyword tokenizer, but this tokenizer isn't part of lucene-core and therefor not available in some modules.
MockKeywordPlugin() - Constructor for class org.elasticsearch.test.MockKeywordPlugin
 
MockLogAppender - Class in org.elasticsearch.test
Test appender that can be used to verify that certain events were logged correctly
MockLogAppender() - Constructor for class org.elasticsearch.test.MockLogAppender
 
MockLogAppender.AbstractEventExpectation - Class in org.elasticsearch.test
 
MockLogAppender.ExceptionSeenEventExpectation - Class in org.elasticsearch.test
 
MockLogAppender.LoggingExpectation - Interface in org.elasticsearch.test
 
MockLogAppender.PatternSeenEventExcpectation - Class in org.elasticsearch.test
 
MockLogAppender.SeenEventExpectation - Class in org.elasticsearch.test
 
MockLogAppender.UnseenEventExpectation - Class in org.elasticsearch.test
 
MockMovingFunctionScript() - Constructor for class org.elasticsearch.script.MockScriptEngine.MockMovingFunctionScript
 
MockNode - Class in org.elasticsearch.node
A node for testing which allows: Overriding Version.CURRENT Adding test plugins that exist on the classpath
MockNode(Settings, Collection<Class<? extends Plugin>>) - Constructor for class org.elasticsearch.node.MockNode
 
MockNode(Settings, Collection<Class<? extends Plugin>>, boolean) - Constructor for class org.elasticsearch.node.MockNode
 
MockNode(Settings, Collection<Class<? extends Plugin>>, Path) - Constructor for class org.elasticsearch.node.MockNode
 
MockNode(Settings, Collection<Class<? extends Plugin>>, Path, boolean) - Constructor for class org.elasticsearch.node.MockNode
 
MockNode(Environment, Collection<Class<? extends Plugin>>) - Constructor for class org.elasticsearch.node.MockNode
 
MockPageCacheRecycler - Class in org.elasticsearch.common.util
 
MockPageCacheRecycler(Settings) - Constructor for class org.elasticsearch.common.util.MockPageCacheRecycler
 
mockScript(String) - Static method in class org.elasticsearch.test.ESTestCase
Create a "mock" script for use either with MockScriptEngine or anywhere where you need a script but don't really care about its contents.
MockScriptEngine - Class in org.elasticsearch.script
A mocked script engine that can be used for testing purpose.
MockScriptEngine() - Constructor for class org.elasticsearch.script.MockScriptEngine
 
MockScriptEngine(String, Map<String, Function<Map<String, Object>, Object>>, Map<ScriptContext<?>, MockScriptEngine.ContextCompiler>) - Constructor for class org.elasticsearch.script.MockScriptEngine
 
MockScriptEngine.ContextCompiler - Interface in org.elasticsearch.script
A non-typed compiler for a single custom context
MockScriptEngine.MockCompiledScript - Class in org.elasticsearch.script
 
MockScriptEngine.MockFilterScript - Class in org.elasticsearch.script
 
MockScriptEngine.MockMetricAggCombineScript - Class in org.elasticsearch.script
 
MockScriptEngine.MockMetricAggInitScript - Class in org.elasticsearch.script
 
MockScriptEngine.MockMetricAggMapScript - Class in org.elasticsearch.script
 
MockScriptEngine.MockMetricAggReduceScript - Class in org.elasticsearch.script
 
MockScriptEngine.MockMovingFunctionScript - Class in org.elasticsearch.script
 
MockScriptEngine.MockScoreScript - Class in org.elasticsearch.script
 
MockScriptEngine.MockSearchScript - Class in org.elasticsearch.script
 
MockScriptEngine.MockSimilarityScript - Class in org.elasticsearch.script
 
MockScriptEngine.MockSimilarityWeightScript - Class in org.elasticsearch.script
 
MockScriptPlugin - Class in org.elasticsearch.script
A script plugin that uses MockScriptEngine as the script engine for tests.
MockScriptPlugin() - Constructor for class org.elasticsearch.script.MockScriptPlugin
 
mockScriptService() - Method in class org.elasticsearch.test.InternalAggregationTestCase
overwrite in tests that need it
MockSearchScript(SearchLookup, Map<String, Object>, Function<Map<String, Object>, Object>) - Constructor for class org.elasticsearch.script.MockScriptEngine.MockSearchScript
 
MockSearchService - Class in org.elasticsearch.search
 
MockSearchService(ClusterService, IndicesService, ThreadPool, ScriptService, BigArrays, FetchPhase) - Constructor for class org.elasticsearch.search.MockSearchService
 
MockSearchService.TestPlugin - Class in org.elasticsearch.search
Marker plugin used by MockNode to enable MockSearchService.
MockSecureSettings - Class in org.elasticsearch.common.settings
A mock implementation of secure settings for tests to use.
MockSecureSettings() - Constructor for class org.elasticsearch.common.settings.MockSecureSettings
 
MockTaskManager - Class in org.elasticsearch.test.tasks
A mock task manager that allows adding listeners for events
MockTaskManager(Settings, ThreadPool, Set<String>) - Constructor for class org.elasticsearch.test.tasks.MockTaskManager
 
MockTaskManagerListener - Interface in org.elasticsearch.test.tasks
Listener for task registration/unregistration
MockTcpTransport - Class in org.elasticsearch.transport
This is a socket based blocking TcpTransport implementation that is used for tests that need real networking.
MockTcpTransport(Settings, ThreadPool, BigArrays, CircuitBreakerService, NamedWriteableRegistry, NetworkService) - Constructor for class org.elasticsearch.transport.MockTcpTransport
 
MockTcpTransport(Settings, ThreadPool, BigArrays, CircuitBreakerService, NamedWriteableRegistry, NetworkService, Version) - Constructor for class org.elasticsearch.transport.MockTcpTransport
 
MockTcpTransport.MockChannel - Class in org.elasticsearch.transport
 
MockTcpTransportPlugin - Class in org.elasticsearch.transport
 
MockTcpTransportPlugin() - Constructor for class org.elasticsearch.transport.MockTcpTransportPlugin
 
MockTerminal - Class in org.elasticsearch.cli
A terminal for tests which captures all output, and can be plugged with fake input.
MockTerminal() - Constructor for class org.elasticsearch.cli.MockTerminal
 
MockTransportClient - Class in org.elasticsearch.transport
 
MockTransportClient(Settings, Class<? extends Plugin>...) - Constructor for class org.elasticsearch.transport.MockTransportClient
 
MockTransportClient(Settings, Collection<Class<? extends Plugin>>) - Constructor for class org.elasticsearch.transport.MockTransportClient
 
MockTransportClient(Settings, Collection<Class<? extends Plugin>>, TransportClient.HostFailureListener) - Constructor for class org.elasticsearch.transport.MockTransportClient
 
MockTransportService - Class in org.elasticsearch.test.transport
A mock delegate service that allows to simulate different network topology failures.
MockTransportService(Settings, Transport, ThreadPool, TransportInterceptor, Function<BoundTransportAddress, DiscoveryNode>, ClusterSettings, Set<String>) - Constructor for class org.elasticsearch.test.transport.MockTransportService
Build the service.
MockTransportService(Settings, Transport, ThreadPool, TransportInterceptor, ClusterSettings) - Constructor for class org.elasticsearch.test.transport.MockTransportService
Build the service.
MockTransportService.TestPlugin - Class in org.elasticsearch.test.transport
 
MockTransportService.Tracer - Class in org.elasticsearch.test.transport
 
MockZenPing - Class in org.elasticsearch.test.discovery
A ZenPing implementation which returns results based on a static in-memory map.
MockZenPing(PingContextProvider) - Constructor for class org.elasticsearch.test.discovery.MockZenPing
 
Modifier(String, boolean) - Constructor for class org.elasticsearch.index.mapper.FieldTypeTestCase.Modifier
 
modify(MappedFieldType) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase.Modifier
Modifies the property
ModuleTestCase - Class in org.elasticsearch.common.inject
Base testcase for testing Module implementations.
ModuleTestCase() - Constructor for class org.elasticsearch.common.inject.ModuleTestCase
 
moveToStarted(ShardRouting) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
 
moveToUnassigned(ShardRouting, UnassignedInfo) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
 
mutate(T) - Method in interface org.elasticsearch.test.EqualsHashCodeTestUtils.MutateFunction
 
mutateInstance(QB) - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
mutateInstance(T) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
 
mutateInstance(T) - Method in class org.elasticsearch.test.AbstractWireTestCase
Returns an instance which is mutated slightly so it should not be equal to the given instance.
MyFilterTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
MyFilterTokenFilterFactory(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.MyFilterTokenFilterFactory
 

N

name - Variable in class org.elasticsearch.test.MockLogAppender.AbstractEventExpectation
 
name - Variable in class org.elasticsearch.test.MockLogAppender.PatternSeenEventExcpectation
 
NAME - Static variable in class org.elasticsearch.script.MockScriptEngine
 
NAME - Static variable in class org.elasticsearch.script.MockScriptPlugin
 
namedWriteableRegistry() - Method in class org.elasticsearch.test.AbstractBuilderTestCase
 
nameFilter(String...) - Static method in class org.elasticsearch.test.InternalTestCluster
Returns a predicate that only accepts settings of nodes with one of the given names.
needs_score() - Method in class org.elasticsearch.script.MockScriptEngine.MockSearchScript
 
nestedParsedDocFactory() - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
Network - Annotation Type in org.elasticsearch.test.junit.annotations
Annotation used to set if internet network connectivity is required to run the test.
NetworkDelay(TimeValue) - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDelay
Delays requests by a fixed time value.
NetworkDisconnect() - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDisconnect
 
NetworkDisruption - Class in org.elasticsearch.test.disruption
Network disruptions are modeled using two components: 1) the NetworkDisruption.DisruptedLinks represents the links in the network that are to be disrupted 2) the NetworkDisruption.NetworkLinkDisruptionType represents the failure mode that is to be applied to the links
NetworkDisruption(NetworkDisruption.DisruptedLinks, NetworkDisruption.NetworkLinkDisruptionType) - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption
 
NetworkDisruption.Bridge - Class in org.elasticsearch.test.disruption
Creates two partitions with symmetric failures and a bridge node that can connect to both of the partitions
NetworkDisruption.DisruptedLinks - Class in org.elasticsearch.test.disruption
Represents a set of nodes with connections between nodes that are to be disrupted
NetworkDisruption.IsolateAllNodes - Class in org.elasticsearch.test.disruption
 
NetworkDisruption.NetworkDelay - Class in org.elasticsearch.test.disruption
Simulates slow or congested network.
NetworkDisruption.NetworkDisconnect - Class in org.elasticsearch.test.disruption
Simulates a network disconnect.
NetworkDisruption.NetworkLinkDisruptionType - Class in org.elasticsearch.test.disruption
Abstract class representing various types of network disruptions.
NetworkDisruption.NetworkUnresponsive - Class in org.elasticsearch.test.disruption
Simulates an unresponsive target node by dropping requests sent from source to target node.
NetworkDisruption.TwoPartitions - Class in org.elasticsearch.test.disruption
Creates two partitions with symmetric failures
NetworkLinkDisruptionType() - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.NetworkLinkDisruptionType
 
NetworkUnresponsive() - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.NetworkUnresponsive
 
newAnalysisSettingsBuilder() - Method in class org.elasticsearch.test.ESTokenStreamTestCase
 
newBlobStore() - Method in class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
 
newBlobStore() - Method in class org.elasticsearch.repositories.ESBlobStoreTestCase
 
newBuilder() - Method in class org.elasticsearch.test.rest.FakeRestChannel
 
newBuilder(XContentType, boolean) - Method in class org.elasticsearch.test.rest.FakeRestChannel
 
newByteArray(long, boolean) - Method in class org.elasticsearch.common.util.MockBigArrays
 
newBytesOutput() - Method in class org.elasticsearch.test.rest.FakeRestChannel
 
newBytesReference(int) - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
newBytesReferenceWithOffsetOfZero(int) - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
newClusterInfoService(Settings, ClusterService, ThreadPool, NodeClient, Consumer<ClusterInfo>) - Method in class org.elasticsearch.node.MockNode
 
newCommand() - Method in class org.elasticsearch.cli.CommandTestCase
Creates a Command to test execution.
newDirectory() - Method in class org.elasticsearch.test.store.MockFSDirectoryService
 
newDirectoryService(ShardPath) - Method in class org.elasticsearch.test.store.MockFSIndexStore
 
newDoubleArray(long, boolean) - Method in class org.elasticsearch.common.util.MockBigArrays
 
newEnvironment(Settings) - Static method in class org.elasticsearch.env.TestEnvironment
 
newErrorBuilder() - Method in class org.elasticsearch.test.rest.FakeRestChannel
 
newFactory(Map<String, Object>, SearchLookup) - Method in class org.elasticsearch.script.MockScriptEngine.MockScoreScript
 
newFloatArray(long, boolean) - Method in class org.elasticsearch.common.util.MockBigArrays
 
newFSDirectory(Path, LockFactory) - Method in class org.elasticsearch.test.store.MockFSDirectoryService
 
newGet(boolean, ParsedDocument) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
newIndexSearcher(IndexReader) - Static method in class org.elasticsearch.search.aggregations.AggregatorTestCase
Added to randomly run with more assertions on the index searcher level, like LuceneTestCase.newSearcher(IndexReader), which can't be used because it also wraps in the IndexSearcher's IndexReader with other implementations that we can't handle.
newIndexSettings(String, Settings, Setting<?>...) - Static method in class org.elasticsearch.test.IndexSettingsModule
 
newIndexSettings(IndexMetaData, Setting<?>...) - Static method in class org.elasticsearch.test.IndexSettingsModule
 
newIndexSettings(Index, Settings, IndexScopedSettings) - Static method in class org.elasticsearch.test.IndexSettingsModule
 
newIndexSettings(Index, Settings, Setting<?>...) - Static method in class org.elasticsearch.test.IndexSettingsModule
 
newIndexSettings(Index, Settings, Settings, Setting<?>...) - Static method in class org.elasticsearch.test.IndexSettingsModule
 
newInstance(String[]) - Static method in class org.elasticsearch.common.logging.TestThreadInfoPatternConverter
Called by log4j2 to initialize this converter.
newInstance(Map<String, Object>) - Method in class org.elasticsearch.ingest.TestTemplateService.MockTemplateScript.Factory
 
newInstance(LeafReaderContext) - Method in class org.elasticsearch.script.MockScriptEngine.MockFilterScript
 
newInstance(LeafReaderContext) - Method in class org.elasticsearch.script.MockScriptEngine.MockMetricAggMapScript
 
newInstance(LeafReaderContext) - Method in class org.elasticsearch.script.MockScriptEngine.MockSearchScript
 
newIntArray(long, boolean) - Method in class org.elasticsearch.common.util.MockBigArrays
 
newLongArray(long, boolean) - Method in class org.elasticsearch.common.util.MockBigArrays
 
newMapperService(NamedXContentRegistry, Path, Settings, String) - Static method in class org.elasticsearch.index.MapperTestUtils
 
newMapperService(NamedXContentRegistry, Path, Settings, IndicesModule, String) - Static method in class org.elasticsearch.index.MapperTestUtils
 
newMockTransport(Settings, Version, ThreadPool) - Static method in class org.elasticsearch.test.transport.MockTransportService
 
newNode(String) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
newNode(String, String, Map<String, String>) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
newNode(String, Map<String, String>) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
newNode(String, Set<DiscoveryNode.Role>) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
newNode(String, Version) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
newNodeEnvironment() - Method in class org.elasticsearch.test.ESTestCase
 
newNodeEnvironment(Settings) - Method in class org.elasticsearch.test.ESTestCase
 
newObjectArray(long) - Method in class org.elasticsearch.common.util.MockBigArrays
 
newReadWriteEngine(EngineConfig) - Method in class org.elasticsearch.test.engine.MockEngineFactory
 
newSearcher(Engine.Searcher) - Method in class org.elasticsearch.test.engine.MockEngineSupport
 
newSearchService(ClusterService, IndicesService, ThreadPool, ScriptService, BigArrays, FetchPhase, ResponseCollectorService) - Method in class org.elasticsearch.node.MockNode
 
newShard(boolean) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
creates a new initializing shard.
newShard(boolean, Settings) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
Creates a new initializing shard.
newShard(boolean, Settings, EngineFactory) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
Creates a new initializing shard.
newShard(ShardRouting, IndexMetaData, EngineFactory, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
creates a new initializing shard.
newShard(ShardRouting, IndexMetaData, IndexSearcherWrapper, EngineFactory, Runnable, RetentionLeaseSyncer, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
creates a new initializing shard.
newShard(ShardRouting, Settings, EngineFactory, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
Creates a new initializing shard.
newShard(ShardRouting, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
newShard(ShardRouting, ShardPath, IndexMetaData, CheckedFunction<IndexSettings, Store, IOException>, IndexSearcherWrapper, EngineFactory, Runnable, RetentionLeaseSyncer, IndexEventListener, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
creates a new initializing shard.
newShard(ShardId, boolean, String, IndexMetaData, IndexSearcherWrapper) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
creates a new initializing shard.
newShard(ShardId, boolean, String, IndexMetaData, IndexSearcherWrapper, Runnable) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
creates a new initializing shard.
newShard(ShardId, boolean, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
creates a new initializing shard.
newShardRouting(String, int, String, boolean, ShardRoutingState) - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
 
newShardRouting(String, int, String, String, boolean, ShardRoutingState) - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
 
newShardRouting(String, int, String, String, boolean, ShardRoutingState, AllocationId) - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
 
newShardRouting(String, int, String, String, boolean, ShardRoutingState, UnassignedInfo) - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
 
newShardRouting(ShardId, String, boolean, ShardRoutingState) - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
 
newShardRouting(ShardId, String, boolean, ShardRoutingState, RecoverySource) - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
 
newShardRouting(ShardId, String, String, boolean, ShardRoutingState) - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
 
newShardRouting(ShardId, String, String, boolean, ShardRoutingState, AllocationId) - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
 
newShardRouting(ShardId, String, String, boolean, ShardRoutingState, UnassignedInfo) - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
 
newStartedShard() - Method in class org.elasticsearch.index.shard.IndexShardTestCase
Creates a new empty shard and starts it.
newStartedShard(boolean) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
creates a new empty shard and starts it.
newStartedShard(boolean, Settings) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
Creates a new empty shard and starts it.
newStartedShard(boolean, Settings, EngineFactory) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
Creates a new empty shard with the specified settings and engine factory and starts it.
newStartedShard(CheckedFunction<Boolean, IndexShard, IOException>, boolean) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
creates a new empty shard and starts it.
newTestIndicesModule(Map<String, Mapper.TypeParser>, Map<String, MetadataFieldMapper.TypeParser>) - Static method in class org.elasticsearch.test.ESTestCase
Creates an IndicesModule for testing with the given mappers and metadata mappers.
newTestScriptModule() - Static method in class org.elasticsearch.test.ESTestCase
 
newTransportService(Settings, Transport, ThreadPool, TransportInterceptor, Function<BoundTransportAddress, DiscoveryNode>, ClusterSettings, Set<String>) - Method in class org.elasticsearch.node.MockNode
 
newUid(String) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
newUid(ParsedDocument) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
newWithRestoreSource(ShardRouting, RecoverySource.SnapshotRecoverySource) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
 
newZenPing(Settings, ThreadPool, TransportService, UnicastHostsProvider) - Method in class org.elasticsearch.test.discovery.TestZenDiscovery
 
noAllocationDeciders() - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
node - Variable in class org.elasticsearch.test.transport.CapturingTransport.CapturedRequest
 
node() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
Return a reference to the singleton node.
nodeA - Variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
nodeB - Variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
nodeConfigPath(int) - Method in class org.elasticsearch.test.ESIntegTestCase
 
nodeConfigPath(int) - Method in class org.elasticsearch.test.NodeConfigurationSource
 
NodeConfigurationSource - Class in org.elasticsearch.test
 
NodeConfigurationSource() - Constructor for class org.elasticsearch.test.NodeConfigurationSource
 
nodeConnected(DiscoveryNode) - Method in class org.elasticsearch.test.transport.CapturingTransport
 
nodeConnected(DiscoveryNode) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
nodeConnected(ConnectionManager, DiscoveryNode) - Method in interface org.elasticsearch.test.transport.StubbableConnectionManager.NodeConnectedBehavior
 
NodeMocksPlugin - Class in org.elasticsearch.node
 
NodeMocksPlugin() - Constructor for class org.elasticsearch.node.NodeMocksPlugin
 
NodeNameInLogsIntegTestCase - Class in org.elasticsearch.common.logging
Tests that extend this class verify that the node name appears in the first few log lines on startup.
NodeNameInLogsIntegTestCase() - Constructor for class org.elasticsearch.common.logging.NodeNameInLogsIntegTestCase
 
nodePlugins() - Method in class org.elasticsearch.test.ESIntegTestCase
Returns a collection of plugins that should be loaded on each node.
nodePlugins() - Method in class org.elasticsearch.test.NodeConfigurationSource
Returns plugins that should be loaded on the node
nodePrefix() - Method in class org.elasticsearch.test.InternalTestCluster
Returns the common node name prefix for this test cluster.
nodes() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.DisruptedLinks
Set of all nodes that can participate in disruptions
nodeSettings() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
Additional settings to add when creating the node.
nodeSettings(int) - Method in class org.elasticsearch.test.ESIntegTestCase
This method is used to obtain settings for the Nth node in the cluster.
nodeSettings(int) - Method in class org.elasticsearch.test.NodeConfigurationSource
 
nodesInclude(String) - Method in class org.elasticsearch.test.InternalTestCluster
Returns a set of nodes that have at least one shard of the given index.
nodesSideOne - Variable in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
 
nodesSideTwo - Variable in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
 
nonMasterClient() - Method in class org.elasticsearch.test.InternalTestCluster
Returns a node client to random node but not the master.
NoOpClient - Class in org.elasticsearch.test.client
Client that always responds with null to every request.
NoOpClient(String) - Constructor for class org.elasticsearch.test.client.NoOpClient
Create a new TestThreadPool for this client.
NoOpClient(ThreadPool) - Constructor for class org.elasticsearch.test.client.NoOpClient
Build with ThreadPool.
NoopGatewayAllocator - Class in org.elasticsearch.test.gateway
An allocator used for tests that doesn't do anything
NoopGatewayAllocator() - Constructor for class org.elasticsearch.test.gateway.NoopGatewayAllocator
 
normalizeOther(MappedFieldType) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase.Modifier
Optional method to implement that allows the field type that will be compared to be modified, so that it does not have the default value for the property being modified.
Norms - org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
 
NOT_SUPPORTED - org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Body
 
NotEqualMessageBuilder - Class in org.elasticsearch.test
Builds a message describing how two sets of values are unequal.
NotEqualMessageBuilder() - Constructor for class org.elasticsearch.test.NotEqualMessageBuilder
The name of the field being compared.
NullDispatcher - Class in org.elasticsearch.http
 
NullDispatcher() - Constructor for class org.elasticsearch.http.NullDispatcher
 
NUMBER_OF_DIFF_TEST_RUNS - Static variable in class org.elasticsearch.test.DiffableTestUtils
 
NUMBER_OF_TEST_RUNS - Static variable in class org.elasticsearch.test.AbstractWireTestCase
 
NUMBER_OF_TEST_RUNS - Static variable in class org.elasticsearch.test.AbstractXContentTestCase
 
numberOfReplicas() - Method in class org.elasticsearch.test.ESIntegTestCase
 
numberOfShards() - Method in class org.elasticsearch.test.ESIntegTestCase
 
numberOfShards() - Method in class org.elasticsearch.test.TestSearchContext
 
numberOfTestRuns(int) - Method in class org.elasticsearch.test.AbstractXContentTestCase.XContentTester
 
numClientNodes() - Method in annotation type org.elasticsearch.test.ESIntegTestCase.ClusterScope
Returns the number of client nodes in the cluster.
numDataAndMasterNodes() - Method in class org.elasticsearch.test.ExternalTestCluster
 
numDataAndMasterNodes() - Method in class org.elasticsearch.test.InternalTestCluster
 
numDataAndMasterNodes() - Method in class org.elasticsearch.test.TestCluster
Returns the number of data and master eligible nodes in the cluster.
numDataNodes() - Method in annotation type org.elasticsearch.test.ESIntegTestCase.ClusterScope
Returns the number of nodes in the cluster.
numDataNodes() - Method in class org.elasticsearch.test.ExternalTestCluster
 
numDataNodes() - Method in class org.elasticsearch.test.InternalTestCluster
 
numDataNodes() - Method in class org.elasticsearch.test.TestCluster
Returns the number of data nodes in the cluster.
NumericDocValues - org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
 
numMasterNodes() - Method in class org.elasticsearch.test.InternalTestCluster
 
numPrimaries - Variable in class org.elasticsearch.test.ESIntegTestCase.NumShards
 
numReplicas - Variable in class org.elasticsearch.test.ESIntegTestCase.NumShards
 

O

OBJECT_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
objectPage() - Method in class org.elasticsearch.common.util.MockPageCacheRecycler
 
ObjectPath - Class in org.elasticsearch.test.rest.yaml
Holds an object and allows to extract specific values from it given their path
ObjectPath(Object) - Constructor for class org.elasticsearch.test.rest.yaml.ObjectPath
 
OldIndexUtils - Class in org.elasticsearch.test
 
OldIndexUtils() - Constructor for class org.elasticsearch.test.OldIndexUtils
 
onBlockDetected(ThreadInfo, ThreadInfo) - Method in class org.elasticsearch.test.disruption.LongGCDisruption
 
onIndexModule(IndexModule) - Method in class org.elasticsearch.test.MockIndexEventListener.TestPlugin
 
onIndexModule(IndexModule) - Method in class org.elasticsearch.test.store.MockFSIndexStore.TestPlugin
 
onNodeStopped(String) - Method in class org.elasticsearch.test.InternalTestCluster.RestartCallback
Executed once the give node name has been stopped.
onSendRequest(long, String, TransportRequest, DiscoveryNode) - Method in class org.elasticsearch.test.transport.CapturingTransport
 
onShardInactive(IndexShard) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
onTaskRegistered(Task) - Method in interface org.elasticsearch.test.tasks.MockTaskManagerListener
 
onTaskUnregistered(Task) - Method in interface org.elasticsearch.test.tasks.MockTaskManagerListener
 
openConnection(DiscoveryNode, ConnectionProfile) - Method in class org.elasticsearch.test.transport.MockTransportService
 
openConnection(DiscoveryNode, ConnectionProfile) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
openConnection(DiscoveryNode, ConnectionProfile, ActionListener<Transport.Connection>) - Method in class org.elasticsearch.test.transport.CapturingTransport
 
openConnection(DiscoveryNode, ConnectionProfile, ActionListener<Transport.Connection>) - Method in class org.elasticsearch.test.transport.StubbableTransport
 
openConnection(Transport, DiscoveryNode, ConnectionProfile, ActionListener<Transport.Connection>) - Method in interface org.elasticsearch.test.transport.StubbableTransport.OpenConnectionBehavior
 
openIndex(String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
openReader(Path) - Method in class org.elasticsearch.common.logging.NodeNameInLogsIntegTestCase
Open the log file.
OPTIONAL - org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Body
 
org.elasticsearch.action.support.replication - package org.elasticsearch.action.support.replication
 
org.elasticsearch.bootstrap - package org.elasticsearch.bootstrap
 
org.elasticsearch.cli - package org.elasticsearch.cli
 
org.elasticsearch.client - package org.elasticsearch.client
 
org.elasticsearch.cluster - package org.elasticsearch.cluster
 
org.elasticsearch.cluster.coordination - package org.elasticsearch.cluster.coordination
 
org.elasticsearch.cluster.routing - package org.elasticsearch.cluster.routing
 
org.elasticsearch.common.bytes - package org.elasticsearch.common.bytes
 
org.elasticsearch.common.inject - package org.elasticsearch.common.inject
 
org.elasticsearch.common.io - package org.elasticsearch.common.io
 
org.elasticsearch.common.logging - package org.elasticsearch.common.logging
 
org.elasticsearch.common.settings - package org.elasticsearch.common.settings
 
org.elasticsearch.common.util - package org.elasticsearch.common.util
 
org.elasticsearch.env - package org.elasticsearch.env
 
org.elasticsearch.http - package org.elasticsearch.http
 
org.elasticsearch.index - package org.elasticsearch.index
 
org.elasticsearch.index.alias - package org.elasticsearch.index.alias
 
org.elasticsearch.index.analysis - package org.elasticsearch.index.analysis
 
org.elasticsearch.index.engine - package org.elasticsearch.index.engine
 
org.elasticsearch.index.mapper - package org.elasticsearch.index.mapper
 
org.elasticsearch.index.reindex - package org.elasticsearch.index.reindex
 
org.elasticsearch.index.replication - package org.elasticsearch.index.replication
 
org.elasticsearch.index.shard - package org.elasticsearch.index.shard
 
org.elasticsearch.index.store - package org.elasticsearch.index.store
 
org.elasticsearch.index.translog - package org.elasticsearch.index.translog
 
org.elasticsearch.indices.analysis - package org.elasticsearch.indices.analysis
 
org.elasticsearch.ingest - package org.elasticsearch.ingest
 
org.elasticsearch.node - package org.elasticsearch.node
 
org.elasticsearch.plugins - package org.elasticsearch.plugins
 
org.elasticsearch.repositories - package org.elasticsearch.repositories
 
org.elasticsearch.repositories.blobstore - package org.elasticsearch.repositories.blobstore
 
org.elasticsearch.script - package org.elasticsearch.script
 
org.elasticsearch.search - package org.elasticsearch.search
 
org.elasticsearch.search.aggregations - package org.elasticsearch.search.aggregations
 
org.elasticsearch.search.aggregations.bucket - package org.elasticsearch.search.aggregations.bucket
 
org.elasticsearch.search.aggregations.metrics - package org.elasticsearch.search.aggregations.metrics
 
org.elasticsearch.test - package org.elasticsearch.test
 
org.elasticsearch.test.client - package org.elasticsearch.test.client
 
org.elasticsearch.test.discovery - package org.elasticsearch.test.discovery
 
org.elasticsearch.test.disruption - package org.elasticsearch.test.disruption
 
org.elasticsearch.test.engine - package org.elasticsearch.test.engine
 
org.elasticsearch.test.fixture - package org.elasticsearch.test.fixture
 
org.elasticsearch.test.gateway - package org.elasticsearch.test.gateway
 
org.elasticsearch.test.hamcrest - package org.elasticsearch.test.hamcrest
 
org.elasticsearch.test.junit.annotations - package org.elasticsearch.test.junit.annotations
 
org.elasticsearch.test.junit.listeners - package org.elasticsearch.test.junit.listeners
 
org.elasticsearch.test.rest - package org.elasticsearch.test.rest
Infrastructure for testing REST.
org.elasticsearch.test.rest.yaml - package org.elasticsearch.test.rest.yaml
Infrastructure to run suites of tests written in YAML against a running Elasticsearch cluster using Elasticsearch's low level REST client.
org.elasticsearch.test.rest.yaml.restspec - package org.elasticsearch.test.rest.yaml.restspec
Specification of REST endpoints used to convert YAML do sections into actual calls to Elasticsearch.
org.elasticsearch.test.rest.yaml.section - package org.elasticsearch.test.rest.yaml.section
Sections within the YAML tests that are executed to run the tests.
org.elasticsearch.test.store - package org.elasticsearch.test.store
 
org.elasticsearch.test.tasks - package org.elasticsearch.test.tasks
 
org.elasticsearch.test.transport - package org.elasticsearch.test.transport
 
org.elasticsearch.threadpool - package org.elasticsearch.threadpool
 
org.elasticsearch.transport - package org.elasticsearch.transport
 
org.elasticsearch.upgrades - package org.elasticsearch.upgrades
 

P

PAGE_SIZE - Static variable in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
parse(String, String, XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
 
parse(String, XContentParser) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApiParser
 
parse(NamedXContentRegistry, String, Path) - Static method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
 
parse(XContentParser) - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSection
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.ContainsAssertion
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.DoSection
 
parse(XContentParser) - Static method in interface org.elasticsearch.test.rest.yaml.section.ExecutableSection
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.GreaterThanAssertion
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.GreaterThanEqualToAssertion
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.IsFalseAssertion
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.IsTrueAssertion
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.LengthAssertion
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.LessThanAssertion
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.LessThanOrEqualToAssertion
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.MatchAssertion
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.SetSection
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.SetupSection
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.SkipSection
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.TeardownSection
 
parse(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.TransformAndSetSection
 
parseAndAssert(InternalAggregation, boolean, boolean) - Method in class org.elasticsearch.test.InternalAggregationTestCase
 
parseCreateField(ParseContext, List) - Method in class org.elasticsearch.index.mapper.MockFieldMapper
 
parsedPostFilter() - Method in class org.elasticsearch.test.TestSearchContext
 
parsedPostFilter(ParsedQuery) - Method in class org.elasticsearch.test.TestSearchContext
 
parsedQuery() - Method in class org.elasticsearch.test.TestSearchContext
 
parsedQuery(ParsedQuery) - Method in class org.elasticsearch.test.TestSearchContext
 
parseIfNext(XContentParser) - Static method in class org.elasticsearch.test.rest.yaml.section.SkipSection
Parse a SkipSection if the next field is skip, otherwise returns SkipSection.EMPTY.
parseQuery(String) - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
parseQuery(XContentParser) - Static method in class org.elasticsearch.test.AbstractQueryTestCase
 
parseQuery(AbstractQueryBuilder<?>) - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
parser - Variable in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
PathUtilsForTesting - Class in org.elasticsearch.common.io
Exposes some package private stuff in PathUtils for framework purposes only!
PathUtilsForTesting() - Constructor for class org.elasticsearch.common.io.PathUtilsForTesting
 
pattern - Variable in class org.elasticsearch.test.MockLogAppender.PatternSeenEventExcpectation
 
PatternSeenEventExcpectation(String, String, Level, String) - Constructor for class org.elasticsearch.test.MockLogAppender.PatternSeenEventExcpectation
 
pauseIndexing() - Method in class org.elasticsearch.test.BackgroundIndexer
Pausing indexing by setting current document limit to 0
performOnPrimary(IndexShard, Request) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationAction
 
performOnReplica(ReplicaRequest, IndexShard) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationAction
 
performPostWriteActions(IndexShard, WriteRequest<?>, Translog.Location, Logger) - Static method in class org.elasticsearch.action.support.replication.TransportWriteActionTestHelper
 
ping(Consumer<ZenPing.PingCollection>, TimeValue) - Method in class org.elasticsearch.test.discovery.MockZenPing
 
pluginContextCompilers() - Method in class org.elasticsearch.script.MockScriptPlugin
 
pluginList(Class<? extends Plugin>...) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
Helper method to create list of plugins without specifying generic types.
pluginScriptLang() - Method in class org.elasticsearch.script.MockScriptPlugin
 
pluginScripts() - Method in class org.elasticsearch.script.MockScriptPlugin
 
PluginTestUtil - Class in org.elasticsearch.plugins
Utility methods for testing plugins
PluginTestUtil() - Constructor for class org.elasticsearch.plugins.PluginTestUtil
 
PosixPermissionsResetter - Class in org.elasticsearch.test
Stores the posix attributes for a path and resets them on close.
PosixPermissionsResetter(Path) - Constructor for class org.elasticsearch.test.PosixPermissionsResetter
 
prepareCreate(String) - Method in class org.elasticsearch.test.ESIntegTestCase
Creates a new CreateIndexRequestBuilder with the settings obtained from ESIntegTestCase.indexSettings().
prepareCreate(String, int) - Method in class org.elasticsearch.test.ESIntegTestCase
Creates a new CreateIndexRequestBuilder with the settings obtained from ESIntegTestCase.indexSettings().
prepareCreate(String, int, Settings.Builder) - Method in class org.elasticsearch.test.ESIntegTestCase
Creates a new CreateIndexRequestBuilder with the settings obtained from ESIntegTestCase.indexSettings().
prepareCreate(String, Settings.Builder) - Method in class org.elasticsearch.test.ESIntegTestCase
Creates a new CreateIndexRequestBuilder with the settings obtained from ESIntegTestCase.indexSettings(), augmented by the given builder
prepareSearch(String...) - Method in class org.elasticsearch.test.client.RandomizingClient
 
preProcess(boolean) - Method in class org.elasticsearch.test.TestSearchContext
 
preserveClusterSettings() - Method in class org.elasticsearch.test.rest.ESRestTestCase
Controls whether or not to preserve cluster settings upon completion of the test.
preserveClusterSettings() - Method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
 
preserveClusterUponCompletion() - Method in class org.elasticsearch.test.rest.ESRestTestCase
Returns whether to preserve the state of the cluster upon completion of this test.
preserveILMPoliciesUponCompletion() - Method in class org.elasticsearch.test.rest.ESRestTestCase
Returns whether to preserve ILM Policies of this test.
preserveILMPoliciesUponCompletion() - Method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
 
preserveIndicesUponCompletion() - Method in class org.elasticsearch.test.rest.ESRestTestCase
Returns whether to preserve the indices created during this test on completion of this test.
preserveIndicesUponCompletion() - Method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
 
preserveReposUponCompletion() - Method in class org.elasticsearch.test.rest.ESRestTestCase
Returns whether to preserve the repositories on completion of this test.
preserveReposUponCompletion() - Method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
 
preserveRollupJobsUponCompletion() - Method in class org.elasticsearch.test.rest.ESRestTestCase
Returns whether to preserve the rollup jobs of this test.
preserveRollupJobsUponCompletion() - Method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
 
preserveSnapshotsUponCompletion() - Method in class org.elasticsearch.test.rest.ESRestTestCase
Returns whether to preserve the snapshots in repositories on completion of this test.
preserveSnapshotsUponCompletion() - Method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
 
preserveTemplatesUponCompletion() - Method in class org.elasticsearch.test.rest.ESRestTestCase
Controls whether or not to preserve templates upon completion of this test.
preserveTemplatesUponCompletion() - Method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
 
PrimaryResult(ReplicaRequest, Response) - Constructor for class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationAction.PrimaryResult
 
primaryTerm - Variable in class org.elasticsearch.index.engine.EngineTestCase
 
primaryTerm - Variable in class org.elasticsearch.index.shard.IndexShardTestCase
 
primaryTranslogDir - Variable in class org.elasticsearch.index.engine.EngineTestCase
 
processRecoverySettings(ClusterSettings, RecoverySettings) - Method in class org.elasticsearch.node.MockNode
 
profileBoundAddresses() - Method in class org.elasticsearch.test.transport.CapturingTransport
 
profileBoundAddresses() - Method in class org.elasticsearch.test.transport.StubbableTransport
 
promoteReplica(IndexShard, Set<String>, IndexShardRoutingTable) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
promotes a replica to primary, incrementing it's term and starting it if needed
promoteReplicaToPrimary(IndexShard) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
promotes the specific replica as the new primary
promoteReplicaToPrimary(IndexShard, BiConsumer<IndexShard, ActionListener<PrimaryReplicaSyncer.ResyncTask>>) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
property - Variable in class org.elasticsearch.index.mapper.FieldTypeTestCase.Modifier
The name of the property that is being modified.
PROVIDED_NAME_SETTING - Static variable in class org.elasticsearch.test.InternalSettingsPlugin
 
putContext(SearchContext) - Method in class org.elasticsearch.search.MockSearchService
 

Q

query() - Method in class org.elasticsearch.test.TestSearchContext
 
queryBoost() - Method in class org.elasticsearch.test.TestSearchContext
 
queryCollectors() - Method in class org.elasticsearch.test.TestSearchContext
 
queryResult() - Method in class org.elasticsearch.test.TestSearchContext
 
queryShardContextMock(MapperService) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
sub-tests that need a more complex mock can overwrite this

R

random - Variable in class org.elasticsearch.test.disruption.SingleNodeDisruption
 
random - Variable in class org.elasticsearch.test.TestCluster
 
random(Random) - Static method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDelay
random(Random, String...) - Static method in class org.elasticsearch.test.disruption.NetworkDisruption.Bridge
 
random(Random, String...) - Static method in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
 
random(Random, Set<String>) - Static method in class org.elasticsearch.test.disruption.NetworkDisruption.Bridge
 
random(Random, Set<String>) - Static method in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
 
random(Random, TimeValue, TimeValue) - Static method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDelay
Delays requests by a random but fixed time value between delayMin and delayMax.
RANDOM_IO_EXCEPTION_RATE_ON_OPEN_SETTING - Static variable in class org.elasticsearch.test.store.MockFSDirectoryService
 
RANDOM_IO_EXCEPTION_RATE_SETTING - Static variable in class org.elasticsearch.test.store.MockFSDirectoryService
 
RANDOM_NO_DELETE_OPEN_FILE_SETTING - Static variable in class org.elasticsearch.test.store.MockFSDirectoryService
 
RANDOM_PREVENT_DOUBLE_WRITE_SETTING - Static variable in class org.elasticsearch.test.store.MockFSDirectoryService
 
randomAlias() - Static method in class org.elasticsearch.index.RandomCreateIndexGenerator
 
randomAliasAction() - Static method in class org.elasticsearch.index.alias.RandomAliasActionsGenerator
 
randomAliasAction(boolean) - Static method in class org.elasticsearch.index.alias.RandomAliasActionsGenerator
 
RandomAliasActionsGenerator - Class in org.elasticsearch.index.alias
 
randomAliases(CreateIndexRequest) - Static method in class org.elasticsearch.index.RandomCreateIndexGenerator
Sets random aliases to the provided CreateIndexRequest
randomAllocationDeciders(Settings, ClusterSettings, Random) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
randomAlphaOfLength(int) - Static method in class org.elasticsearch.test.ESTestCase
 
randomAlphaOfLengthBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
 
randomAnalyzer() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
 
randomArray(int, int, IntFunction<T[]>, Supplier<T>) - Static method in class org.elasticsearch.test.ESTestCase
 
randomArray(int, IntFunction<T[]>, Supplier<T>) - Static method in class org.elasticsearch.test.ESTestCase
 
randomAsciiName() - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
randomBoolean() - Static method in class org.elasticsearch.test.ESTestCase
 
randomByte() - Static method in class org.elasticsearch.test.ESTestCase
 
randomByteArrayOfLength(int) - Static method in class org.elasticsearch.test.ESTestCase
Helper method to create a byte array of a given length populated with random byte values
randomBytes(int) - Static method in class org.elasticsearch.repositories.ESBlobStoreTestCase
 
randomCompatibleVersion(Random, Version) - Static method in class org.elasticsearch.test.VersionUtils
Returns a random Version from all available versions, that is compatible with the given version.
RandomCreateIndexGenerator - Class in org.elasticsearch.index
 
randomCreateIndexRequest() - Static method in class org.elasticsearch.index.RandomCreateIndexGenerator
Returns a random CreateIndexRequest.
randomDateTimeZone() - Static method in class org.elasticsearch.test.ESTestCase
generate a random DateTimeZone from the ones available in joda library
RandomDocumentPicks - Class in org.elasticsearch.ingest
 
randomDouble() - Static method in class org.elasticsearch.test.ESTestCase
 
randomDoubleBetween(double, double, boolean) - Static method in class org.elasticsearch.test.ESTestCase
Returns a double value in the interval [start, end) if lowerInclusive is set to true, (start, end) otherwise.
randomExecutionHint() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractTermsTestCase
 
randomExistingFieldName(Random, IngestDocument) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
Returns a randomly selected existing field name out of the fields that are contained in the document provided as an argument.
randomFieldName(Random) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
Returns a random field name.
randomFieldOrScript(ValuesSourceAggregationBuilder<?, ?>, String) - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
 
randomFieldsExcludeFilter(Predicate<String>) - Method in class org.elasticsearch.test.AbstractXContentTestCase.XContentTester
 
randomFieldValue(Random) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
Generates a random field value, can be a string, a number, a list of an object itself.
randomFloat() - Static method in class org.elasticsearch.test.ESTestCase
 
randomFrom(Collection<T>) - Static method in class org.elasticsearch.test.ESTestCase
Pick a random object from the given collection.
randomFrom(List<T>) - Static method in class org.elasticsearch.test.ESTestCase
Pick a random object from the given list.
randomFrom(Random, Collection<T>) - Static method in class org.elasticsearch.test.ESTestCase
Pick a random object from the given collection.
randomFrom(Random, T...) - Static method in class org.elasticsearch.test.ESTestCase
Pick a random object from the given array.
randomFrom(T...) - Static method in class org.elasticsearch.test.ESTestCase
Pick a random object from the given array.
randomFuzziness(String) - Static method in class org.elasticsearch.test.AbstractQueryTestCase
 
randomGeohash(int, int) - Static method in class org.elasticsearch.test.ESTestCase
 
randomIndexSettings() - Static method in class org.elasticsearch.index.RandomCreateIndexGenerator
randomIndexTemplate() - Method in class org.elasticsearch.test.ESIntegTestCase
Creates a randomized index template.
randomIngestDocument(Random) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
Generates a random document and random metadata
randomIngestDocument(Random, Map<String, Object>) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
Generates a document that holds random metadata and the document provided as a map argument
randomInt() - Static method in class org.elasticsearch.test.ESTestCase
 
randomInt(int) - Static method in class org.elasticsearch.test.ESTestCase
A random integer from 0..max (inclusive).
randomIntBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
A random integer from min to max (inclusive).
randomizeContentType() - Method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
 
RandomizingClient - Class in org.elasticsearch.test.client
A Client that randomizes request parameters.
RandomizingClient(Client, Random) - Constructor for class org.elasticsearch.test.client.RandomizingClient
 
randomLeafFieldName(Random) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
Returns a random leaf field name.
randomLong() - Static method in class org.elasticsearch.test.ESTestCase
 
randomLongBetween(long, long) - Static method in class org.elasticsearch.test.ESTestCase
A random long number between min (inclusive) and max (inclusive).
randomMap(int) - Static method in class org.elasticsearch.index.alias.RandomAliasActionsGenerator
 
randomMapping(String) - Static method in class org.elasticsearch.index.RandomCreateIndexGenerator
Creates a random mapping, with the mapping definition nested under the given type name.
randomMappingFields(XContentBuilder, boolean) - Static method in class org.elasticsearch.index.RandomCreateIndexGenerator
Adds random mapping fields to the provided XContentBuilder
randomMinimumShouldMatch() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
 
randomNonNegativeLong() - Static method in class org.elasticsearch.test.ESTestCase
 
randomNumberOfBuckets() - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
randomNumericDocValueFormat() - Static method in class org.elasticsearch.test.InternalAggregationTestCase
 
randomNumericField() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
 
RandomObjects - Class in org.elasticsearch.test
 
randomPositiveTimeValue() - Static method in class org.elasticsearch.test.ESTestCase
 
randomRealisticUnicodeOfCodepointLength(int) - Static method in class org.elasticsearch.test.ESTestCase
 
randomRealisticUnicodeOfCodepointLengthBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
 
randomRealisticUnicodeOfLength(int) - Static method in class org.elasticsearch.test.ESTestCase
 
randomRealisticUnicodeOfLengthBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
 
randomRecoverySource() - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
 
randomRepoPath() - Method in class org.elasticsearch.test.ESIntegTestCase
Returns path to a random directory that can be used to create a temporary file system repo
randomRepoPath(Settings) - Static method in class org.elasticsearch.test.ESIntegTestCase
Returns path to a random directory that can be used to create a temporary file system repo
randomRouting() - Static method in class org.elasticsearch.index.alias.RandomAliasActionsGenerator
 
randomSearchRequest(Supplier<SearchSourceBuilder>) - Static method in class org.elasticsearch.search.RandomSearchRequestGenerator
Build a random search request.
randomSearchRequest(SearchRequest, Supplier<SearchSourceBuilder>) - Static method in class org.elasticsearch.search.RandomSearchRequestGenerator
Set random fields to the provided search request.
RandomSearchRequestGenerator - Class in org.elasticsearch.search
Builds random search requests.
randomSearchSourceBuilder(Supplier<HighlightBuilder>, Supplier<SuggestBuilder>, Supplier<RescorerBuilder<?>>, Supplier<List<SearchExtBuilder>>, Supplier<CollapseBuilder>) - Static method in class org.elasticsearch.search.RandomSearchRequestGenerator
 
randomShardInfo(Random) - Static method in class org.elasticsearch.test.RandomObjects
Returns a tuple that contains a randomized ReplicationResponse.ShardInfo value (left side) and its corresponding value (right side) after it has been printed out as a ToXContent and parsed back using a parsing method like ReplicationResponse.ShardInfo.fromXContent(XContentParser).
randomShardInfo(Random, boolean) - Static method in class org.elasticsearch.test.RandomObjects
Returns a tuple that contains a randomized ReplicationResponse.ShardInfo value (left side) and its corresponding value (right side) after it has been printed out as a ToXContent and parsed back using a parsing method like ReplicationResponse.ShardInfo.fromXContent(XContentParser).
randomShort() - Static method in class org.elasticsearch.test.ESTestCase
 
randomSource(Random) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
 
randomSource(Random) - Static method in class org.elasticsearch.test.RandomObjects
Returns a random source containing a random number of fields, objects and array, with maximum depth 5.
randomSource(Random, XContentType) - Static method in class org.elasticsearch.test.RandomObjects
Returns a random source in a given XContentType containing a random number of fields, objects and array, with maximum depth 5.
randomSource(Random, XContentType, int) - Static method in class org.elasticsearch.test.RandomObjects
Returns a random source in a given XContentType containing a random number of fields, objects and array, with maximum depth 5.
randomStoredFieldValues(Random, XContentType) - Static method in class org.elasticsearch.test.RandomObjects
Returns a tuple containing random stored field values and their corresponding expected values once printed out via ToXContent.toXContent(XContentBuilder, ToXContent.Params) and parsed back via XContentParser.objectText().
randomString(Random) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
 
randomSubsetOf(int, Collection<T>) - Static method in class org.elasticsearch.test.ESTestCase
Returns size random values
randomSubsetOf(int, T...) - Static method in class org.elasticsearch.test.ESTestCase
Returns size random values
randomSubsetOf(Collection<T>) - Static method in class org.elasticsearch.test.ESTestCase
Returns a random subset of values (including a potential empty list)
randomTimeValue() - Static method in class org.elasticsearch.test.ESTestCase
 
randomTimeValue(int, int) - Static method in class org.elasticsearch.test.ESTestCase
 
randomTimeValue(int, int, String...) - Static method in class org.elasticsearch.test.ESTestCase
 
randomTimeZone() - Static method in class org.elasticsearch.test.ESTestCase
generate a random TimeZone from the ones available in java.util
randomTypes - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
randomUnicodeOfCodepointLength(int) - Static method in class org.elasticsearch.test.ESTestCase
 
randomUnicodeOfCodepointLengthBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
 
randomUnicodeOfLength(int) - Static method in class org.elasticsearch.test.ESTestCase
 
randomUnicodeOfLengthBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
 
randomUnique(Supplier<T>, int) - Static method in class org.elasticsearch.test.ESTestCase
Builds a set of unique items.
randomValueOtherThan(T, Supplier<T>) - Static method in class org.elasticsearch.test.ESTestCase
helper to get a random value in a certain range that's different from the input
randomValueOtherThanMany(Predicate<T>, Supplier<T>) - Static method in class org.elasticsearch.test.ESTestCase
helper to get a random value in a certain range that's different from the input
randomVersion(Random) - Static method in class org.elasticsearch.test.VersionUtils
Returns a random Version from all available versions.
randomVersionBetween(Random, Version, Version) - Static method in class org.elasticsearch.test.VersionUtils
Returns a random Version between minVersion and maxVersion (inclusive).
randomZone() - Static method in class org.elasticsearch.test.ESTestCase
generate a random TimeZone from the ones available in java.time
readAllOperationsInLucene(Engine, MapperService) - Static method in class org.elasticsearch.index.engine.EngineTestCase
Reads all engine operations that have been processed by the engine from Lucene index.
readBlobFully(BlobContainer, String, int) - Static method in class org.elasticsearch.repositories.ESBlobStoreTestCase
 
readDiffFrom(String, StreamInput) - Static method in class org.elasticsearch.test.TestCustomMetaData
 
readFrom(Function<String, T>, StreamInput) - Static method in class org.elasticsearch.test.TestCustomMetaData
 
readFrom(StreamInput) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.StringMessageRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.TestRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.Version0Request
 
readFrom(StreamInput) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.Version1Request
 
readSecret(String) - Method in class org.elasticsearch.cli.MockTerminal
 
readText(String) - Method in class org.elasticsearch.cli.MockTerminal
 
receivedRequest(long, String) - Method in class org.elasticsearch.test.transport.MockTransportService.Tracer
 
receivedResponse(long, DiscoveryNode, String) - Method in class org.elasticsearch.test.transport.MockTransportService.Tracer
 
recoverPrimary(IndexShard) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
recoverReplica(IndexShard) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
recoverReplica(IndexShard, BiFunction<IndexShard, DiscoveryNode, RecoveryTarget>) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
recoverReplica(IndexShard, BiFunction<IndexShard, DiscoveryNode, RecoveryTarget>, boolean) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
recoverReplica(IndexShard, IndexShard, boolean) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
recovers a replica from the given primary
recoverReplica(IndexShard, IndexShard, BiFunction<IndexShard, DiscoveryNode, RecoveryTarget>, boolean, boolean) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
recovers a replica from the given primary
recoverShardFromSnapshot(IndexShard, Snapshot, Repository) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
Recover a shard from a snapshot using a given repository
recoverShardFromStore(IndexShard) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
recoverUnstartedReplica(IndexShard, IndexShard, BiFunction<IndexShard, DiscoveryNode, RecoveryTarget>, boolean, Set<String>, IndexShardRoutingTable) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
Recovers a replica from the give primary, allow the user to supply a custom recovery target.
recoveryEmptyReplica(IndexShard, boolean) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
recoveryListener - Static variable in class org.elasticsearch.index.shard.IndexShardTestCase
 
RecoverySettingsChunkSizePlugin - Class in org.elasticsearch.node
Marker plugin that will trigger MockNode making RecoverySettingsChunkSizePlugin.CHUNK_SIZE_SETTING dynamic.
RecoverySettingsChunkSizePlugin() - Constructor for class org.elasticsearch.node.RecoverySettingsChunkSizePlugin
 
refresh(String) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
refresh(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
Waits for relocations and refreshes all indices in the cluster.
RegexMatcher - Class in org.elasticsearch.test.hamcrest
Matcher that supports regular expression and allows to provide optional flags
RegexMatcher(String) - Constructor for class org.elasticsearch.test.hamcrest.RegexMatcher
 
RegexMatcher(String, int) - Constructor for class org.elasticsearch.test.hamcrest.RegexMatcher
 
register(String, String, TaskAwareRequest) - Method in class org.elasticsearch.test.tasks.MockTaskManager
 
registerDerivedNodeNameWithLogger(String) - Method in class org.elasticsearch.node.MockNode
 
registerRequestHandler(RequestHandlerRegistry<Request>) - Method in class org.elasticsearch.test.transport.CapturingTransport
 
registerRequestHandler(RequestHandlerRegistry<Request>) - Method in class org.elasticsearch.test.transport.StubbableTransport
 
reinitPrimaryShard() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
reinitShard(IndexShard, ShardRouting, EngineFactory, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
Takes an existing shard, closes it and starts a new initialing shard at the same location
reinitShard(IndexShard, ShardRouting, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
Takes an existing shard, closes it and starts a new initialing shard at the same location
reinitShard(IndexShard, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
Takes an existing shard, closes it and starts a new initialing shard at the same location
relocate(ShardRouting, String) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
 
relocate(ShardRouting, String, long) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
 
relocate(ShardRouting, String, long) - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
 
removeAndEnsureHealthy(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.BlockClusterStateProcessing
 
removeAndEnsureHealthy(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.BlockMasterServiceOnMaster
 
removeAndEnsureHealthy(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.BusyMasterServiceDisruption
 
removeAndEnsureHealthy(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.LongGCDisruption
 
removeAndEnsureHealthy(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.NetworkDisruption
 
removeAndEnsureHealthy(InternalTestCluster) - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
 
removeAndEnsureHealthy(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.SlowClusterStateProcessing
 
removeContext(long) - Method in class org.elasticsearch.search.MockSearchService
 
removeDisruption(MockTransportService, MockTransportService) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkLinkDisruptionType
removeFromCluster(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.NetworkDisruption
 
removeFromCluster(InternalTestCluster) - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
 
removeFromCluster(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.SingleNodeDisruption
 
removeFromNode(String, InternalTestCluster) - Method in class org.elasticsearch.test.disruption.NetworkDisruption
 
removeFromNode(String, InternalTestCluster) - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
 
removeFromNode(String, InternalTestCluster) - Method in class org.elasticsearch.test.disruption.SingleNodeDisruption
 
removeLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.test.transport.CapturingTransport
 
removeLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.test.transport.StubbableTransport
 
removeListener(MockTaskManagerListener) - Method in class org.elasticsearch.test.tasks.MockTaskManager
 
removeListener(TransportConnectionListener) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
removeMessageListener(TransportMessageListener) - Method in class org.elasticsearch.test.transport.CapturingTransport
 
removeMessageListener(TransportMessageListener) - Method in class org.elasticsearch.test.transport.StubbableTransport
 
removeReplica(IndexShard) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
removeRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
removeTracer(MockTransportService.Tracer) - Method in class org.elasticsearch.test.transport.MockTransportService
 
renewRetentionLease(String, long, String) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
replacePlaceholders(Map<String, String>) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestPath
 
replaceStashedValues(Map<String, Object>) - Method in class org.elasticsearch.test.rest.yaml.Stash
Goes recursively against each map entry and replaces any string value starting with "$" with its corresponding value retrieved from the stash
replicaDeleteForDoc(String, long, long, long) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
replicaEngine - Variable in class org.elasticsearch.index.engine.EngineTestCase
 
replicaIndexForDoc(ParsedDocument, long, long, boolean) - Method in class org.elasticsearch.index.engine.EngineTestCase
 
replicaRequest() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationAction.PrimaryResult
 
ReplicationAction(Request, ActionListener<Response>, ESIndexLevelReplicationTestCase.ReplicationGroup, String) - Constructor for class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationAction
 
ReplicationGroup(IndexMetaData) - Constructor for class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
replicaTranslogDir - Variable in class org.elasticsearch.index.engine.EngineTestCase
 
ReproduceInfoPrinter - Class in org.elasticsearch.test.junit.listeners
A RunListener that emits a command you can use to re-run a failing test with the failing random seed to System.err.
ReproduceInfoPrinter() - Constructor for class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter
 
ReproduceInfoPrinter.GradleMessageBuilder - Class in org.elasticsearch.test.junit.listeners
 
request - Variable in class org.elasticsearch.test.transport.CapturingTransport.CapturedRequest
 
request() - Method in class org.elasticsearch.index.reindex.AbstractAsyncBulkByScrollActionTestCase
 
request() - Method in class org.elasticsearch.test.rest.FakeRestChannel
 
request() - Method in class org.elasticsearch.test.TestSearchContext
 
Request(long, String, URI, Map<String, String>, byte[]) - Constructor for class org.elasticsearch.test.fixture.AbstractHttpFixture.Request
 
requestId - Variable in class org.elasticsearch.test.transport.CapturingTransport.CapturedRequest
 
requestSent(DiscoveryNode, long, String, TransportRequestOptions) - Method in class org.elasticsearch.test.transport.MockTransportService.Tracer
 
REQUIRED - org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Body
 
rescore() - Method in class org.elasticsearch.test.TestSearchContext
 
reset() - Method in class org.elasticsearch.cli.MockTerminal
Wipes the input and output.
resetCheckIndexStatus() - Method in class org.elasticsearch.test.ESTestCase
 
resetNodeAfterTest() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
This method returns true if the node that is used in the background should be reset after each test.
resetPortCounter() - Static method in class org.elasticsearch.test.ESTestCase
 
resetTerminal() - Method in class org.elasticsearch.cli.CommandTestCase
 
resize(ByteArray, long) - Method in class org.elasticsearch.common.util.MockBigArrays
 
resize(DoubleArray, long) - Method in class org.elasticsearch.common.util.MockBigArrays
 
resize(FloatArray, long) - Method in class org.elasticsearch.common.util.MockBigArrays
 
resize(IntArray, long) - Method in class org.elasticsearch.common.util.MockBigArrays
 
resize(LongArray, long) - Method in class org.elasticsearch.common.util.MockBigArrays
 
resize(ObjectArray<T>, long) - Method in class org.elasticsearch.common.util.MockBigArrays
 
resolveExpectedValue(ClientYamlTestExecutionContext) - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
 
resolveIndex(String) - Static method in class org.elasticsearch.test.ESIntegTestCase
 
resolveIndex(String) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
 
respond(ActionListener<Response>) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationAction.PrimaryResult
 
response(String) - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestExecutionContext
Extracts a specific value from the last saved response
Response(int, Map<String, String>, byte[]) - Constructor for class org.elasticsearch.test.fixture.AbstractHttpFixture.Response
 
responses() - Method in class org.elasticsearch.test.rest.FakeRestChannel
 
responseSent(long, String) - Method in class org.elasticsearch.test.transport.MockTransportService.Tracer
 
responseSent(long, String, Throwable) - Method in class org.elasticsearch.test.transport.MockTransportService.Tracer
 
REST_TESTS_BLACKLIST - Static variable in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
Property that allows to blacklist some of the REST tests based on a comma separated list of globs e.g.
REST_TESTS_BLACKLIST_ADDITIONS - Static variable in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
We use tests.rest.blacklist in build files to blacklist tests; this property enables a user to add additional blacklisted tests on top of the tests blacklisted in the build.
REST_TESTS_SUITE - Static variable in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
Property that allows to control which REST tests get run.
RestActionTestCase - Class in org.elasticsearch.test.rest
A common base class for Rest*ActionTests.
RestActionTestCase() - Constructor for class org.elasticsearch.test.rest.RestActionTestCase
 
restAdminSettings() - Method in class org.elasticsearch.test.rest.ESRestTestCase
Returns the REST client settings used for admin actions like cleaning up after the test has completed.
RestartCallback() - Constructor for class org.elasticsearch.test.InternalTestCluster.RestartCallback
 
restartNode(String, InternalTestCluster.RestartCallback) - Method in class org.elasticsearch.test.InternalTestCluster
Restarts a node and calls the callback during restart.
restartRandomDataNode() - Method in class org.elasticsearch.test.InternalTestCluster
Restarts a random data node in the cluster
restartRandomDataNode(InternalTestCluster.RestartCallback) - Method in class org.elasticsearch.test.InternalTestCluster
Restarts a random data node in the cluster and calls the callback during restart.
restartRandomNode() - Method in class org.elasticsearch.test.InternalTestCluster
Restarts a random node in the cluster
restartRandomNode(InternalTestCluster.RestartCallback) - Method in class org.elasticsearch.test.InternalTestCluster
Restarts a random node in the cluster and calls the callback during restart.
RestClientBuilderTestCase - Class in org.elasticsearch.client
A test case with access to internals of a RestClient.
RestClientBuilderTestCase() - Constructor for class org.elasticsearch.client.RestClientBuilderTestCase
 
restClientSettings() - Method in class org.elasticsearch.test.rest.ESRestTestCase
Used to obtain settings for the REST client that is used to send REST requests.
restoreContentType() - Static method in class org.elasticsearch.test.ESTestCase
 
restoreFileSystem() - Static method in class org.elasticsearch.test.ESTestCase
 
RestoreOnlyRepository - Class in org.elasticsearch.index.shard
A dummy repository for testing which just needs restore overridden
RestoreOnlyRepository(String) - Constructor for class org.elasticsearch.index.shard.RestoreOnlyRepository
 
resumeThreads(Set<Thread>) - Method in class org.elasticsearch.test.disruption.LongGCDisruption
 
rewrite(Query) - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
rewriteAndFetch(QueryBuilder, QueryRewriteContext) - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
rewriteQuery(QB, QueryRewriteContext) - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
rollingRestart() - Method in class org.elasticsearch.test.InternalTestCluster
Restarts all nodes in a rolling restart fashion ie.
rollingRestart(InternalTestCluster.RestartCallback) - Method in class org.elasticsearch.test.InternalTestCluster
Restarts all nodes in a rolling restart fashion ie.
routingKeyForShard(String, int) - Method in class org.elasticsearch.test.ESIntegTestCase
Compute a routing key that will route documents to the shard-th shard of the provided index.
run(Engine, Translog.Snapshot) - Method in class org.elasticsearch.index.engine.TranslogHandler
 
runAllRunnableTasks() - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
runAllTasks() - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
runAllTasksInTimeOrder() - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
runRandomTask() - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
Runs an arbitrary runnable task.

S

safeClass(Object) - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
a utility to get the class of an object, protecting for null (i.e., returning null if the input is null)
scaledRandomIntBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
Returns a "scaled" random number between min and max (inclusive).
scheduleAt(long, Runnable) - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
Schedule a task for future execution.
scheduleNow(Runnable) - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
Schedule a task for immediate execution.
scope() - Method in annotation type org.elasticsearch.test.ESIntegTestCase.ClusterScope
Returns the scope.
scriptFields() - Method in class org.elasticsearch.test.TestSearchContext
 
scrollContext() - Method in class org.elasticsearch.test.TestSearchContext
 
scrollContext(ScrollContext) - Method in class org.elasticsearch.test.TestSearchContext
 
search(IndexSearcher, Query, AggregationBuilder, int, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
 
search(IndexSearcher, Query, AggregationBuilder, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
 
searchAfter() - Method in class org.elasticsearch.test.TestSearchContext
 
searchAfter(FieldDoc) - Method in class org.elasticsearch.test.TestSearchContext
 
searchAndReduce(IndexSearcher, Query, AggregationBuilder, int, ScriptService, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
Divides the provided IndexSearcher in sub-searcher, one for each segment, builds an aggregator for each sub-searcher filtered by the provided Query and returns the reduced InternalAggregation.
searchAndReduce(IndexSearcher, Query, AggregationBuilder, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
 
searcher() - Method in class org.elasticsearch.test.TestSearchContext
 
SearchHitHasIdMatcher(String) - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasIdMatcher
 
SearchHitHasIndexMatcher(String) - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasIndexMatcher
 
SearchHitHasScoreMatcher(float) - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasScoreMatcher
 
SearchHitHasTypeMatcher(String) - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasTypeMatcher
 
searchType() - Method in class org.elasticsearch.test.TestSearchContext
 
seed() - Method in class org.elasticsearch.test.TestCluster
 
SeenEventExpectation(String, String, Level, String) - Constructor for class org.elasticsearch.test.MockLogAppender.SeenEventExpectation
 
sendMessage(BytesReference, ActionListener<Void>) - Method in class org.elasticsearch.transport.FakeTcpChannel
 
sendMessage(BytesReference, ActionListener<Void>) - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
 
sendRequest(long, String, TransportRequest, TransportRequestOptions) - Method in class org.elasticsearch.test.transport.StubbableTransport.WrappedConnection
 
sendRequest(Transport.Connection, long, String, TransportRequest, TransportRequestOptions) - Method in interface org.elasticsearch.test.transport.StubbableTransport.SendRequestBehavior
 
sendResponse(RestResponse) - Method in class org.elasticsearch.test.rest.FakeRestChannel
 
seqNoAndPrimaryTerm() - Method in class org.elasticsearch.test.TestSearchContext
 
seqNoAndPrimaryTerm(boolean) - Method in class org.elasticsearch.test.TestSearchContext
 
serviceA - Variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
serviceB - Variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
ServiceDisruptionScheme - Interface in org.elasticsearch.test.disruption
 
set(long) - Method in class org.elasticsearch.index.engine.EngineTestCase.PrimaryTermSupplier
 
setAssertNoFailuresOnStop(boolean) - Method in class org.elasticsearch.test.BackgroundIndexer
 
setCatch(String) - Method in class org.elasticsearch.test.rest.yaml.section.DoSection
 
setClusterReadOnly(boolean) - Static method in class org.elasticsearch.test.ESIntegTestCase
Sets or unsets the cluster read_only mode
setContentType() - Static method in class org.elasticsearch.test.ESTestCase
 
setDefaultConnectBehavior(StubbableTransport.OpenConnectionBehavior) - Method in class org.elasticsearch.test.transport.StubbableTransport
 
setDefaultGetConnectionBehavior(StubbableConnectionManager.GetConnectionBehavior) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
setDefaultNodeConnectedBehavior(StubbableConnectionManager.NodeConnectedBehavior) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
setDisruptionScheme(ServiceDisruptionScheme) - Method in class org.elasticsearch.test.ESIntegTestCase
 
setDisruptionScheme(ServiceDisruptionScheme) - Method in class org.elasticsearch.test.InternalTestCluster
 
setDummyNullValue(Object) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
Sets the null value used by the modifier for null value testing.
setExecutionDelayVariabilityMillis(long) - Method in class org.elasticsearch.cluster.coordination.DeterministicTaskQueue
 
setFile(String, byte[]) - Method in class org.elasticsearch.common.settings.MockSecureSettings
 
setFileSystem() - Static method in class org.elasticsearch.test.ESTestCase
 
setHostsListContainsOnlyFirstNode(boolean) - Method in class org.elasticsearch.test.InternalTestCluster
 
setMaxFieldSize(int) - Method in class org.elasticsearch.test.BackgroundIndexer
the minimum size in code points of a payload field in the indexed documents
setMaxNumberOfBuckets(int) - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
setMinFieldSize(int) - Method in class org.elasticsearch.test.BackgroundIndexer
the minimum size in code points of a payload field in the indexed documents
setMinimumMasterNodes(int) - Method in class org.elasticsearch.test.ESIntegTestCase
Sets the cluster's minimum master node and make sure the response is acknowledge.
setNanoTimeOverride(long) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.MockAllocationService
 
setNewDelegate(IndexEventListener) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
setNodeSelector(NodeSelector) - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
Set the selector that decides which node can run this request.
setOnPutContext(Consumer<SearchContext>) - Method in class org.elasticsearch.search.MockSearchService
 
setOptions(Request, Map<String, String>) - Static method in class org.elasticsearch.test.rest.yaml.ClientYamlTestClient
 
setPermissions(Set<PosixFilePermission>) - Method in class org.elasticsearch.test.PosixPermissionsResetter
 
setRandomIndexSettings(Random, Settings.Builder) - Method in class org.elasticsearch.test.ESIntegTestCase
 
setSearcher(Engine.Searcher) - Method in class org.elasticsearch.test.TestSearchContext
 
SetSection - Class in org.elasticsearch.test.rest.yaml.section
Represents a set section: - set: {_scroll_id: scroll_id}
SetSection(XContentLocation) - Constructor for class org.elasticsearch.test.rest.yaml.section.SetSection
 
setShardInfo(ReplicationResponse.ShardInfo) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationAction.PrimaryResult
 
setSize(int) - Method in class org.elasticsearch.test.TestSearchContext
 
setState(ClusterApplierService, ClusterState) - Static method in class org.elasticsearch.test.ClusterServiceUtils
 
setState(ClusterService, ClusterState) - Static method in class org.elasticsearch.test.ClusterServiceUtils
Sets the state on the cluster applier service
setState(ClusterService, ClusterState.Builder) - Static method in class org.elasticsearch.test.ClusterServiceUtils
 
setState(MasterService, ClusterState) - Static method in class org.elasticsearch.test.ClusterServiceUtils
 
setString(String, String) - Method in class org.elasticsearch.common.settings.MockSecureSettings
 
setSubAggregationsSupplier(Supplier<InternalAggregations>) - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
setTask(SearchTask) - Method in class org.elasticsearch.test.TestSearchContext
 
settings - Variable in class org.elasticsearch.test.discovery.TestZenDiscovery.TestPlugin
 
settings(Version) - Static method in class org.elasticsearch.test.ESTestCase
Return consistent index settings for the provided index version.
setTypeList() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
setup() - Static method in class org.elasticsearch.common.io.PathUtilsForTesting
Sets a new default filesystem for testing
setup() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
setUp() - Method in class org.elasticsearch.index.engine.EngineTestCase
 
setUp() - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
setUp() - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
 
setUp() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
 
setUp() - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
setUp() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
setUpClass() - Static method in class org.elasticsearch.test.ESSingleNodeTestCase
 
setUpController() - Method in class org.elasticsearch.test.rest.RestActionTestCase
 
setUpdateFrequency(TimeValue) - Method in class org.elasticsearch.cluster.MockInternalClusterInfoService
 
setupForTest() - Method in class org.elasticsearch.index.reindex.AbstractAsyncBulkByScrollActionTestCase
 
SetupSection - Class in org.elasticsearch.test.rest.yaml.section
Represents a setup section.
setupSuiteScopeCluster() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
setupSuiteScopeCluster() - Method in class org.elasticsearch.test.ESIntegTestCase
This method is executed iff the test is annotated with ESIntegTestCase.SuiteScopeTestCase before the first test of this class is executed.
setupTestCluster() - Method in class org.elasticsearch.test.ESIntegTestCase
 
setUpThreadPool() - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
shardId - Variable in class org.elasticsearch.index.engine.EngineTestCase
 
shardRoutingChanged(IndexShard, ShardRouting, ShardRouting) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
ShardRoutingHelper - Class in org.elasticsearch.cluster.routing
A helper class that allows access to package private APIs for testing.
ShardRoutingHelper() - Constructor for class org.elasticsearch.cluster.routing.ShardRoutingHelper
 
shardRoutings() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
shardSizeFunction - Variable in class org.elasticsearch.cluster.MockInternalClusterInfoService
 
shardTarget() - Method in class org.elasticsearch.test.TestSearchContext
 
shuffleFieldsExceptions(String[]) - Method in class org.elasticsearch.test.AbstractXContentTestCase.XContentTester
 
shuffleMap(LinkedHashMap<String, Object>, Set<String>) - Static method in class org.elasticsearch.test.ESTestCase
 
shuffleProtectedFields() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Subclasses can override this method and return an array of fieldnames which should be protected from recursive random shuffling in the AbstractQueryTestCase.testFromXContent() test case
shuffleXContent(XContentBuilder, String...) - Method in class org.elasticsearch.test.ESTestCase
Randomly shuffles the fields inside objects in the XContentBuilder passed in.
shuffleXContent(XContentParser, boolean, String...) - Static method in class org.elasticsearch.test.ESTestCase
Randomly shuffles the fields inside objects parsed using the XContentParser passed in.
similarityService() - Method in class org.elasticsearch.test.TestSearchContext
 
SingleNodeDisruption - Class in org.elasticsearch.test.disruption
 
SingleNodeDisruption(Random) - Constructor for class org.elasticsearch.test.disruption.SingleNodeDisruption
 
size() - Method in class org.elasticsearch.test.ExternalTestCluster
 
size() - Method in class org.elasticsearch.test.InternalTestCluster
 
size() - Method in class org.elasticsearch.test.TestCluster
Returns the number of nodes in the cluster.
size() - Method in class org.elasticsearch.test.TestSearchContext
 
size() - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
 
size(int) - Method in class org.elasticsearch.test.TestSearchContext
 
skip(Version) - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
 
SkipSection - Class in org.elasticsearch.test.rest.yaml.section
Represents a skip section that tells whether a specific test section or suite needs to be skipped based on: - the elasticsearch version the tests are running against - a specific test feature required that might not be implemented yet by the runner
SkipSection(String, List<String>, String) - Constructor for class org.elasticsearch.test.rest.yaml.section.SkipSection
 
SlowClusterStateProcessing - Class in org.elasticsearch.test.disruption
 
SlowClusterStateProcessing(String, Random) - Constructor for class org.elasticsearch.test.disruption.SlowClusterStateProcessing
 
SlowClusterStateProcessing(String, Random, long, long, long, long) - Constructor for class org.elasticsearch.test.disruption.SlowClusterStateProcessing
 
SlowClusterStateProcessing(Random) - Constructor for class org.elasticsearch.test.disruption.SlowClusterStateProcessing
 
SlowClusterStateProcessing(Random, long, long, long, long) - Constructor for class org.elasticsearch.test.disruption.SlowClusterStateProcessing
 
smartClient() - Method in class org.elasticsearch.test.InternalTestCluster
Returns a "smart" node client to a random node in the cluster
smartNameFieldType(String) - Method in class org.elasticsearch.test.TestSearchContext
 
snapshotShard(IndexShard, Store, SnapshotId, IndexId, IndexCommit, IndexShardSnapshotStatus) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
snapshotShard(IndexShard, Snapshot, Repository) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
Snapshot a shard using a given repository
sort() - Method in class org.elasticsearch.test.TestSearchContext
 
sort(SortAndFormats) - Method in class org.elasticsearch.test.TestSearchContext
 
SortedDocValues - org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
 
SortedSetDocValues - org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
 
source() - Method in class org.elasticsearch.test.TestSearchContext
 
SOURCE - Static variable in class org.elasticsearch.index.engine.EngineTestCase
 
sourceRequested() - Method in class org.elasticsearch.test.TestSearchContext
 
spinForAtLeastNMilliseconds(long) - Static method in class org.elasticsearch.test.ESTestCase
 
spinForAtLeastOneMillisecond() - Static method in class org.elasticsearch.test.ESTestCase
 
start() - Method in class org.elasticsearch.test.BackgroundIndexer
Start indexing with no limit to the number of documents
start() - Method in class org.elasticsearch.test.discovery.MockZenPing
 
start() - Method in class org.elasticsearch.test.transport.CapturingTransport
 
start() - Method in class org.elasticsearch.test.transport.StubbableTransport
 
start(int) - Method in class org.elasticsearch.test.BackgroundIndexer
Start indexing
startAll() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
startCoordinatingOnlyNode(Settings) - Method in class org.elasticsearch.test.InternalTestCluster
 
startDataOnlyNode() - Method in class org.elasticsearch.test.InternalTestCluster
 
startDataOnlyNode(Settings) - Method in class org.elasticsearch.test.InternalTestCluster
 
startDataOnlyNodes(int) - Method in class org.elasticsearch.test.InternalTestCluster
 
startDataOnlyNodes(int, Settings) - Method in class org.elasticsearch.test.InternalTestCluster
 
startDisrupting() - Method in class org.elasticsearch.test.disruption.BlockClusterStateProcessing
 
startDisrupting() - Method in class org.elasticsearch.test.disruption.BlockMasterServiceOnMaster
 
startDisrupting() - Method in class org.elasticsearch.test.disruption.BusyMasterServiceDisruption
 
startDisrupting() - Method in class org.elasticsearch.test.disruption.IntermittentLongGCDisruption
 
startDisrupting() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
 
startDisrupting() - Method in class org.elasticsearch.test.disruption.NetworkDisruption
 
startDisrupting() - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
 
startDisrupting() - Method in class org.elasticsearch.test.disruption.SlowClusterStateProcessing
 
startMasterOnlyNode() - Method in class org.elasticsearch.test.InternalTestCluster
 
startMasterOnlyNode(Settings) - Method in class org.elasticsearch.test.InternalTestCluster
 
startMasterOnlyNodes(int) - Method in class org.elasticsearch.test.InternalTestCluster
 
startMasterOnlyNodes(int, Settings) - Method in class org.elasticsearch.test.InternalTestCluster
 
startNode() - Method in class org.elasticsearch.test.InternalTestCluster
Starts a node with default settings and returns its name.
startNode(long) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
 
startNode(Settings) - Method in class org.elasticsearch.test.InternalTestCluster
Starts a node with the given settings and returns its name.
startNode(Settings.Builder) - Method in class org.elasticsearch.test.InternalTestCluster
Starts a node with the given settings builder and returns its name.
startNodes(int) - Method in class org.elasticsearch.test.InternalTestCluster
Starts multiple nodes with default settings and returns their names
startNodes(int, Settings) - Method in class org.elasticsearch.test.InternalTestCluster
Starts multiple nodes with the given settings and returns their names
startNodes(Settings...) - Method in class org.elasticsearch.test.InternalTestCluster
Starts multiple nodes with the given settings and returns their names
startPrimary() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
startRandomInitializingShard(ClusterState, AllocationService) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
startReplicaAfterRecovery(IndexShard, IndexShard, Set<String>, IndexShardRoutingTable) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
startReplicas(int) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
startVerification() - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
stash() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestExecutionContext
 
Stash - Class in org.elasticsearch.test.rest.yaml
Allows to cache the last obtained test response and or part of it within variables that can be used as input values in following requests and assertions.
Stash() - Constructor for class org.elasticsearch.test.rest.yaml.Stash
 
stashValue(String, Object) - Method in class org.elasticsearch.test.rest.yaml.Stash
Allows to saved a specific field in the stash as key-value pair
stop() - Method in class org.elasticsearch.test.BackgroundIndexer
Stop all background threads *
stop() - Method in class org.elasticsearch.test.transport.CapturingTransport
 
stop() - Method in class org.elasticsearch.test.transport.StubbableTransport
 
stopCurrentMasterNode() - Method in class org.elasticsearch.test.InternalTestCluster
Stops the current master node forcefully
stopDisrupting() - Method in class org.elasticsearch.test.disruption.BlockClusterStateProcessing
 
stopDisrupting() - Method in class org.elasticsearch.test.disruption.BlockMasterServiceOnMaster
 
stopDisrupting() - Method in class org.elasticsearch.test.disruption.BusyMasterServiceDisruption
 
stopDisrupting() - Method in class org.elasticsearch.test.disruption.IntermittentLongGCDisruption
 
stopDisrupting() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
 
stopDisrupting() - Method in class org.elasticsearch.test.disruption.NetworkDisruption
 
stopDisrupting() - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
 
stopDisrupting() - Method in class org.elasticsearch.test.disruption.SlowClusterStateProcessing
 
stopInternal() - Method in class org.elasticsearch.transport.MockTcpTransport
 
stopRandomDataNode() - Method in class org.elasticsearch.test.InternalTestCluster
Stops a random data node in the cluster.
stopRandomNode(Predicate<Settings>) - Method in class org.elasticsearch.test.InternalTestCluster
Stops a random node in the cluster that applies to the given filter or non if the non of the nodes applies to the filter.
stopRandomNonMasterNode() - Method in class org.elasticsearch.test.InternalTestCluster
Stops any of the current nodes but not the master node.
store - Variable in class org.elasticsearch.index.engine.EngineTestCase
 
storedFieldsContext() - Method in class org.elasticsearch.test.TestSearchContext
 
storedFieldsContext(StoredFieldsContext) - Method in class org.elasticsearch.test.TestSearchContext
 
storedFieldsRequested() - Method in class org.elasticsearch.test.TestSearchContext
 
storeReplica - Variable in class org.elasticsearch.index.engine.EngineTestCase
 
StreamsUtils - Class in org.elasticsearch.test
 
StreamsUtils() - Constructor for class org.elasticsearch.test.StreamsUtils
 
strictOnly - Variable in class org.elasticsearch.index.mapper.FieldTypeTestCase.Modifier
true if this modifier only makes types incompatible in strict mode, false otherwise
STRING_ALIAS_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
STRING_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
STRING_FIELD_NAME_2 - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
 
StringMessageRequest() - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.StringMessageRequest
 
StringMessageRequest(String) - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.StringMessageRequest
 
StubbableConnectionManager - Class in org.elasticsearch.test.transport
 
StubbableConnectionManager(ConnectionManager, Settings, Transport, ThreadPool) - Constructor for class org.elasticsearch.test.transport.StubbableConnectionManager
 
StubbableConnectionManager.GetConnectionBehavior - Interface in org.elasticsearch.test.transport
 
StubbableConnectionManager.NodeConnectedBehavior - Interface in org.elasticsearch.test.transport
 
StubbableTransport - Class in org.elasticsearch.test.transport
 
StubbableTransport(Transport) - Constructor for class org.elasticsearch.test.transport.StubbableTransport
 
StubbableTransport.OpenConnectionBehavior - Interface in org.elasticsearch.test.transport
 
StubbableTransport.SendRequestBehavior - Interface in org.elasticsearch.test.transport
 
StubbableTransport.WrappedConnection - Class in org.elasticsearch.test.transport
 
subAggregationsSupplier - Variable in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
 
subReaderWrapper - Variable in class org.elasticsearch.test.engine.MockEngineSupport.DirectoryReaderWrapper
 
suggest() - Method in class org.elasticsearch.test.TestSearchContext
 
suggest(SuggestionSearchContext) - Method in class org.elasticsearch.test.TestSearchContext
 
SUITE - org.elasticsearch.test.ESIntegTestCase.Scope
A cluster shared across all method in a single test suite
SUITE_CLUSTER_NODE_PREFIX - Static variable in class org.elasticsearch.test.ESIntegTestCase
node names of the corresponding clusters will start with these prefixes
supportsBoost() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Few queries allow you to set the boost on the Java API, although the corresponding parser doesn't parse it as it isn't supported.
supportsDedicatedMasters() - Method in annotation type org.elasticsearch.test.ESIntegTestCase.ClusterScope
Indicates whether the cluster can have dedicated master nodes.
supportsQueryName() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Few queries allow you to set the query name on the Java API, although the corresponding parser doesn't parse it as it isn't supported.
supportsUnknownFields() - Method in class org.elasticsearch.test.AbstractSerializingTestCase
Indicates whether the parser supports unknown fields or not.
supportsUnknownFields() - Method in class org.elasticsearch.test.AbstractStreamableXContentTestCase
Indicates whether the parser supports unknown fields or not.
supportsUnknownFields() - Method in class org.elasticsearch.test.AbstractXContentTestCase
Indicates whether the parser supports unknown fields or not.
supportsUnknownFields(boolean) - Method in class org.elasticsearch.test.AbstractXContentTestCase.XContentTester
 
suspendThreads(Set<Thread>) - Method in class org.elasticsearch.test.disruption.LongGCDisruption
resolves all threads belonging to given node and suspends them if their current stack trace is "safe".
syncGlobalCheckpoint() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
syncRetentionLeases(ShardId, RetentionLeases, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
 
SYSPROP_THIRDPARTY - Static variable in class org.elasticsearch.test.ESIntegTestCase
Property that controls whether ThirdParty Integration tests are run (not the default).

T

task - Variable in class org.elasticsearch.index.reindex.AbstractAsyncBulkByScrollActionTestCase
 
teardown() - Static method in class org.elasticsearch.common.io.PathUtilsForTesting
Resets filesystem back to the real system default
tearDown() - Method in class org.elasticsearch.index.engine.EngineTestCase
 
tearDown() - Method in class org.elasticsearch.index.reindex.AbstractAsyncBulkByScrollActionTestCase
 
tearDown() - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
tearDown() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
 
tearDown() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
tearDownClass() - Static method in class org.elasticsearch.test.ESSingleNodeTestCase
 
TeardownSection - Class in org.elasticsearch.test.rest.yaml.section
 
tearDownThreadPool() - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
terminal - Variable in class org.elasticsearch.cli.CommandTestCase
The terminal that execute uses.
terminate(ExecutorService...) - Static method in class org.elasticsearch.test.ESTestCase
 
terminate(ThreadPool) - Static method in class org.elasticsearch.test.ESTestCase
 
terminateAfter() - Method in class org.elasticsearch.test.TestSearchContext
 
terminateAfter(int) - Method in class org.elasticsearch.test.TestSearchContext
 
terms(String) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
 
terms(String) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.ThrowingFields
 
Terms - org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
 
TermsEnum - org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
 
TermVectors - org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
 
test() - Method in class org.elasticsearch.test.AbstractXContentTestCase.XContentTester
 
test() - Method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
 
TEST - org.elasticsearch.test.ESIntegTestCase.Scope
A test exclusive test cluster
TEST_CLUSTER_NODE_PREFIX - Static variable in class org.elasticsearch.test.ESIntegTestCase
 
testAcceptedChannelCount() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testAdapterSendReceiveCallbacks() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
TestAllocateDecision(Decision) - Constructor for class org.elasticsearch.cluster.ESAllocationTestCase.TestAllocateDecision
 
TestAnalysis(IndexAnalyzers, Map<String, TokenFilterFactory>, Map<String, TokenizerFactory>, Map<String, CharFilterFactory>) - Constructor for class org.elasticsearch.test.ESTestCase.TestAnalysis
 
testArrayOffset() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testBasicEquals() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testBlockingIncomingRequests() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testChannelCloseWhileConnecting() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testCharFilters() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
 
testCheckCompatibility() - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
 
testCheckTypeName() - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
 
testClone() - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
 
TestCluster - Class in org.elasticsearch.test
Base test cluster that exposes the basis to run tests against any elasticsearch cluster, whose layout (e.g.
TestCluster(long) - Constructor for class org.elasticsearch.test.TestCluster
 
testClusterClosed() - Method in class org.elasticsearch.test.disruption.NetworkDisruption
 
testClusterClosed() - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
 
testClusterClosed() - Method in class org.elasticsearch.test.disruption.SingleNodeDisruption
 
testCoerce() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
testCompareTo() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testConcurrentDisconnectOnNonPublishedConnection() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testConcurrentSendRespondAndDisconnect() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testContainerCreationAndDeletion() - Method in class org.elasticsearch.repositories.ESBlobStoreTestCase
 
testCopyBytesRefSharesBytes() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
TestCustomMetaData - Class in org.elasticsearch.test
 
TestCustomMetaData(String) - Constructor for class org.elasticsearch.test.TestCustomMetaData
 
testDecimalCoerce() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
testDefaults() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
testDeleteBlob() - Method in class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
 
testDeleteBlobIgnoringIfNotExists() - Method in class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
 
testDiffableSerialization() - Method in class org.elasticsearch.test.AbstractDiffableSerializationTestCase
 
testDiffableSerialization() - Method in class org.elasticsearch.test.AbstractDiffableWireSerializationTestCase
 
testDiffableSerialization(Supplier<T>, Function<T, T>, NamedWriteableRegistry, Writeable.Reader<T>, Writeable.Reader<Diff<T>>) - Static method in class org.elasticsearch.test.DiffableTestUtils
Tests making random changes to an object, calculating diffs for these changes, sending this diffs over the wire and appling these diffs on the other side.
testDisconnectListener() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testDocument() - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
testDocumentWithTextField() - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
testDocumentWithTextField(String) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
testEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testEmptyName() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
testEmptyToBytesRefIterator() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
TestEnvironment - Class in org.elasticsearch.env
Provides a convenience method for tests to construct an Environment when the config path does not matter.
testEquals() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testEquals() - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
 
testEqualsAndHashcode() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
 
testEqualsAndHashcode() - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
testEqualsAndHashcode() - Method in class org.elasticsearch.test.AbstractWireTestCase
Tests that the equals and hashcode methods are consistent and copied versions of the instance have are equal.
testErrorMessage() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
TestEventListener() - Constructor for class org.elasticsearch.test.MockIndexEventListener.TestEventListener
 
testFailToSend() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testFailure(Failure) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter
 
testFinished(Description) - Method in class org.elasticsearch.test.junit.listeners.LoggingListener
 
testFinished(Description) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter
 
testFreeze() - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
 
testFromXContent() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
Generic test that creates new AggregatorFactory from the test AggregatorFactory and checks both for equality and asserts equality on the two queries.
testFromXContent() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Generic test that creates new query from the test query and checks both for equality and asserts equality on the two queries.
testFromXContent() - Method in class org.elasticsearch.test.AbstractSerializingTestCase
Generic test that creates new instance from the test instance and checks both for equality and asserts equality on the two instances.
testFromXContent() - Method in class org.elasticsearch.test.AbstractStreamableXContentTestCase
Generic test that creates new instance from the test instance and checks both for equality and asserts equality on the two queries.
testFromXContent() - Method in class org.elasticsearch.test.AbstractXContentTestCase
Generic test that creates new instance from the test instance and checks both for equality and asserts equality on the two queries.
testFromXContent() - Method in class org.elasticsearch.test.InternalAggregationTestCase
 
testFromXContent(int, Supplier<T>, boolean, String[], Predicate<String>, CheckedBiFunction<XContent, BytesReference, XContentParser, IOException>, CheckedFunction<XContentParser, T, IOException>, BiConsumer<T, T>, boolean, ToXContent.Params) - Static method in class org.elasticsearch.test.AbstractXContentTestCase
 
testFromXContentMulti() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
Create at least 2 aggregations and test equality and hash
testFromXContentWithRandomFields() - Method in class org.elasticsearch.test.InternalAggregationTestCase
 
TestGatewayAllocator - Class in org.elasticsearch.test.gateway
A gateway allocator implementation that keeps an in memory list of started shard allocation that are used as replies to the, normally async, fetch data requests.
TestGatewayAllocator() - Constructor for class org.elasticsearch.test.gateway.TestGatewayAllocator
 
testGet() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testHandlerIsInvokedOnConnectionClose() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testHandshakeUpdatesVersion() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testHandshakeWithIncompatVersion() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testHashCode() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testHelloWorld() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testHelloWorldCompressed() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testHostOnMessages() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testIndicesDeletedFromRepository() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
testInputStreamSkip() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testIterator() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testIteratorRandom() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testIterators() - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
 
testKeepAlivePings() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testLength() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testList() - Method in class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
 
testLocalNodeConnection() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
TestLogging - Annotation Type in org.elasticsearch.test.junit.annotations
Annotation used to set a custom log level for a specific test method.
testMockFailToSendNoConnectRule() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testMockUnresponsiveRule() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testMultipleSnapshotAndRollback() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
testMultiTermAware() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
 
testMultiValuedField() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testMultiValuedFieldWithValueScript() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testMultiValuedFieldWithValueScriptWithParams() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testMustRewrite() - Method in class org.elasticsearch.test.AbstractQueryTestCase
This test ensures that queries that need to be rewritten have dedicated tests.
testNegativeBoosts() - Method in class org.elasticsearch.test.AbstractQueryTestCase
 
testNodeNameIsOnAllLinesOfLog() - Method in class org.elasticsearch.common.logging.NodeNameInLogsIntegTestCase
 
testNoDocValues() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
testNotifyOnShutdown() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testNotIndexed() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
testNullValue() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
testOrderByEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testOtherDocCount(String...) - Method in class org.elasticsearch.search.aggregations.bucket.AbstractTermsTestCase
 
testParsedDocument(String, String, ParseContext.Document, BytesReference, Mapping) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
testParsedDocument(String, String, ParseContext.Document, BytesReference, Mapping, boolean) - Static method in class org.elasticsearch.index.engine.EngineTestCase
 
TestPlugin() - Constructor for class org.elasticsearch.cluster.MockInternalClusterInfoService.TestPlugin
 
TestPlugin() - Constructor for class org.elasticsearch.search.MockSearchService.TestPlugin
 
TestPlugin() - Constructor for class org.elasticsearch.test.MockIndexEventListener.TestPlugin
 
TestPlugin() - Constructor for class org.elasticsearch.test.store.MockFSIndexStore.TestPlugin
 
TestPlugin() - Constructor for class org.elasticsearch.test.transport.MockTransportService.TestPlugin
 
TestPlugin(Settings) - Constructor for class org.elasticsearch.test.discovery.TestZenDiscovery.TestPlugin
 
testPreBuiltMultiTermAware() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
 
TestProcessor - Class in org.elasticsearch.ingest
Processor used for testing, keeps track of how many times it is invoked and accepts a Consumer of IngestDocument to be called when executed.
TestProcessor(RuntimeException) - Constructor for class org.elasticsearch.ingest.TestProcessor
 
TestProcessor(String, String, RuntimeException) - Constructor for class org.elasticsearch.ingest.TestProcessor
 
TestProcessor(String, String, Consumer<IngestDocument>) - Constructor for class org.elasticsearch.ingest.TestProcessor
 
TestProcessor(String, String, Function<IngestDocument, IngestDocument>) - Constructor for class org.elasticsearch.ingest.TestProcessor
 
TestProcessor(Consumer<IngestDocument>) - Constructor for class org.elasticsearch.ingest.TestProcessor
 
TestProcessor.Factory - Class in org.elasticsearch.ingest
 
testProfileSettings() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testProfilesIncludesDefault() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testQueryWrappedInArray() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Test that wraps the randomly generated query into an array as follows: { "query_name" : [{}]} This causes unexpected situations in parser code that may not be handled properly.
testRandomReads() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testReadNonExistingPath() - Method in class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
 
testReduceRandom() - Method in class org.elasticsearch.test.InternalAggregationTestCase
 
testRegisterHandlerTwice() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
TestRequest() - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.TestRequest
 
TestRequest(String) - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.TestRequest
 
testResponseHeadersArePreserved() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testRetentionLeasesClearedOnRestore() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
testRunFinished(Result) - Method in class org.elasticsearch.test.junit.listeners.LoggingListener
 
testRunStarted(Description) - Method in class org.elasticsearch.test.junit.listeners.LoggingListener
 
TESTS_CLIENT_RATIO - Static variable in class org.elasticsearch.test.ESIntegTestCase
Key used to set the transport client ratio via the commandline -D"tests.client.ratio"
TESTS_CLUSTER - Static variable in class org.elasticsearch.test.ESIntegTestCase
Key used to eventually switch to using an external cluster and provide its transport addresses
TESTS_ENABLE_MOCK_MODULES - Static variable in class org.elasticsearch.test.ESIntegTestCase
A boolean value to enable or disable mock modules.
testScriptMultiValued() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testScriptMultiValuedWithParams() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testScriptSingleValued() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testScriptSingleValuedWithParams() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
TestSearchContext - Class in org.elasticsearch.test
 
TestSearchContext(QueryShardContext) - Constructor for class org.elasticsearch.test.TestSearchContext
 
TestSearchContext(QueryShardContext, IndexShard) - Constructor for class org.elasticsearch.test.TestSearchContext
 
TestSearchContext(ThreadPool, BigArrays, IndexService) - Constructor for class org.elasticsearch.test.TestSearchContext
 
TestSeedPlugin() - Constructor for class org.elasticsearch.test.ESIntegTestCase.TestSeedPlugin
 
testSendRandomRequests() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testSerialization() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
Test serialization and deserialization of the test AggregatorFactory.
testSerialization() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Test serialization and deserialization of the test query.
testSerialization() - Method in class org.elasticsearch.test.AbstractWireTestCase
Test serialization and deserialization of the test instance.
testSerializationMulti() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
Create at least 2 aggregations and test equality and hash
testShallowCopy() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
 
TestShardRouting - Class in org.elasticsearch.cluster.routing
A helper that allows to create shard routing instances within tests, while not requiring to expose different simplified constructors on the ShardRouting itself.
TestShardRouting() - Constructor for class org.elasticsearch.cluster.routing.TestShardRouting
 
testSingleValuedField() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testSingleValuedFieldGetProperty() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testSingleValuedFieldPartiallyUnmapped() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testSingleValuedFieldWithValueScript() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testSingleValuedFieldWithValueScriptWithParams() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testSlice() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testSliceArrayOffset() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testSliceCopyBytesRef() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testSliceEquals() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testSliceIterator() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testSliceStreamInput() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testSliceToBytesRef() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testSliceWriteToOutputStream() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testSnapshotAndRestore() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
 
testStarted(Description) - Method in class org.elasticsearch.test.junit.listeners.LoggingListener
 
testStarted(Description) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter
 
testStore() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
testStreamInput() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testStreamInputBulkReadWithOffset() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testStreamInputMarkAndReset() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testTcpHandshake() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testTcpHandshakeConnectionReset() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testTcpHandshakeTimeout() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
TestTemplateService - Class in org.elasticsearch.ingest
 
TestTemplateService.MockTemplateScript - Class in org.elasticsearch.ingest
 
TestTemplateService.MockTemplateScript.Factory - Class in org.elasticsearch.ingest
 
testThreadContext() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
TestThreadInfoPatternConverter - Class in org.elasticsearch.common.logging
Converts %test_thread_info in log4j patterns into information based on the loggin thread's name.
TestThreadPool - Class in org.elasticsearch.threadpool
 
TestThreadPool(String) - Constructor for class org.elasticsearch.threadpool.TestThreadPool
 
TestThreadPool(String, Settings) - Constructor for class org.elasticsearch.threadpool.TestThreadPool
 
testTimeoutPerConnection() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testTimeoutSendExceptionWithDelayedResponse() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testTimeoutSendExceptionWithNeverSendingBackResponse() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testToBytes() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testToBytesRef() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testToBytesRefMaterializedPages() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testToBytesRefSharedPage() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testTokenFilters() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
 
testTokenizers() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
 
testToQuery() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Test creates the Query from the QueryBuilder under test and delegates the assertions being made on the result to the implementing subclass.
testToString() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
Generic test that checks that the toString method renders the XContent correctly.
testToUtf8() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
testTracerLog() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testTransportProfilesWithPortAndHost() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testTransportStats() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testTransportStatsWithException() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testUnknownField() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Test that unknown field trigger ParsingException.
testUnknownObjectException() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Test that adding an additional object within each object of the otherwise correct query always triggers some kind of parse exception.
testUnmapped() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
 
testValidOutput() - Method in class org.elasticsearch.test.AbstractQueryTestCase
Generic test that checks that the Strings.toString() method renders the XContent correctly.
testVerifyOverwriteFails() - Method in class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
 
testVersionFrom0to0() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testVersionFrom0to1() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testVersionFrom1to0() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testVersionFrom1to1() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testVoidMessageCompressed() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
testWriteRead() - Method in class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
 
testWriteToOutputStream() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
 
TestZenDiscovery - Class in org.elasticsearch.test.discovery
A alternative zen discovery which allows using mocks for things like pings, as well as giving access to internals.
TestZenDiscovery.TestPlugin - Class in org.elasticsearch.test.discovery
A plugin which installs mock discovery and configures it to be used.
TEXT_PLAIN_CONTENT_TYPE - Static variable in class org.elasticsearch.test.fixture.AbstractHttpFixture
 
threadPool - Variable in class org.elasticsearch.index.engine.EngineTestCase
 
threadPool - Variable in class org.elasticsearch.index.reindex.AbstractAsyncBulkByScrollActionTestCase
 
threadPool - Variable in class org.elasticsearch.index.shard.IndexShardTestCase
 
threadPool - Variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
threadPoolSettings() - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
throttleAllocationDeciders() - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
ThrowingFields(Fields, ThrowingLeafReaderWrapper.Thrower) - Constructor for class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.ThrowingFields
 
ThrowingLeafReaderWrapper - Class in org.elasticsearch.test.engine
An FilterLeafReader that allows to throw exceptions if certain methods are called on is.
ThrowingLeafReaderWrapper(LeafReader, ThrowingLeafReaderWrapper.Thrower) - Constructor for class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
 
ThrowingLeafReaderWrapper.Flags - Enum in org.elasticsearch.test.engine
ThrowingLeafReaderWrapper.Thrower - Interface in org.elasticsearch.test.engine
A callback interface that allows to throw certain exceptions for methods called on the IndexReader that is wrapped by ThrowingLeafReaderWrapper
ThrowingLeafReaderWrapper.ThrowingFields - Class in org.elasticsearch.test.engine
Wraps a Fields but with additional asserts
ThrowingLeafReaderWrapper.ThrowingTerms - Class in org.elasticsearch.test.engine
Wraps a Terms but with additional asserts
ThrowingTerms(Terms, ThrowingLeafReaderWrapper.Thrower) - Constructor for class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.ThrowingTerms
 
timeEstimateCounter() - Method in class org.elasticsearch.test.TestSearchContext
 
timeout() - Method in class org.elasticsearch.test.TestSearchContext
 
timeout() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.StringMessageRequest
 
timeout(TimeValue) - Method in class org.elasticsearch.test.TestSearchContext
 
tmpPaths() - Method in class org.elasticsearch.test.ESTestCase
Returns a random number of temporary paths.
tokenFilter - Variable in class org.elasticsearch.test.ESTestCase.TestAnalysis
 
tokenizer - Variable in class org.elasticsearch.test.ESTestCase.TestAnalysis
 
TOLERANCE - Static variable in class org.elasticsearch.test.InternalAggregationTestCase
 
tombstoneDocSupplier() - Static method in class org.elasticsearch.index.engine.EngineTestCase
Creates a tombstone document that only includes uid, seq#, term and version fields.
toShuffledXContent(ToXContent, XContentType, ToXContent.Params, boolean, String...) - Method in class org.elasticsearch.test.ESTestCase
Returns the bytes that represent the XContent output of the provided ToXContent object, using the provided XContentType.
toShuffledXContent(ToXContent, XContentType, ToXContent.Params, boolean, CheckedBiFunction<XContent, BytesReference, XContentParser, IOException>, String...) - Static method in class org.elasticsearch.test.ESTestCase
Returns the bytes that represent the XContent output of the provided ToXContent object, using the provided XContentType.
toString() - Method in class org.elasticsearch.index.engine.DocIdSeqNoAndTerm
 
toString() - Method in class org.elasticsearch.test.client.RandomizingClient
 
toString() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.Bridge
 
toString() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDelay
 
toString() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDisconnect
 
toString() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkUnresponsive
 
toString() - Method in class org.elasticsearch.test.disruption.NetworkDisruption
 
toString() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
 
toString() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Request
 
toString() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Response
 
toString() - Method in class org.elasticsearch.test.NotEqualMessageBuilder
The failure message.
toString() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
 
toString() - Method in class org.elasticsearch.test.TestCustomMetaData
 
toString() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.TestRequest
 
toString() - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
 
toString(MappedFieldType) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
 
totalIndexedDocs() - Method in class org.elasticsearch.test.BackgroundIndexer
 
totalNumShards - Variable in class org.elasticsearch.test.ESIntegTestCase.NumShards
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.test.rest.yaml.Stash
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.test.TestCustomMetaData
 
toXContentBuilder(XContent) - Method in class org.elasticsearch.test.rest.yaml.ObjectPath
Create a new XContentBuilder from the xContent object underlying this ObjectPath.
traceEnabled() - Method in class org.elasticsearch.test.transport.MockTransportService
 
Tracer() - Constructor for class org.elasticsearch.test.transport.MockTransportService.Tracer
 
traceReceivedRequest(long, String) - Method in class org.elasticsearch.test.transport.MockTransportService
 
traceReceivedResponse(long, DiscoveryNode, String) - Method in class org.elasticsearch.test.transport.MockTransportService
 
traceRequestSent(DiscoveryNode, long, String, TransportRequestOptions) - Method in class org.elasticsearch.test.transport.MockTransportService
 
traceResponseSent(long, String) - Method in class org.elasticsearch.test.transport.MockTransportService
 
traceResponseSent(long, String, Exception) - Method in class org.elasticsearch.test.transport.MockTransportService
 
trackScores() - Method in class org.elasticsearch.test.TestSearchContext
 
trackScores(boolean) - Method in class org.elasticsearch.test.TestSearchContext
 
trackTotalHits() - Method in class org.elasticsearch.test.TestSearchContext
 
trackTotalHits(boolean) - Method in class org.elasticsearch.test.TestSearchContext
 
TransformAndSetSection - Class in org.elasticsearch.test.rest.yaml.section
Represents a transform_and_set section:
TransformAndSetSection(XContentLocation) - Constructor for class org.elasticsearch.test.rest.yaml.section.TransformAndSetSection
 
TRANSLOG_RETENTION_CHECK_INTERVAL_SETTING - Static variable in class org.elasticsearch.test.InternalSettingsPlugin
 
TranslogDeletionPolicies - Class in org.elasticsearch.index.translog
 
TranslogDeletionPolicies() - Constructor for class org.elasticsearch.index.translog.TranslogDeletionPolicies
 
translogHandler - Variable in class org.elasticsearch.index.engine.EngineTestCase
 
TranslogHandler - Class in org.elasticsearch.index.engine
 
TranslogHandler(NamedXContentRegistry, IndexSettings) - Constructor for class org.elasticsearch.index.engine.TranslogHandler
 
transport() - Method in class org.elasticsearch.test.transport.MockTransportService
 
TRANSPORT_CLIENT_PREFIX - Static variable in class org.elasticsearch.test.InternalTestCluster
 
transportClient() - Method in class org.elasticsearch.test.InternalTestCluster
Returns a transport client
transportClientPlugins() - Method in class org.elasticsearch.test.ESIntegTestCase
Returns a collection of plugins that should be loaded when creating a transport client.
transportClientPlugins() - Method in class org.elasticsearch.test.NodeConfigurationSource
Returns plugins that should be loaded in the transport client
transportClientRatio - Variable in class org.elasticsearch.test.TestCluster
 
transportClientRatio() - Method in annotation type org.elasticsearch.test.ESIntegTestCase.ClusterScope
Returns the transport client ratio.
transportClientSettings() - Method in class org.elasticsearch.test.ESIntegTestCase
This method is used to obtain additional settings for clients created by the internal cluster.
transportClientSettings() - Method in class org.elasticsearch.test.NodeConfigurationSource
 
TransportWriteActionTestHelper - Class in org.elasticsearch.action.support.replication
 
TransportWriteActionTestHelper() - Constructor for class org.elasticsearch.action.support.replication.TransportWriteActionTestHelper
 
TRUSTSTORE_PASSWORD - Static variable in class org.elasticsearch.test.rest.ESRestTestCase
 
TRUSTSTORE_PATH - Static variable in class org.elasticsearch.test.rest.ESRestTestCase
 
TwoPartitions(String, String) - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
 
TwoPartitions(Set<String>, Set<String>) - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
 
typeName() - Method in class org.elasticsearch.index.mapper.MockFieldMapper.FakeFieldType
 
TYPES - Variable in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 

U

unregister(Task) - Method in class org.elasticsearch.test.tasks.MockTaskManager
 
UnseenEventExpectation(String, String, Level, String) - Constructor for class org.elasticsearch.test.MockLogAppender.UnseenEventExpectation
 
updateIndexSettings(String, Settings.Builder) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
 
updateMappings(IndexShard, IndexMetaData) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
 
updateRoutingEntry(IndexShard, ShardRouting) - Static method in class org.elasticsearch.index.shard.IndexShardTestCase
 
uri() - Method in class org.elasticsearch.test.rest.FakeRestRequest
 
USE_MOCK_PINGS - Static variable in class org.elasticsearch.test.discovery.TestZenDiscovery
 
USE_MOCK_TASK_MANAGER_SETTING - Static variable in class org.elasticsearch.test.tasks.MockTaskManager
 

V

validate() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
 
validateClusterFormed() - Method in class org.elasticsearch.test.InternalTestCluster
ensure a cluster is formed with all published nodes.
validateClusterFormed(String) - Method in class org.elasticsearch.test.InternalTestCluster
ensure a cluster is formed with all published nodes, but do so by using the client of the specified node
validateClusterForming() - Method in class org.elasticsearch.test.InternalTestCluster.RestartCallback
returns true if the restart should also validate the cluster has reformed
value() - Method in annotation type org.elasticsearch.test.junit.annotations.TestLogging
 
valueOf(String) - Static method in enum org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.test.ESIntegTestCase.Scope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Body
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.test.ESIntegTestCase.Scope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Body
Returns an array containing the constants of this enum type, in the order they are declared.
verify(String, DiscoveryNode) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
 
version() - Method in class org.elasticsearch.test.TestSearchContext
 
version(boolean) - Method in class org.elasticsearch.test.TestSearchContext
 
version0 - Static variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
Version0Request() - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.Version0Request
 
version1 - Static variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
 
Version1Request() - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.Version1Request
 
VersionSensitiveWarningsHandler(Set<Version>) - Constructor for class org.elasticsearch.test.rest.ESRestTestCase.VersionSensitiveWarningsHandler
 
VersionUtils - Class in org.elasticsearch.test
Utilities for selecting versions in tests
VersionUtils() - Constructor for class org.elasticsearch.test.VersionUtils
 

W

waitForActiveLicense(RestClient) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
Wait for the license to be applied and active.
waitForDocs(long) - Method in class org.elasticsearch.test.ESIntegTestCase
Waits until at least a give number of document is visible for searchers
waitForDocs(long, int, TimeUnit, BackgroundIndexer) - Method in class org.elasticsearch.test.ESIntegTestCase
Waits until at least a give number of document is visible for searchers
waitForDocs(long, BackgroundIndexer) - Method in class org.elasticsearch.test.ESIntegTestCase
Waits until at least a give number of document is visible for searchers
waitForOpsToComplete(InternalEngine, long) - Static method in class org.elasticsearch.index.engine.EngineTestCase
Waits for all operations up to the provided sequence number to complete in the given internal engine.
waitForPendingTasks(RestClient) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
Wait for outstanding tasks to complete.
waitForPendingTasks(RestClient, Predicate<String>) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
Wait for outstanding tasks to complete.
waitForRelocation() - Method in class org.elasticsearch.test.ESIntegTestCase
Waits for all relocating shards to become active using the cluster health API.
waitForRelocation(ClusterHealthStatus) - Method in class org.elasticsearch.test.ESIntegTestCase
Waits for all relocating shards to become active and the cluster has reached the given health status using the cluster health API.
waitForTaskCompletion(Task) - Method in interface org.elasticsearch.test.tasks.MockTaskManagerListener
 
waitForTaskCompletion(Task, long) - Method in class org.elasticsearch.test.tasks.MockTaskManager
 
waitNoPendingTasksOnAll() - Method in class org.elasticsearch.test.ESIntegTestCase
Waits until all nodes have no pending tasks.
warningsShouldFailRequest(List<String>) - Method in class org.elasticsearch.test.rest.ESRestTestCase.VersionSensitiveWarningsHandler
 
WHOLE_TYPES - Variable in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
 
wipe(Set<String>) - Method in class org.elasticsearch.test.TestCluster
Wipes any data that a test can leave behind: indices, templates (except exclude templates) and repositories
wipeAllTemplates(Set<String>) - Method in class org.elasticsearch.test.TestCluster
Removes all templates, except the templates defined in the exclude
wipeIndices(String...) - Method in class org.elasticsearch.test.TestCluster
Deletes the given indices from the tests cluster.
wipePendingDataDirectories() - Method in class org.elasticsearch.test.InternalTestCluster
 
wipeRepositories(String...) - Method in class org.elasticsearch.test.TestCluster
Deletes repositories, supports wildcard notation.
wipeTemplates(String...) - Method in class org.elasticsearch.test.TestCluster
Deletes index templates, support wildcard notation.
withCircuitBreaking() - Method in class org.elasticsearch.common.util.MockBigArrays
 
withContent(BytesReference, XContentType) - Method in class org.elasticsearch.test.rest.FakeRestRequest.Builder
 
withHeaders(Map<String, List<String>>) - Method in class org.elasticsearch.test.rest.FakeRestRequest.Builder
 
withMethod(RestRequest.Method) - Method in class org.elasticsearch.test.rest.FakeRestRequest.Builder
 
withParams(Map<String, String>) - Method in class org.elasticsearch.test.rest.FakeRestRequest.Builder
 
withPath(String) - Method in class org.elasticsearch.test.rest.FakeRestRequest.Builder
 
withRemoteAddress(SocketAddress) - Method in class org.elasticsearch.test.rest.FakeRestRequest.Builder
 
wrap(DirectoryReader) - Static method in class org.elasticsearch.search.aggregations.AggregatorTestCase
 
WRAP_READER_RATIO - Static variable in class org.elasticsearch.test.engine.MockEngineSupport
Allows tests to wrap an index reader randomly with a given ratio.
wrapSearcher(Engine.Searcher) - Method in class org.elasticsearch.test.engine.MockEngineSupport
 
wrapTerms(String) - Method in interface org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Thrower
If this method returns true the Terms instance for the given field is wrapped with Thrower support otherwise no exception will be thrown for the current Terms instance or any other instance obtained from it.
writableRegistry() - Method in class org.elasticsearch.test.ESTestCase
The NamedWriteableRegistry to use for this test.
writeBlob(BlobContainer, String, BytesArray) - Static method in class org.elasticsearch.repositories.ESBlobStoreTestCase
 
writeBlob(BlobContainer, String, BytesArray, boolean) - Method in class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
 
writePluginProperties(Path, String...) - Static method in class org.elasticsearch.plugins.PluginTestUtil
 
writeRandomBlob(BlobContainer, String, int) - Static method in class org.elasticsearch.repositories.ESBlobStoreTestCase
 
writeTo(StreamOutput) - Method in class org.elasticsearch.test.TestCustomMetaData
 
writeTo(StreamOutput) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.StringMessageRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.TestRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.Version0Request
 
writeTo(StreamOutput) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.Version1Request
 

X

XCONTENT_REGISTRY - Static variable in interface org.elasticsearch.test.rest.yaml.section.ExecutableSection
NamedXContentRegistry that parses the default list of ExecutableSections available for tests.
xContentRegistry() - Method in class org.elasticsearch.test.AbstractBuilderTestCase
 
xContentRegistry() - Method in class org.elasticsearch.test.ESIntegTestCase
 
xContentRegistry() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
 
xContentRegistry() - Method in class org.elasticsearch.test.ESTestCase
The NamedXContentRegistry to use for this test.
xContentRegistry() - Method in class org.elasticsearch.test.InternalAggregationTestCase
 
xContentTester(CheckedBiFunction<XContent, BytesReference, XContentParser, IOException>, Function<XContentType, T>, ToXContent.Params, CheckedFunction<XContentParser, T, IOException>) - Static method in class org.elasticsearch.test.AbstractXContentTestCase
 
xContentTester(CheckedBiFunction<XContent, BytesReference, XContentParser, IOException>, Supplier<T>, CheckedBiConsumer<T, XContentBuilder, IOException>, CheckedFunction<XContentParser, T, IOException>) - Static method in class org.elasticsearch.test.AbstractXContentTestCase
 
xContentTester(CheckedBiFunction<XContent, BytesReference, XContentParser, IOException>, Supplier<T>, CheckedFunction<XContentParser, T, IOException>) - Static method in class org.elasticsearch.test.AbstractXContentTestCase
 
xContentTester(CheckedBiFunction<XContent, BytesReference, XContentParser, IOException>, Supplier<T>, ToXContent.Params, CheckedFunction<XContentParser, T, IOException>) - Static method in class org.elasticsearch.test.AbstractXContentTestCase
 
XContentTestUtils - Class in org.elasticsearch.test
 

Y

yesAllocationDeciders() - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y 
All Classes All Packages