Index
All Classes|All Packages|Constant Field Values|Deprecated API|Serialized Form
A
- AbstractAsyncBulkByScrollActionTestCase<Request extends org.elasticsearch.index.reindex.AbstractBulkByScrollRequest<Request>,Response extends org.elasticsearch.index.reindex.BulkByScrollResponse> - Class in org.elasticsearch.index.reindex
- AbstractAsyncBulkByScrollActionTestCase() - Constructor for class org.elasticsearch.index.reindex.AbstractAsyncBulkByScrollActionTestCase
- AbstractBlobContainerRetriesTestCase - Class in org.elasticsearch.repositories.blobstore
- AbstractBlobContainerRetriesTestCase() - Constructor for class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- AbstractBlobContainerRetriesTestCase.ZeroInputStream - Class in org.elasticsearch.repositories.blobstore
-
A resettable InputStream that only serves zeros.
- AbstractBootstrapCheckTestCase - Class in org.elasticsearch.test
- AbstractBootstrapCheckTestCase() - Constructor for class org.elasticsearch.test.AbstractBootstrapCheckTestCase
- AbstractBroadcastResponseTestCase<T extends org.elasticsearch.action.support.broadcast.BroadcastResponse> - Class in org.elasticsearch.test
- AbstractBroadcastResponseTestCase() - Constructor for class org.elasticsearch.test.AbstractBroadcastResponseTestCase
- 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
- AbstractCoordinatorTestCase - Class in org.elasticsearch.cluster.coordination
- AbstractCoordinatorTestCase() - Constructor for class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- AbstractCoordinatorTestCase.Cluster - Class in org.elasticsearch.cluster.coordination
- AbstractCoordinatorTestCase.Cluster.ClusterNode - Class in org.elasticsearch.cluster.coordination
- AbstractDiffableSerializationTestCase<T extends org.elasticsearch.cluster.Diffable<T> & org.elasticsearch.common.xcontent.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 org.elasticsearch.cluster.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(String, int) - 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.
- AbstractHttpServerTransportTestCase - Class in org.elasticsearch.http
- AbstractHttpServerTransportTestCase() - Constructor for class org.elasticsearch.http.AbstractHttpServerTransportTestCase
- AbstractMultiClustersTestCase - Class in org.elasticsearch.test
- AbstractMultiClustersTestCase() - Constructor for class org.elasticsearch.test.AbstractMultiClustersTestCase
- AbstractNamedWriteableTestCase<T extends org.elasticsearch.common.io.stream.NamedWriteable> - Class in org.elasticsearch.test
-
Standard test case for testing the wire serialization of subclasses of NamedWriteable.
- AbstractNamedWriteableTestCase() - Constructor for class org.elasticsearch.test.AbstractNamedWriteableTestCase
- 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
- AbstractNXYSignificanceHeuristicTestCase - Class in org.elasticsearch.search.aggregations.bucket
-
Abstract test case for testing NXY significant term heuristics
- AbstractNXYSignificanceHeuristicTestCase() - Constructor for class org.elasticsearch.search.aggregations.bucket.AbstractNXYSignificanceHeuristicTestCase
- AbstractQueryTestCase<QB extends org.elasticsearch.index.query.AbstractQueryBuilder<QB>> - Class in org.elasticsearch.test
- AbstractQueryTestCase() - Constructor for class org.elasticsearch.test.AbstractQueryTestCase
- AbstractSchemaValidationTestCase<T extends org.elasticsearch.common.xcontent.ToXContent> - Class in org.elasticsearch.test
-
Test case for validating
ToXContent
objects against a json schema. - AbstractSchemaValidationTestCase() - Constructor for class org.elasticsearch.test.AbstractSchemaValidationTestCase
- AbstractSerializingTestCase<T extends org.elasticsearch.common.xcontent.ToXContent & org.elasticsearch.common.io.stream.Writeable> - Class in org.elasticsearch.test
- AbstractSerializingTestCase() - Constructor for class org.elasticsearch.test.AbstractSerializingTestCase
- AbstractSignificanceHeuristicTestCase - Class in org.elasticsearch.search.aggregations.bucket
-
Abstract test case for testing significant term heuristics
- AbstractSignificanceHeuristicTestCase() - Constructor for class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
- 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
- AbstractSnapshotIntegTestCase - Class in org.elasticsearch.snapshots
- AbstractSnapshotIntegTestCase() - Constructor for class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- AbstractTermsTestCase - Class in org.elasticsearch.search.aggregations.bucket
- AbstractTermsTestCase() - Constructor for class org.elasticsearch.search.aggregations.bucket.AbstractTermsTestCase
- AbstractThirdPartyRepositoryTestCase - Class in org.elasticsearch.repositories
- AbstractThirdPartyRepositoryTestCase() - Constructor for class org.elasticsearch.repositories.AbstractThirdPartyRepositoryTestCase
- AbstractWireSerializingTestCase<T extends org.elasticsearch.common.io.stream.Writeable> - Class in org.elasticsearch.test
-
Standard test case for testing the wire serialization of subclasses of Writeable.
- AbstractWireSerializingTestCase() - Constructor for class org.elasticsearch.test.AbstractWireSerializingTestCase
- AbstractWireTestCase<T> - Class in org.elasticsearch.test
-
Standard test case for testing wire serialization.
- AbstractWireTestCase() - Constructor for class org.elasticsearch.test.AbstractWireTestCase
- AbstractXContentTestCase<T extends org.elasticsearch.common.xcontent.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.
- acceptChannel(ServerChannelContext) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- acceptException(ServerChannelContext, Exception) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- action - Variable in class org.elasticsearch.test.transport.CapturingTransport.CapturedRequest
- ActionListenerUtils - Class in org.elasticsearch.test
-
Test utilities for working with
ActionListener
s. - ActionListenerUtils() - Constructor for class org.elasticsearch.test.ActionListenerUtils
- ActionTestUtils - Class in org.elasticsearch.action.support
- activeDisruption - Variable in class org.elasticsearch.test.disruption.NetworkDisruption
- activeException(ChannelContext<?>, Exception) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- adaptResponse(Response, IndexShard) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationAction
- addBody(Map<String, Object>) - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
- addBwCFailedSnapshot(String, String, Map<String, Object>) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
-
Adds a snapshot in state
SnapshotState.FAILED
to the given repository. - addCloseListener(ActionListener<Void>) - Method in class org.elasticsearch.test.transport.StubbableTransport.WrappedConnection
- addCloseListener(ActionListener<Void>) - Method in class org.elasticsearch.transport.FakeTcpChannel
- 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
- addDoc(LuceneDocument) - Method in class org.elasticsearch.index.mapper.TestDocumentParserContext
- addEstimateBytesAndMaybeBreak(long, String) - Method in class org.elasticsearch.common.breaker.TestCircuitBreaker
- addEstimateBytesAndMaybeBreak(long, String) - Method in class org.elasticsearch.common.util.MockBigArrays.LimitedBreaker
- 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, 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(TransportAddress, StubbableConnectionManager.GetConnectionBehavior) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
- addGetConnectionBehavior(StubbableConnectionManager.GetConnectionBehavior) - Method in class org.elasticsearch.test.transport.MockTransportService
-
Adds a get connection behavior that is the default get connection behavior.
- addHeaders(Map<String, String>) - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
- additionalNamedContents() - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
-
Any extra named xcontents required not registered by
SearchModule
- additionalNamedWriteables() - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
-
Any extra named writeables required not registered by
SearchModule
- 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.StubbableTransport
- addListener(MockTaskManagerListener) - Method in class org.elasticsearch.test.tasks.MockTaskManager
- addListener(TransportConnectionListener) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
- addMockGeoShapeFieldMapper() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Returns
true
iff this test cluster should use a dummy geo_shape field mapper - addMockHttpTransport() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Returns
true
iff this test cluster should use a dummy http transport - addMockHttpTransport() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
True if a dummy http transport should be used, or false if the real http transport should be used.
- addMockInternalEngine() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Returns
true
if this test cluster can use a mock internal engine. - addMockTransportService() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Iff this returns true mock transport implementations are used for the test runs.
- addMultiField(MockFieldMapper.Builder) - Method in class org.elasticsearch.index.mapper.MockFieldMapper.Builder
- addNodeConnectedBehavior(StubbableConnectionManager.NodeConnectedBehavior) - Method in class org.elasticsearch.test.transport.MockTransportService
-
Adds a node connected behavior that is the default node connected behavior.
- addOnStopListener(Runnable) - Method in class org.elasticsearch.test.transport.MockTransportService
- 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
- addRequestHandlingBehavior(String, StubbableTransport.RequestHandlingBehavior<R>) - Method in class org.elasticsearch.test.transport.MockTransportService
-
Adds a new handling behavior that is used when the defined request is received.
- addRescore(RescoreContext) - Method in class org.elasticsearch.test.TestSearchContext
- addressesFromString(String) - Method in class org.elasticsearch.test.transport.FakeTransport
- addressesFromString(String) - Method in class org.elasticsearch.test.transport.StubbableTransport
- addRetentionLease(String, long, String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
- addRoles(Set<DiscoveryNodeRole>) - Static method in class org.elasticsearch.test.NodeRoles
- addRoles(Settings, Set<DiscoveryNodeRole>) - Static method in class org.elasticsearch.test.NodeRoles
- 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.readSecret(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
- addTextInput(String) - Method in class org.elasticsearch.cli.MockTerminal
-
Adds an an input that will be return from
MockTerminal.readText(String)
. - 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.
- addWithoutBreaking(long) - Method in class org.elasticsearch.common.util.MockBigArrays.LimitedBreaker
- admin() - Static 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.common.util.concurrent.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
- afterClose() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Hook for checking things after all
Aggregator
s have been closed. - afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.cluster.coordination.MockSinglePrioritizingExecutor
- 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
- afterPrimariesBeforeReplicas(RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.DelayedShardsMockGatewayAllocator
- afterPrimariesBeforeReplicas(RoutingAllocation) - Method in class org.elasticsearch.test.gateway.TestGatewayAllocator
- 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)
- aggCardinality(String) - Static method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Request an aggregation that returns the
CardinalityUpperBound
that was passed to its ctor. - 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
- AggregatorTestCase.InternalAggCardinality - Class in org.elasticsearch.search.aggregations
- aliasExists(String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- aliasExists(String, String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- allocateUnassigned(ShardRouting, RoutingAllocation, ExistingShardsAllocator.UnassignedAllocationHandler) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.DelayedShardsMockGatewayAllocator
- allocateUnassigned(ShardRouting, RoutingAllocation, ExistingShardsAllocator.UnassignedAllocationHandler) - Method in class org.elasticsearch.test.gateway.TestGatewayAllocator
- allocationId - Variable in class org.elasticsearch.index.engine.EngineTestCase
- allowedWarnings(String...) - Method in class org.elasticsearch.test.ESTestCase
-
Allow the given warnings, but don't require their presence.
- 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.
- allowsNullValues() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- allowTypesRemovalWarnings() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
-
Deprecated.this method is only required while we deprecate types and can be removed in 8.0
- 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
- anyActionListener() - Static method in class org.elasticsearch.test.ActionListenerUtils
-
Returns a Mockito matcher for any argument that is an
ActionListener
. - anyCheckedFunction() - Static method in class org.elasticsearch.test.CheckedFunctionUtils
-
Returns a Mockito matcher for any argument that is an
CheckedFunction
. - anyCheckedSupplier() - Static method in class org.elasticsearch.test.CheckedFunctionUtils
-
Returns a Mockito matcher for any argument that is an
CheckedSupplier
. - 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
- appendDocs(int) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
- appendEnvironmentSettings() - 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
- apply(Map<String, Object>) - Method in class org.elasticsearch.script.MockDeterministicScript
- applyDisruption(MockTransportService, MockTransportService) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDelay
- 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.
- applyFailedShards(List<FailedShard>, RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.DelayedShardsMockGatewayAllocator
- applyFailedShards(List<FailedShard>, RoutingAllocation) - 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(List<ShardRouting>, RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.DelayedShardsMockGatewayAllocator
- applyStartedShards(List<ShardRouting>, RoutingAllocation) - 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
- asDeterministic(Function<Map<String, Object>, Object>) - Static method in class org.elasticsearch.script.MockDeterministicScript
- asNonDeterministic(Function<Map<String, Object>, Object>) - Static method in class org.elasticsearch.script.MockDeterministicScript
- 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.AbstractMultiClustersTestCase
- 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
- assertAllCancellableTasksAreCancelled(String) - Static method in class org.elasticsearch.test.TaskAssertions
- assertAllEqual(int) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
- assertAllExpectationsMatched() - Method in class org.elasticsearch.test.MockLogAppender
- assertAllPersistedStatesClosed() - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- 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
- assertAllTasksHaveFinished(String) - Static method in class org.elasticsearch.test.TaskAssertions
- assertArrayEquals(StackTraceElement[], StackTraceElement[]) - Static method in class org.elasticsearch.test.ESTestCase
-
Compares two stack traces, ignoring module (which is not yet serialized)
- assertAtMostOneLuceneDocumentPerSequenceNumber(Engine) - Static method in class org.elasticsearch.index.engine.EngineTestCase
- assertAtMostOneLuceneDocumentPerSequenceNumber(IndexSettings, DirectoryReader) - Static method in class org.elasticsearch.index.engine.EngineTestCase
- assertBlobsByPrefix(BlobStoreRepository, BlobPath, String, Map<String, BlobMetadata>) - Static method in class org.elasticsearch.repositories.blobstore.BlobStoreTestUtil
- 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.
- assertCleanupResponse(CleanupRepositoryResponse, long, long) - Method in class org.elasticsearch.repositories.AbstractThirdPartyRepositoryTestCase
- assertConsistency(BlobStoreRepository) - Static method in class org.elasticsearch.repositories.blobstore.BlobStoreTestUtil
-
Assert that there are no unreferenced indices or unreferenced root-level metadata blobs in any repository.
- assertConsistencyAsync(BlobStoreRepository) - Static method in class org.elasticsearch.repositories.blobstore.BlobStoreTestUtil
-
Same as
BlobStoreTestUtil.assertConsistency(BlobStoreRepository)
but async so it can be used in tests that don't allow blocking. - 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.
- assertConsistentHistoryInLuceneIndex() - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- assertCorruptionVisible(BlobStoreRepository, Map<String, Set<String>>) - Static method in class org.elasticsearch.repositories.blobstore.BlobStoreTestUtil
- assertDiffApplication(T, T, Diff<T>) - Static method in class org.elasticsearch.test.DiffableTestUtils
-
Asserts that changes are applied correctly, i.e.
- assertDocCount(String, long) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- assertDocCount(IndexShard, int) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
- assertDocs(IndexShard, String...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
- assertDocValuesDisabled(IndexableField[]) - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- assertDocValuesField(LuceneDocument, String) - Static method in class org.elasticsearch.index.mapper.MapperTestCase
- assertEmptyRepo(Map<String, BytesReference>) - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
- assertEmptyTranslog(String) - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Asserts that we do not retain any extra translog for the given index (i.e., turn off the translog retention)
- assertEqualInstances(T, T) - Method in class org.elasticsearch.test.AbstractBroadcastResponseTestCase
- assertEqualInstances(T, T) - Method in class org.elasticsearch.test.AbstractWireTestCase
-
Assert that two instances are equal.
- 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
- assertExists(GetResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
- assertExistsQuery(MappedFieldType, Query, LuceneDocument) - Method in class org.elasticsearch.index.mapper.MapperTestCase
- assertExistsQuery(MapperService) - Method in class org.elasticsearch.index.mapper.MapperTestCase
- 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
- assertFetch(MapperService, String, Object, String) - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
Assert that fetching a value using
MappedFieldType.valueFetcher(org.elasticsearch.index.query.SearchExecutionContext, java.lang.String)
produces the same value as fetching using doc values. - assertFileCount(Path, int) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- 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
- assertFitsIn(ByteSizeValue, Function<BigArrays, Releasable>) - Static method in class org.elasticsearch.common.util.MockBigArrays
-
Assert that a function returning a
Releasable
runs to completion when allocated a breaker with that breaks when it uses more thanmax
bytes and that the function doesn't leak any BigArrays if it is given a breaker that allows fewer bytes. - 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
- assertFutureThrows(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
- assertFutureThrows(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
- assertFutureThrows(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
- assertFutureThrows(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
- assertFutureThrows(ActionFuture<?>, RestStatus) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
- assertFutureThrows(ActionFuture<?>, RestStatus, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
- assertHasNorms(LuceneDocument, String) - Static method in class org.elasticsearch.index.mapper.MapperTestCase
- 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
- assertIndexDisabled(IndexableField[]) - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- 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
- assertMatched() - Method in class org.elasticsearch.test.MockLogAppender.EventuallySeenEventExpectation
- assertMatched() - Method in interface org.elasticsearch.test.MockLogAppender.LoggingExpectation
- assertMatched() - Method in class org.elasticsearch.test.MockLogAppender.PatternSeenEventExpectation
- 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
- assertMultipleValues(IndexableField[]) - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- assertNoDocValuesField(LuceneDocument, String) - Static method in class org.elasticsearch.index.mapper.MapperTestCase
- assertNoFailureListener(CheckedConsumer<T, Exception>) - Static method in class org.elasticsearch.action.support.ActionTestUtils
- assertNoFailures() - Method in class org.elasticsearch.test.BackgroundIndexer
- assertNoFailures(Map<?, ?>) - Static method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
- 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
- assertNoFieldNamesField(LuceneDocument) - Static method in class org.elasticsearch.index.mapper.MapperTestCase
- assertNoFileBasedRecovery(String, Predicate<String>) - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Asserts that replicas on nodes satisfying the
targetNode
should have perform operation-based recoveries. - assertNoInFlightContext() - Static method in class org.elasticsearch.search.MockSearchService
-
Throw an
AssertionError
if there are still in-flight contexts. - assertNoInFlightDocsInEngine() - Method in class org.elasticsearch.test.InternalTestCluster
- assertNoInFlightDocuments(Engine) - Static method in class org.elasticsearch.index.engine.EngineTestCase
- assertNoPendingHandshakes(Transport) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- assertNoSearchHits(SearchResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
- 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
- assertParseMaximalWarnings() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- assertParseMinimalWarnings() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- assertReduced(T, List<T>) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
- assertReduced(T, List<T>) - Method in class org.elasticsearch.test.InternalAggregationTestCase
- assertRepoConsistency() - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- assertRequestBuilderThrows(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
- assertRequestBuilderThrows(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
- assertRequestBuilderThrows(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
- assertRequestBuilderThrows(ActionRequestBuilder<?, ?>, RestStatus) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
- assertRequestBuilderThrows(ActionRequestBuilder<?, ?>, RestStatus, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
- assertRequestsFinished() - Method in class org.elasticsearch.test.InternalTestCluster
- 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.
- assertSearchable(MappedFieldType) - Method in class org.elasticsearch.index.mapper.MapperTestCase
- 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
-
Assert that instances copied at a particular version are equal.
- 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.
- assertSnapshotListSorted(List<SnapshotInfo>, GetSnapshotsRequest.SortBy, SortOrder) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- 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
- assertStateEquals(ClusterState, ClusterState) - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- assertSuccessful(Logger, ActionFuture<CreateSnapshotResponse>) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- assertSuccessful(ActionFuture<CreateSnapshotResponse>) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- assertSuccessfulRestore(RestoreSnapshotRequestBuilder) - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- assertSuccessfulSnapshot(CreateSnapshotRequestBuilder) - 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
- assertTotalHits(int, Map<?, ?>) - Method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
- assertToXContentAfterSerialization(AB, AB) - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
-
Make sure serialization preserves toXContent.
- assertToXContentEquivalence() - Method in class org.elasticsearch.test.AbstractBroadcastResponseTestCase
- 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 theXContent
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
BytesReference
s created throughToXContent.toXContent(XContentBuilder, ToXContent.Params)
hold the same content. - assertValidBlockId(String) - Static method in class org.elasticsearch.repositories.azure.AzureFixtureHelper
- 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(boolean, String...) - Method in class org.elasticsearch.test.ESTestCase
- assertWarnings(String...) - Method in class org.elasticsearch.test.ESTestCase
- asyncRecoverReplica(IndexShard, BiFunction<IndexShard, DiscoveryNode, RecoveryTarget>) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
- AsyncRecoveryTarget - Class in org.elasticsearch.indices.recovery
-
Wraps a
RecoveryTarget
to make all remote calls to be executed asynchronously using the providedexecutor
. - AsyncRecoveryTarget(RecoveryTargetHandler, Executor) - Constructor for class org.elasticsearch.indices.recovery.AsyncRecoveryTarget
- autoManageMasterNodes() - Element in annotation interface org.elasticsearch.test.ESIntegTestCase.ClusterScope
-
Indicates whether the cluster automatically manages cluster bootstrapping and the removal of any master-eligible nodes as well as
ElectMasterService.DISCOVERY_ZEN_MINIMUM_MASTER_NODES_SETTING
if running the pre-7.0 cluster coordination implementation. - available() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase.ZeroInputStream
- awaitClusterState(Predicate<ClusterState>) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- awaitClusterState(Logger, String, Predicate<ClusterState>) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- awaitClusterState(Logger, Predicate<ClusterState>) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- awaitIdle() - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- 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 - awaitMasterFinishRepoOperations() - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- awaitNDeletionsInProgress(int) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- awaitNoMoreRunningOperations() - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- awaitNoMoreRunningOperations(String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- awaitNumberOfSnapshotsInProgress(int) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- awaitNumberOfSnapshotsInProgress(Logger, int) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- awaitStopped() - Method in class org.elasticsearch.test.BackgroundIndexer
- awaitTaskWithPrefix(String) - Static method in class org.elasticsearch.test.TaskAssertions
- awaitTermination(long, TimeUnit) - Method in class org.elasticsearch.cluster.coordination.MockSinglePrioritizingExecutor
- AzureFixtureHelper - Class in org.elasticsearch.repositories.azure
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, 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.
- backingIndexEqualTo(String, int) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- backingIndexPattern(String, long) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- BaseAggregationTestCase<AB extends org.elasticsearch.search.aggregations.AbstractAggregationBuilder<AB>> - Class in org.elasticsearch.search.aggregations
- BaseAggregationTestCase() - Constructor for class org.elasticsearch.search.aggregations.BaseAggregationTestCase
- BasePipelineAggregationTestCase<AF extends org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder<AF>> - Class in org.elasticsearch.search.aggregations
- BasePipelineAggregationTestCase() - Constructor for class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
- basicAuthHeaderValue(String, SecureString) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
-
Construct a Basic auth header
- before() - Method in class org.elasticsearch.test.ESTestCase
- beforeAllocation(RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.DelayedShardsMockGatewayAllocator
- beforeAllocation(RoutingAllocation) - Method in class org.elasticsearch.test.gateway.TestGatewayAllocator
- 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(ShardRouting, 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.
- BETA - Enum constant in enum class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Stability
- between(int, int) - Static method in class org.elasticsearch.test.ESTestCase
-
An alias for
ESTestCase.randomIntBetween(int, int)
. - bigarrays - Variable in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
- BINARY_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
- BinaryDocValues - Enum constant in enum class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
- bind(String, InetSocketAddress) - Method in class org.elasticsearch.transport.nio.MockNioTransport
- bitsetFilterCache() - Method in class org.elasticsearch.test.TestSearchContext
- BLACK_HOLE - Enum constant in enum class org.elasticsearch.test.disruption.DisruptableMockTransport.ConnectionStatus
-
Simulate a blackhole partition: inbound and outbound messages are silently discarded.
- BLACK_HOLE_REQUESTS_ONLY - Enum constant in enum class org.elasticsearch.test.disruption.DisruptableMockTransport.ConnectionStatus
-
Simulate an asymmetric partition: outbound messages are silently discarded, but inbound messages are delivered normally.
- blobContainer(BlobPath) - Method in class org.elasticsearch.snapshots.mockstore.BlobStoreWrapper
- blobContainer(BlobPath) - Method in class org.elasticsearch.snapshots.mockstore.MockRepository.MockBlobStore
- blobLengthFromContentLength(long) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- blobs() - Method in interface org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase.BlobStoreHttpHandler
- BlobStoreTestUtil - Class in org.elasticsearch.repositories.blobstore
- BlobStoreTestUtil() - Constructor for class org.elasticsearch.repositories.blobstore.BlobStoreTestUtil
- BlobStoreWrapper - Class in org.elasticsearch.snapshots.mockstore
- BlobStoreWrapper(BlobStore) - Constructor for class org.elasticsearch.snapshots.mockstore.BlobStoreWrapper
- blockAllDataNodes(String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- blockAndFailDataNode(String, String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- blockAndFailOnDataFiles() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- BlockClusterStateProcessing - Class in org.elasticsearch.test.disruption
- BlockClusterStateProcessing(String, Random) - Constructor for class org.elasticsearch.test.disruption.BlockClusterStateProcessing
- blockDataNode(String, String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- blocked() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- blockMasterFromDeletingIndexNFile(String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- blockMasterFromFinalizingSnapshotOnIndexFile(String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- blockMasterFromFinalizingSnapshotOnSnapFile(String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- blockMasterOnShardLevelSnapshotFile(String, String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- blockMasterOnWriteIndexFile(String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- BlockMasterServiceOnMaster - Class in org.elasticsearch.test.disruption
- BlockMasterServiceOnMaster(Random) - Constructor for class org.elasticsearch.test.disruption.BlockMasterServiceOnMaster
- blockNodeOnAnyFiles(String, String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- blockNodeWithIndex(String, String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- blockOnDataFiles() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- BOOLEAN_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
- 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.MockHttpTransport
- boundAddress() - Method in class org.elasticsearch.test.transport.FakeTransport
- 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(ContentPath) - Method in class org.elasticsearch.index.mapper.MockFieldMapper.Builder
- buildClient(Settings, HttpHost[]) - Method in class org.elasticsearch.test.rest.ESRestTestCase
- buildEnvSettings(Settings) - Method in class org.elasticsearch.test.ESTestCase
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.MockFieldMapper.Builder
- 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
- buildMockFieldMapper(MappedFieldType) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Build a
FieldMapper
to create theMappingLookup
used for the aggs. - 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, Settings) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- buildService(String, Version, 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
- bytesContentType() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
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(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.TestAllocateDecision
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.TestAllocateDecision
- cancel(CancellableTask, String) - Static method in class org.elasticsearch.tasks.TaskCancelHelper
- canFailRequest(HttpExchange) - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase.ErroneousHttpHandler
- canUpdateInPlace(Settings, Set<String>) - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- 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
- cardinality() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase.InternalAggCardinality
- categoryClass() - Method in class org.elasticsearch.test.AbstractNamedWriteableTestCase
-
The type of
NamedWriteable
to read. - categoryClass() - Method in class org.elasticsearch.test.InternalAggregationTestCase
- CERTIFICATE_AUTHORITIES - Static variable in class org.elasticsearch.test.rest.ESRestTestCase
- 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
- checkCancelled(SearchShardTask) - Method in class org.elasticsearch.search.MockSearchService
- CheckedFunctionUtils - Class in org.elasticsearch.test
-
Test utilities for working with
CheckedFunction
s andCheckedSupplier
s. - CheckedFunctionUtils() - Constructor for class org.elasticsearch.test.CheckedFunctionUtils
- 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.MockFSDirectoryFactory
- checkIndexFailures - Static variable in class org.elasticsearch.test.ESTestCase
-
MockFSDirectoryService sets this:
- checkNoSoftDeletesLoaded(ReadOnlyEngine) - Static method in class org.elasticsearch.index.engine.EngineTestCase
- checkStaticState() - Static method in class org.elasticsearch.test.ESTestCase
- CHUNK_SIZE_SETTING - Static variable in class org.elasticsearch.node.RecoverySettingsChunkSizePlugin
-
The chunk size.
- ClasspathUtils - Class in org.elasticsearch.test
- ClasspathUtils() - Constructor for class org.elasticsearch.test.ClasspathUtils
- cleanFiles(int, long, Store.MetadataSnapshot, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.AsyncRecoveryTarget
- cleanUpCluster() - Method in class org.elasticsearch.test.ESIntegTestCase
- cleanUpCluster() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Clean up after the test case.
- cleanupReleasables() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- 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
- clearAdditionalRoles() - Static method in class org.elasticsearch.test.ESTestCase
- 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.OpenConnectionBehavior
- clearCallback() - Method in interface org.elasticsearch.test.transport.StubbableTransport.RequestHandlingBehavior
- 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.InternalTestCluster
- clearDisruptionScheme(boolean) - Method in class org.elasticsearch.test.InternalTestCluster
- clearInboundRules() - Method in class org.elasticsearch.test.transport.MockTransportService
-
Clears all the inbound rules.
- clearOutboundRules(TransportAddress) - Method in class org.elasticsearch.test.transport.MockTransportService
-
Clears the outbound rules associated with the provided delegate address.
- clearOutboundRules(TransportService) - Method in class org.elasticsearch.test.transport.MockTransportService
-
Clears the outbound rules associated with the provided delegate service.
- clearScroll(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Clears the given scroll Ids
- client() - Method in class org.elasticsearch.test.AbstractMultiClustersTestCase
- 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) - Method in class org.elasticsearch.test.AbstractMultiClustersTestCase
- 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_CERT_PATH - Static variable in class org.elasticsearch.test.rest.ESRestTestCase
- CLIENT_KEY_PASSWORD - Static variable in class org.elasticsearch.test.rest.ESRestTestCase
- CLIENT_KEY_PATH - Static variable in class org.elasticsearch.test.rest.ESRestTestCase
- 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, Version, String, 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 Class in org.elasticsearch.test.rest.yaml.restspec
- ClientYamlSuiteRestApi.Path - Class in org.elasticsearch.test.rest.yaml.restspec
- ClientYamlSuiteRestApi.Stability - Enum Class in org.elasticsearch.test.rest.yaml.restspec
- ClientYamlSuiteRestApi.Visibility - Enum Class in org.elasticsearch.test.rest.yaml.restspec
- ClientYamlSuiteRestApiParser - Class in org.elasticsearch.test.rest.yaml.restspec
-
Parser for a
ClientYamlSuiteRestApi
. - ClientYamlSuiteRestApiParser() - Constructor for class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApiParser
- 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
ClientYamlTestSection
s 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.
- ClientYamlTestSection(XContentLocation, String, SkipSection, List<ExecutableSection>) - Constructor for class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSection
- ClientYamlTestSuite - Class in org.elasticsearch.test.rest.yaml.section
-
Holds a REST test suite loaded from a specific yaml file.
- ClientYamlTestSuite(String, String, SetupSection, TeardownSection, List<ClientYamlTestSection>) - Constructor for class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
- clone() - Method in class org.elasticsearch.cluster.coordination.LinearizabilityChecker.History
- clone() - Method in class org.elasticsearch.common.settings.MockSecureSettings
- cloneShardSnapshot(SnapshotId, SnapshotId, RepositoryShardId, ShardGeneration, ActionListener<ShardSnapshotResult>) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- close() - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase.Cluster
- 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.repositories.blobstore.AbstractBlobContainerRetriesTestCase.ZeroInputStream
- close() - Method in class org.elasticsearch.snapshots.mockstore.BlobStoreWrapper
- close() - Method in class org.elasticsearch.test.BackgroundIndexer
- close() - Method in class org.elasticsearch.test.client.NoOpClient
- close() - Method in class org.elasticsearch.test.client.NoOpNodeClient
- 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.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(T) - Method in class org.elasticsearch.transport.LeakTracker.Leak
-
Stop tracking the object that this leak was created for.
- closeClient() - Static method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
- closeClients() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- closeException(ChannelContext<?>, Exception) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- closeIndex(String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- closeInternal() - Method in class org.elasticsearch.test.DummyShardLock
- closeNoBlock() - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
- closeNodeEnvironmentsAfterEachTest() - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- 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
- CloseToAssertion - Class in org.elasticsearch.test.rest.yaml.section
-
Represents a close_to assert section: - close_to: { get.fields._routing: { value: 5.1, error: 0.00001 } }
- CloseToAssertion(XContentLocation, String, Double, Double) - Constructor for class org.elasticsearch.test.rest.yaml.section.CloseToAssertion
- 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
- cluster(String) - Method in class org.elasticsearch.test.AbstractMultiClustersTestCase
- Cluster(int, boolean, Settings) - Constructor for class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase.Cluster
- clusterAdmin() - Static method in class org.elasticsearch.test.ESIntegTestCase
-
Returns a random cluster admin client.
- ClusterInfoServiceUtils - Class in org.elasticsearch.cluster
- ClusterInfoServiceUtils() - Constructor for class org.elasticsearch.cluster.ClusterInfoServiceUtils
- clusterName() - Method in class org.elasticsearch.common.logging.JsonLogLine
- clusterName(String, long) - Static method in class org.elasticsearch.test.InternalTestCluster
- clusters() - Method in class org.elasticsearch.test.AbstractMultiClustersTestCase
- 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
- clusterSettingsA - Variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- clusterState(long, long, DiscoveryNode, CoordinationMetadata.VotingConfiguration, CoordinationMetadata.VotingConfiguration, long) - Static method in class org.elasticsearch.cluster.coordination.CoordinationStateTestCluster
- clusterState(long, long, DiscoveryNodes, CoordinationMetadata.VotingConfiguration, CoordinationMetadata.VotingConfiguration, long) - Static method in class org.elasticsearch.cluster.coordination.CoordinationStateTestCluster
- ClusterStateCreationUtils - Class in org.elasticsearch.action.support.replication
-
Helper methods for generating cluster states
- ClusterStateCreationUtils() - Constructor for class org.elasticsearch.action.support.replication.ClusterStateCreationUtils
- clusterUuid() - Method in class org.elasticsearch.common.logging.JsonLogLine
- 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
- CommandTestCase - Class in org.elasticsearch.cli
-
A base test case for cli tools.
- CommandTestCase() - Constructor for class org.elasticsearch.cli.CommandTestCase
- compare(String, boolean, 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
- compileScript(Script, ScriptContext<T>) - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- compileScript(Script, ScriptContext<T>) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- complete(Function<Object, Object>) - Method in class org.elasticsearch.cluster.coordination.LinearizabilityChecker.History
-
Completes the history with response events for invocations that are missing corresponding responses
- component() - Method in class org.elasticsearch.common.logging.JsonLogLine
- concurrentlyApplyOps(List<Engine.Operation>, InternalEngine) - Static method in class org.elasticsearch.index.engine.EngineTestCase
- config(EngineConfig, Store, Path) - 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
- configureAndConnectsToRemoteClusters() - Method in class org.elasticsearch.test.AbstractMultiClustersTestCase
- configureClient(RestClientBuilder, Settings) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- configureNodeAndClusterIdStateListener(ClusterService) - Method in class org.elasticsearch.node.MockNode
- configureRemoteCluster(String, Collection<String>) - Method in class org.elasticsearch.test.AbstractMultiClustersTestCase
- CONNECTED - Enum constant in enum class org.elasticsearch.test.disruption.DisruptableMockTransport.ConnectionStatus
-
No disruption: deliver messages normally.
- connectedNodes(ConnectionManager, DiscoveryNode) - Method in interface org.elasticsearch.test.transport.StubbableConnectionManager.NodeConnectedBehavior
- connectException(SocketChannelContext, Exception) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- connectionManager() - Method in class org.elasticsearch.test.transport.MockTransportService
- connectToNode(DiscoveryNode, ConnectionProfile, ConnectionManager.ConnectionValidator, ActionListener<Void>) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
- contains(Version) - Method in class org.elasticsearch.test.rest.yaml.section.VersionRange
- 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(int) - Method in class org.elasticsearch.test.BackgroundIndexer
-
Continue indexing after it has paused.
- controller() - Method in class org.elasticsearch.test.rest.RestActionTestCase
-
A test
RestController
. - convertToEngineOp(Translog.Operation, Engine.Operation.Origin) - Method in class org.elasticsearch.index.engine.TranslogHandler
- convertToMap(ToXContent) - Static method in class org.elasticsearch.test.XContentTestUtils
- convertToXContent(Map<String, ?>, XContentType) - Static method in class org.elasticsearch.test.XContentTestUtils
- CoordinationStateTestCluster - Class in org.elasticsearch.cluster.coordination
- CoordinationStateTestCluster(List<DiscoveryNode>, ElectionStrategy) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationStateTestCluster
- 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
- copyEvents() - Method in class org.elasticsearch.cluster.coordination.LinearizabilityChecker.History
-
Copy the list of events for external use.
- 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.AbstractNamedWriteableTestCase
- copyInstance(T, Version) - Method in class org.elasticsearch.test.AbstractWireSerializingTestCase
-
Copy the
Writeable
by round tripping it through StreamInput and StreamOutput. - copyInstance(T, Version) - Method in class org.elasticsearch.test.AbstractWireTestCase
-
Copy the instance as by reading and writing using the code specific to the provided version.
- copyNamedWriteable(T, NamedWriteableRegistry, Class<T>) - Static method in class org.elasticsearch.test.ESTestCase
-
Create a copy of an original
NamedWriteable
object by running it through aBytesStreamOutput
and reading it in again using a providedWriteable.Reader
. - copyNamedWriteable(T, NamedWriteableRegistry, Class<T>, Version) - Static method in class org.elasticsearch.test.ESTestCase
-
Same as
ESTestCase.copyNamedWriteable(NamedWriteable, NamedWriteableRegistry, Class)
but also allows to provide aVersion
argument which will be used to write and read back the object. - copyTo(String) - Method in class org.elasticsearch.index.mapper.MockFieldMapper.Builder
- 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 aBytesStreamOutput
and reading it in again using a providedWriteable.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 aVersion
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.MockFSDirectoryFactory.ElasticsearchMockDirectoryWrapper
- CRASH_INDEX_SETTING - Static variable in class org.elasticsearch.test.store.MockFSDirectoryFactory
- create(Map<String, Processor.Factory>, String, String, Map<String, Object>) - Method in class org.elasticsearch.ingest.TestProcessor.Factory
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.MyFilterTokenFilterFactory
- createAggBuilderForTypeTest(MappedFieldType, String) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
This method is invoked each time a field type is tested in
AggregatorTestCase.testSupportedFieldTypes()
. - createAggregationContext(IndexSearcher, Query, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Create a AggregationContext for testing an
Aggregator
. - createAggregationContext(IndexSearcher, IndexSettings, Query, CircuitBreakerService, long, int, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Create a AggregationContext for testing an
Aggregator
. - createAggregator(AggregationBuilder, IndexSearcher, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- createAggregator(AggregationBuilder, AggregationContext) - 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
- createAllocationService(Settings, GatewayAllocator, SnapshotsInfoService) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
- createAllocationService(Settings, SnapshotsInfoService) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
- createBackingIndex(String, int) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- createBackingIndex(String, int, long) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- createBigArrays(PageCacheRecycler, CircuitBreakerService) - Method in class org.elasticsearch.node.MockNode
- createBlobContainer(Integer, TimeValue, Boolean, ByteSizeValue) - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- createBlobStore() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- 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
- createConnection(DiscoveryNode) - Method in class org.elasticsearch.test.transport.MockTransport
- createContext(ReaderContext, ShardSearchRequest, SearchShardTask, boolean) - Method in class org.elasticsearch.search.MockSearchService
- createDanglingIndex(BlobStoreRepository, String, Set<String>) - Static method in class org.elasticsearch.repositories.blobstore.BlobStoreTestUtil
- createDefaultIndexAnalyzers() - Method in class org.elasticsearch.test.ESTestCase
-
Creates an IndexAnalyzers with a single default analyzer
- createDiscoveryNode(int, boolean) - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- createDocumentMapper(String, String) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createDocumentMapper(XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createDocumentMapper(Version, String) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createDocumentMapper(Version, XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createEngine(EngineConfig) - Method in class org.elasticsearch.index.engine.EngineTestCase
- createEngine(EngineConfig, int) - Static 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
- createErroneousHttpHandler(HttpHandler) - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
- createExecutor() - Static method in class org.elasticsearch.common.lucene.store.ESIndexInputTestCase
- createFilterScript(Map<String, Object>, SearchLookup) - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
- createFirstBackingIndex(String) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- createFirstBackingIndex(String, long) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- 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
- createFullSnapshot(String, String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- 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
- createHttpHandlers() - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
- 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.
- createIndexAnalyzers() - Static method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createIndexAnalyzers(IndexSettings) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createIndexSettings() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- createIndexSettings(Version, Settings) - Static method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createIndexWithContent(String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- createIndexWithContent(String, Settings) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- createIndexWithRandomDocs(String, int) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- createInternalEngine(EngineTestCase.IndexWriterFactory, BiFunction<Long, Long, LocalCheckpointTracker>, ToLongBiFunction<Engine, Engine.Operation>, EngineConfig) - Static method in class org.elasticsearch.index.engine.EngineTestCase
- createIntervalFilterScript() - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
- createJsonMapView(InputStream) - Static method in class org.elasticsearch.test.XContentTestUtils
- createMapperService(String) - Static method in class org.elasticsearch.index.engine.EngineTestCase
- createMapperService(String, String) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createMapperService(BooleanSupplier, XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createMapperService(Settings, String) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createMapperService(Settings, XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createMapperService(XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createMapperService(Version, Settings, BooleanSupplier) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createMapperService(Version, Settings, BooleanSupplier, XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
-
Create a
MapperService
like we would for an index. - createMapperService(Version, XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createMapping(String, String, String) - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- createMapping(String, String, String, Settings) - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- createMasterService(ThreadPool, ClusterState) - Static method in class org.elasticsearch.test.ClusterServiceUtils
- createMasterService(ThreadPool, DiscoveryNode) - Static method in class org.elasticsearch.test.ClusterServiceUtils
- 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) - Static method in class org.elasticsearch.test.transport.MockTransportService
- createNewService(Settings, Version, ThreadPool, ClusterSettings) - Static method in class org.elasticsearch.test.transport.MockTransportService
- createNoOpNodeConnectionsService() - Static method in class org.elasticsearch.test.ClusterServiceUtils
- createNSnapshots(String, int) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- createNSnapshots(Logger, String, int) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- 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(NamedXContentRegistry, XContent, BytesReference) - Method in class org.elasticsearch.test.ESTestCase
-
Create a new
XContentParser
. - 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
. - createRepository(String) - Method in class org.elasticsearch.repositories.AbstractThirdPartyRepositoryTestCase
- createRepository(String) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- createRepository(String, boolean) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- createRepository(String, String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- createRepository(String, String, Path) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- createRepository(String, String, Settings.Builder) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- createRepository(String, String, Settings.Builder, boolean) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- createRepository(String, Settings, boolean) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- createRepository(Logger, String, String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- createRepository(Logger, String, String, Settings.Builder, boolean) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- createRepositoryNoVerify(String, String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- createRestClient() - Static method in class org.elasticsearch.test.ESIntegTestCase
- createRestClient(List<NodeInfo>, RestClientBuilder.HttpClientConfigCallback, String) - Static method in class org.elasticsearch.test.ESIntegTestCase
- createRestClient(RestClientBuilder.HttpClientConfigCallback, String) - Static method in class org.elasticsearch.test.ESIntegTestCase
- createSearchContext(IndexService) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
Create a new search context.
- createSearchExecutionContext() - Static method in class org.elasticsearch.test.AbstractBuilderTestCase
- createSearchExecutionContext(IndexSearcher) - Static method in class org.elasticsearch.test.AbstractBuilderTestCase
- createSearchExecutionContext(MapperService) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- createShardContextWithNoType() - 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
- createSnapshot(String, String, boolean) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- createSnapshot(String, String, List<String>) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- createSnapshot(RestClient, String, String, boolean) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- 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
- createSubAggregations() - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
- createTaskManager(Settings, ThreadPool, Set<String>) - Method in class org.elasticsearch.test.transport.MockTransportService
- createTestAggregatorBuilder() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
- createTestAggregatorFactory() - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
- 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.AbstractBroadcastResponseTestCase
- createTestInstance() - Method in class org.elasticsearch.test.AbstractSchemaValidationTestCase
-
Creates a random instance to use in the schema tests.
- 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(int, int, int, List<DefaultShardOperationFailedException>) - Method in class org.elasticsearch.test.AbstractBroadcastResponseTestCase
- createTestInstance(String, long, InternalAggregations, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
- createTestInstance(String, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
- createTestInstance(String, Map<String, Object>) - Method in class org.elasticsearch.test.InternalAggregationTestCase
- createTestInstance(String, Map<String, Object>) - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
- createTestInstance(String, Map<String, Object>, InternalAggregations) - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
- createTestInstanceForXContent() - Method in class org.elasticsearch.test.InternalAggregationTestCase
- createTestMetadata() - Method in class org.elasticsearch.test.InternalAggregationTestCase
- createTestQueryBuilder() - Method in class org.elasticsearch.test.AbstractQueryTestCase
- createTestQueryBuilder(boolean, boolean) - Method in class org.elasticsearch.test.AbstractQueryTestCase
- createTestWarmer(IndexSettings) - Static method in class org.elasticsearch.index.shard.IndexShardTestCase
- createThreadPoolExecutor() - Method in class org.elasticsearch.cluster.service.FakeThreadPoolMasterService
- createTimestampField(String) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- 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
- createTransportService(Settings, ThreadPool, TransportInterceptor, Function<BoundTransportAddress, DiscoveryNode>, ClusterSettings, Set<String>) - Method in class org.elasticsearch.test.disruption.DisruptableMockTransport
- createTransportService(Settings, ThreadPool, TransportInterceptor, Function<BoundTransportAddress, DiscoveryNode>, ClusterSettings, Set<String>) - Method in class org.elasticsearch.test.transport.MockTransport
- 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, 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.
- credentials() - Method in class org.elasticsearch.repositories.AbstractThirdPartyRepositoryTestCase
- 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
- dataNode() - Static method in class org.elasticsearch.test.NodeRoles
- dataNode(Settings) - Static method in class org.elasticsearch.test.NodeRoles
- 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.
- dataOnlyNode() - Static method in class org.elasticsearch.test.NodeRoles
- dataOnlyNode(Settings) - Static method in class org.elasticsearch.test.NodeRoles
- dataPathSettings(String) - Method in class org.elasticsearch.test.InternalTestCluster
- DataStreamTestHelper - Class in org.elasticsearch.cluster.metadata
- DataStreamTestHelper() - Constructor for class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- DATE_ALIAS_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
- DATE_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
- DATE_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
- DATE_NANOS_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
- DATE_RANGE_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
- dateField(String, DateFieldMapper.Resolution) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Make a DateFieldMapper.DateFieldType for a
date
. - debugTestCase(AggregationBuilder, Query, IndexSearcher, TriConsumer<R, Class<? extends Aggregator>, Map<String, Map<String, Object>>>, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Execute and aggregation and collect its
debug
information. - debugTestCase(AggregationBuilder, Query, CheckedConsumer<RandomIndexWriter, IOException>, TriConsumer<R, Class<? extends Aggregator>, Map<String, Map<String, Object>>>, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Execute and aggregation and collect its
debug
information. - dedupAfterFetch() - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
A few field types (e.g.
- DEFAULT_CLUSTER_STATE_UPDATE_DELAY - Static variable in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- 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_ELECTION_DELAY - Static variable in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- DEFAULT_EXECUTABLE_CONTEXTS - Static variable in interface org.elasticsearch.test.rest.yaml.section.ExecutableSection
-
Default list of
ExecutableSection
s 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
- DEFAULT_NAMED_WRITABLE_REGISTRY - Static variable in class org.elasticsearch.test.ESTestCase
- DEFAULT_STABILISATION_TIME - Static variable in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- DEFAULT_TEST_WORKER_ID - Static variable in class org.elasticsearch.test.ESTestCase
- defaultGeoFieldName - Static variable in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- defaultIndexName - Static variable in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- defaultInt(Setting<Integer>) - Static method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- defaultMillis(Setting<TimeValue>) - Static method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- defaultSettings - Variable in class org.elasticsearch.index.engine.EngineTestCase
- defaultType - Static variable in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- DelayedShardsMockGatewayAllocator() - Constructor for class org.elasticsearch.cluster.ESAllocationTestCase.DelayedShardsMockGatewayAllocator
- delegate() - Method in class org.elasticsearch.snapshots.mockstore.BlobStoreWrapper
- delete(DeleteRequest) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
- deleteAllNodeShutdownMetadata() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
If any nodes are registered for shutdown, removes their metadata.
- deleteDoc(IndexShard, String, String) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
- deleteIndex(String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- deleteIndex(RestClient, String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- deleteRepository(String) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- deleteRepository(String) - Method in class org.elasticsearch.test.rest.ESRestTestCase
- deleteSnapshot(String, String, boolean) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- deleteSnapshot(RestClient, String, String, boolean) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- deleteSnapshots(Collection<SnapshotId>, long, Version, ActionListener<RepositoryData>) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- describeMismatchSafely(ImmutableOpenMap<String, ?>, Description) - Method in class org.elasticsearch.test.hamcrest.CollectionMatchers.ImmutableOpenMapHasAllKeysMatcher
- describeMismatchSafely(ImmutableOpenMap<String, ?>, 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
- destroyExecutor() - Static method in class org.elasticsearch.common.lucene.store.ESIndexInputTestCase
- DeterministicTaskQueue - Class in org.elasticsearch.common.util.concurrent
-
Permits the testing of async processes by interleaving all the tasks on a single thread in a pseudo-random (deterministic) fashion, letting each task spawn future tasks, and simulating the passage of time.
- DeterministicTaskQueue() - Constructor for class org.elasticsearch.common.util.concurrent.DeterministicTaskQueue
- DeterministicTaskQueue(Settings, Random) - Constructor for class org.elasticsearch.common.util.concurrent.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
- disableRepoConsistencyCheck(String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- DISCONNECT - Static variable in class org.elasticsearch.test.disruption.NetworkDisruption
-
Simulates a network disconnect.
- DISCONNECTED - Enum constant in enum class org.elasticsearch.test.disruption.DisruptableMockTransport.ConnectionStatus
-
Simulate disconnection: inbound and outbound messages throw a
ConnectTransportException
. - disconnectFromNode(DiscoveryNode) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
- disconnectFromRemoteClusters() - Method in class org.elasticsearch.test.AbstractMultiClustersTestCase
- DiskUsageIntegTestCase - Class in org.elasticsearch.cluster
-
An integration test case that allows mocking the disk usage per node.
- DiskUsageIntegTestCase() - Constructor for class org.elasticsearch.cluster.DiskUsageIntegTestCase
- DiskUsageIntegTestCase.TestFileStore - Class in org.elasticsearch.cluster
- dispatchBadRequest(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
- DisruptableMockTransport - Class in org.elasticsearch.test.disruption
- DisruptableMockTransport(DiscoveryNode, Logger, DeterministicTaskQueue) - Constructor for class org.elasticsearch.test.disruption.DisruptableMockTransport
- DisruptableMockTransport.ConnectionStatus - Enum Class in org.elasticsearch.test.disruption
-
Response type from
DisruptableMockTransport.getConnectionStatus(DiscoveryNode)
indicating whether, and how, messages should be disrupted on this transport. - 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.CloseToAssertion
- 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, SearchExecutionContext) - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Checks the result of
QueryBuilder.toQuery(SearchExecutionContext)
given the originalQueryBuilder
andSearchExecutionContext
. - doAssertReducedMultiBucketConsumer(Aggregation, MultiBucketConsumerService.MultiBucketConsumer) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- doAssertReducedMultiBucketConsumer(Aggregation, MultiBucketConsumerService.MultiBucketConsumer) - Method in class org.elasticsearch.test.InternalAggregationTestCase
- doAssertReducedMultiBucketConsumer(Aggregation, MultiBucketConsumerService.MultiBucketConsumer) - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
- doc() - Method in class org.elasticsearch.index.mapper.TestDocumentParserContext
- DocIdSeqNoAndSource - Class in org.elasticsearch.index.engine
-
A tuple of document id, sequence number, primary term, source and version of a document
- DocIdSeqNoAndSource(String, BytesRef, long, long, long) - Constructor for class org.elasticsearch.index.engine.DocIdSeqNoAndSource
- docIdsToLoad() - Method in class org.elasticsearch.test.TestSearchContext
- docIdsToLoad(int[], int) - 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.MockHttpTransport
- doClose() - Method in class org.elasticsearch.test.transport.FakeTransport
- doClose() - Method in class org.elasticsearch.test.transport.MockTransportService
- doCreateTestQueryBuilder() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Create the query that is being tested
- docs() - Method in class org.elasticsearch.index.mapper.TestDocumentParserContext
- DocsAndPositionsEnum - Enum constant in enum class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
- DocsEnum - Enum constant in enum class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
- docValuesContext() - Method in class org.elasticsearch.test.TestSearchContext
- docValuesContext(FetchDocValuesContext) - Method in class org.elasticsearch.test.TestSearchContext
- doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.test.client.NoOpClient
- doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.test.client.NoOpNodeClient
- doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.test.rest.RestActionTestCase.VerifyingClient
- doGetSequentialStoredFieldsReader(StoredFieldsReader) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
- 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.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|warnings_regex: - 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.test.MockHttpTransport
- doStart() - Method in class org.elasticsearch.test.transport.FakeTransport
- doStart() - Method in class org.elasticsearch.transport.nio.MockNioTransport
- doStop() - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- doStop() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- doStop() - Method in class org.elasticsearch.test.MockHttpTransport
- doStop() - Method in class org.elasticsearch.test.transport.FakeTransport
- doStop() - Method in class org.elasticsearch.test.transport.MockTransportService
- 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.search.aggregations.BasePipelineAggregationTestCase
- DOUBLE_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
- doubleField(String) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Make a NumberFieldMapper.NumberFieldType for a
double
. - doubleValue() - Method in class org.elasticsearch.script.ScoreAccessor
- downloadStorageEndpoint(BlobContainer, String) - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- doWrapDirectoryReader(DirectoryReader) - Method in class org.elasticsearch.index.engine.EngineTestCase.MatchingDirectoryReader
- doWrapDirectoryReader(DirectoryReader) - Method in class org.elasticsearch.test.FieldMaskingReader
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase.InternalAggCardinality
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase.InternalAggCardinality
- drainInputStream(InputStream) - Static method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
-
Consumes and closes the given
InputStream
- DUMMY_UPDATABLE_SETTING_NAME - Static variable in class org.elasticsearch.snapshots.mockstore.MockRepository
-
Setting name for a setting that can be updated dynamically to test
MockRepository.canUpdateInPlace(Settings, Set)
. - DummyShardLock - Class in org.elasticsearch.test
- DummyShardLock(ShardId) - Constructor for class org.elasticsearch.test.DummyShardLock
- dynamicMapping(Mapping) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
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.MockFSDirectoryFactory.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
- emptyReduceContextBuilder() - Static method in class org.elasticsearch.test.InternalAggregationTestCase
-
Builds an
InternalAggregation.ReduceContextBuilder
that is valid but empty. - emptyReduceContextBuilder(PipelineAggregator.PipelineTree) - Static method in class org.elasticsearch.test.InternalAggregationTestCase
-
Builds an
InternalAggregation.ReduceContextBuilder
that is valid and nearly empty except that it containPipelineAggregator
s. - EmptySystemIndices - Class in org.elasticsearch.indices
-
A test class which contains a singleton instance of the
SystemIndices
class that has been created with no non-standard system indices defined except for those defined within the class itself. - 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.MatchingDirectoryReader - Class in org.elasticsearch.index.engine
- EngineTestCase.PrimaryTermSupplier - Class in org.elasticsearch.index.engine
- ensureAllArraysAreReleased() - Static method in class org.elasticsearch.common.util.MockBigArrays
- 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
- ensureClusterStateCanBeReadByNodeTool() - 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) - 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() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
waits until all shard initialization is completed.
- ensureNoInitializingShards() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
-
waits until all shard initialization is completed.
- ensurePeerRecoveryRetentionLeasesRenewedAndSynced(String) - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Peer recovery retention leases are renewed and synced to replicas periodically (every 30 seconds).
- 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
- entityAsList(Response) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
-
Convert the entity from a
Response
into a list of maps. - 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.DocIdSeqNoAndSource
- equals(Object) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Path
- 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.
- ErroneousHttpHandler(HttpHandler, int) - Constructor for class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase.ErroneousHttpHandler
- errors() - Method in class org.elasticsearch.test.rest.FakeRestChannel
- errorThrowingScript() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- 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
- ESBlobStoreRepositoryIntegTestCase - Class in org.elasticsearch.repositories.blobstore
-
Integration tests for
BlobStoreRepository
implementations. - ESBlobStoreRepositoryIntegTestCase() - Constructor for class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- 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
- ESFsBasedRepositoryIntegTestCase - Class in org.elasticsearch.repositories.blobstore
- ESFsBasedRepositoryIntegTestCase() - Constructor for class org.elasticsearch.repositories.blobstore.ESFsBasedRepositoryIntegTestCase
- ESIndexInputTestCase - Class in org.elasticsearch.common.lucene.store
-
Test harness for verifying
IndexInput
implementations. - ESIndexInputTestCase() - Constructor for class org.elasticsearch.common.lucene.store.ESIndexInputTestCase
- ESIndexLevelReplicationTestCase - Class in org.elasticsearch.index.replication
- ESIndexLevelReplicationTestCase() - Constructor for class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
- ESIndexLevelReplicationTestCase.ReplicationAction<Request extends org.elasticsearch.action.support.replication.ReplicationRequest<Request>,ReplicaRequest extends org.elasticsearch.action.support.replication.ReplicationRequest<ReplicaRequest>,Response extends org.elasticsearch.action.support.replication.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 Interface in org.elasticsearch.test
-
Defines a cluster scope for a
ESIntegTestCase
subclass. - ESIntegTestCase.NumShards - Class in org.elasticsearch.test
- ESIntegTestCase.Scope - Enum Class in org.elasticsearch.test
-
The scope of a test cluster used together with
ESIntegTestCase.ClusterScope
annotations onESIntegTestCase
subclasses. - ESIntegTestCase.SuiteScopeTestCase - Annotation Interface 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 Interface in org.elasticsearch.test
-
Annotation for third-party integration tests.
- ESMockAPIBasedRepositoryIntegTestCase - Class in org.elasticsearch.repositories.blobstore
-
Integration tests for
BlobStoreRepository
implementations rely on mock APIs that emulate cloud-based services. - ESMockAPIBasedRepositoryIntegTestCase() - Constructor for class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
- ESMockAPIBasedRepositoryIntegTestCase.BlobStoreHttpHandler - Interface in org.elasticsearch.repositories.blobstore
-
A
HttpHandler
that allows to list stored blobs - ESMockAPIBasedRepositoryIntegTestCase.DelegatingHttpHandler - Interface in org.elasticsearch.repositories.blobstore
- ESMockAPIBasedRepositoryIntegTestCase.ErroneousHttpHandler - Class in org.elasticsearch.repositories.blobstore
-
HTTP handler that injects random service errors Note: it is not a good idea to allow this handler to simulate too many errors as it would slow down the test suite.
- ESMockAPIBasedRepositoryIntegTestCase.HttpStatsCollectorHandler - Class in org.elasticsearch.repositories.blobstore
-
HTTP handler that allows collect request stats per request type.
- 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
viaObjectPath(Object)
returns the result of callingObjectPath.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
- Event(LinearizabilityChecker.EventType, Object, int) - Constructor for class org.elasticsearch.cluster.coordination.LinearizabilityChecker.Event
- EventuallySeenEventExpectation(String, String, Level, String) - Constructor for class org.elasticsearch.test.MockLogAppender.EventuallySeenEventExpectation
- 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(Runnable) - Method in class org.elasticsearch.test.disruption.DisruptableMockTransport
- execute(String...) - Method in class org.elasticsearch.cli.CommandTestCase
-
Runs a command with the given args.
- execute(TransportAction<Request, Response>, Task, Request, ActionListener<Response>) - Static method in class org.elasticsearch.action.support.ActionTestUtils
-
Executes the given action.
- execute(Command, String...) - Method in class org.elasticsearch.cli.CommandTestCase
-
Runs the specified command with the given args.
- 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
- executeBlocking(TransportAction<Request, Response>, Request) - Static method in class org.elasticsearch.action.support.ActionTestUtils
- executeConsistentStateUpdate(Function<RepositoryData, ClusterStateUpdateTask>, String, Consumer<Exception>) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- executeGet(GetRequest) - Method in class org.elasticsearch.test.AbstractBuilderTestCase
-
Override this to handle
Client.get(GetRequest)
calls from parsers / builders - executeLocally(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.test.client.NoOpNodeClient
- executeLocally(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.test.rest.RestActionTestCase.VerifyingClient
- executeLocally(ActionType<Response>, Request, TaskListener<Response>) - Method in class org.elasticsearch.test.client.NoOpNodeClient
- executeLocally(ActionType<Response>, Request, TaskListener<Response>) - Method in class org.elasticsearch.test.rest.RestActionTestCase.VerifyingClient
- 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
- executor(String) - Method in class org.elasticsearch.threadpool.TestThreadPool
- 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
- expectReduceUsesTooManyBuckets(InternalAggregation, int) - Static method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
-
Reduce an aggreation, expecting it to collect more than a certain number of buckets.
- expectSoftDeletesWarning(Request, String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- expectTranslogRetentionWarning(Request) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- 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.
- EXPERIMENTAL - Enum constant in enum class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Stability
- 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
- extractTotalHits(Map<?, ?>) - Static method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
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
- failReadsAllDataNodes(String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- failureAndSuccessEvents - Variable in class org.elasticsearch.test.ESTestCase
- FakeFieldType(String) - 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) - 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
- FakeThreadPoolMasterService - Class in org.elasticsearch.cluster.service
- FakeThreadPoolMasterService(String, String, ThreadPool, Consumer<Runnable>) - Constructor for class org.elasticsearch.cluster.service.FakeThreadPoolMasterService
- FakeTransport - Class in org.elasticsearch.test.transport
-
A transport that does nothing.
- FakeTransport() - Constructor for class org.elasticsearch.test.transport.FakeTransport
- FEATURE_FLAG - Enum constant in enum class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Visibility
- 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
- fetchFieldsContext() - Method in class org.elasticsearch.test.TestSearchContext
- fetchFieldsContext(FetchFieldsContext) - Method in class org.elasticsearch.test.TestSearchContext
- fetchFromDocValues(MapperService, MappedFieldType, DocValueFormat, Object) - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
Use a ValueFetcher to extract values from doc values.
- 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
- fetchSourceValue(MappedFieldType, Object) - Static method in class org.elasticsearch.index.mapper.FieldTypeTestCase
- fetchSourceValue(MappedFieldType, Object, String) - Static method in class org.elasticsearch.index.mapper.FieldTypeTestCase
- fetchSourceValues(MappedFieldType, Object...) - Static method in class org.elasticsearch.index.mapper.FieldTypeTestCase
- fieldFromSource(String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
- fieldMapping(CheckedConsumer<XContentBuilder, IOException>) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- FieldMaskingReader - Class in org.elasticsearch.test
- FieldMaskingReader(String, DirectoryReader) - Constructor for class org.elasticsearch.test.FieldMaskingReader
- fieldName() - Method in class org.elasticsearch.index.mapper.MetadataMapperTestCase
- Fields - Enum constant in enum class 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
- fileSystemProvider - Static variable in class org.elasticsearch.cluster.DiskUsageIntegTestCase
- filteredWarnings() - Method in class org.elasticsearch.test.AbstractMultiClustersTestCase
- filteredWarnings() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
- filteredWarnings() - Method in class org.elasticsearch.test.ESTestCase
- finalizeRecovery(long, long, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.AsyncRecoveryTarget
- finalizeSnapshot(FinalizeSnapshotContext) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- findFilePaths(ClassLoader, String) - Static method in class org.elasticsearch.test.ClasspathUtils
- FIPS_SYSPROP - Static variable in class org.elasticsearch.test.ESTestCase
- floatValue() - Method in class org.elasticsearch.script.ScoreAccessor
- 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.
- flush(String, boolean) - Method in class org.elasticsearch.test.rest.ESRestTestCase
- 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.
- forceSingleDataPath() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Override to return true in tests that cannot handle multiple data paths.
- forEachFileRecursively(Path, CheckedBiConsumer<Path, BasicFileAttributes, IOException>) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- format(String, Map<String, Object>) - Static method in class org.elasticsearch.common.util.NamedFormatter
-
Replaces named parameters of the form
%(param)
in format strings. - 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
- from(BufferedReader) - Static method in class org.elasticsearch.common.logging.JsonLogsStream
- from(Path) - Static method in class org.elasticsearch.common.logging.JsonLogsStream
- 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
- generateHistoryOnReplica(int, long, boolean, boolean, boolean) - Method in class org.elasticsearch.index.engine.EngineTestCase
- generateMapping(String) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- generateMapping(String, String) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- generateNewSeqNo(Engine) - Static method in class org.elasticsearch.index.engine.EngineTestCase
-
Generate a new sequence number and return it.
- generateRandomInputValue(MappedFieldType) - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
Create a random
_source
value for this field. - 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, long, int, int, String) - Static method in class org.elasticsearch.index.engine.EngineTestCase
- genericChannelException(ChannelContext<?>, Exception) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- 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
- GeometryTestUtils - Class in org.elasticsearch.geo
- GeometryTestUtils() - Constructor for class org.elasticsearch.geo.GeometryTestUtils
- geoPointField(String) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Make a GeoPointFieldMapper.GeoPointFieldType for a
geo_point
. - GeoPointShapeQueryTestCase - Class in org.elasticsearch.search.geo
- GeoPointShapeQueryTestCase() - Constructor for class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- GeoShapeQueryTestCase - Class in org.elasticsearch.search.geo
- GeoShapeQueryTestCase() - Constructor for class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- get() - Method in class org.elasticsearch.index.engine.EngineTestCase.PrimaryTermSupplier
- get(String) - Method in class org.elasticsearch.test.XContentTestUtils.JsonMapView
- getAcceptedChannels(TcpTransport) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- 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
- getAllConnectedNodes() - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
- 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)
. - getAnyLeader() - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase.Cluster
- 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 - getBasePort() - Static method in class org.elasticsearch.test.ESTestCase
- getBestMatchingPaths(Set<String>) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
-
Returns the best matching paths based on the provided parameters, which may include either path parts or query_string parameters.
- 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
- 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
- getChannelType() - Method in class org.elasticsearch.transport.TestTransportChannel
- 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.
- getClientYamlTestCandidate() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestExecutionContext
- 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
- getClusterStateWithDataStreams(List<Tuple<String, Integer>>, List<String>) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
-
Constructs
ClusterState
with the specified data streams and indices. - getClusterStateWithDataStreams(List<Tuple<String, Integer>>, List<String>, int) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
-
Constructs
ClusterState
with the specified data streams and indices. - 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
- getConnectionProfile() - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
- getConnectionStatus(DiscoveryNode) - Method in class org.elasticsearch.test.disruption.DisruptableMockTransport
- 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
- getCountForIndex(String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- getCurrentMasterNodeInstance(Class<T>) - Method in class org.elasticsearch.test.InternalTestCluster
- getCurrentTimeMillis() - Method in class org.elasticsearch.common.util.concurrent.DeterministicTaskQueue
- getCurrentTypes() - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
- 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
- getDefaultSeedAddresses() - Method in class org.elasticsearch.test.transport.FakeTransport
- getDefaultSeedAddresses() - Method in class org.elasticsearch.test.transport.StubbableTransport
- getDefaultSettings() - Method in class org.elasticsearch.test.InternalTestCluster
- getDelegate() - Method in interface org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase.DelegatingHttpHandler
- getDelegate() - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase.ErroneousHttpHandler
- getDelegate() - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase.HttpStatsCollectorHandler
- getDescription() - Method in class org.elasticsearch.ingest.TestProcessor
- getDirectoryFactories() - Method in class org.elasticsearch.test.store.MockFSIndexStore.TestPlugin
- getDisconnectException(long, String, DiscoveryNode) - Method in class org.elasticsearch.test.disruption.DisruptableMockTransport
- getDiscoveryNode(String) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
- getDisruptableMockTransport(TransportAddress) - Method in class org.elasticsearch.test.disruption.DisruptableMockTransport
- 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
- getElectionStrategy() - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- 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
- getEnsureGreenTimeout() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Permits subclasses to increase the default timeout when waiting for green health
- getError() - Method in class org.elasticsearch.test.rest.yaml.section.CloseToAssertion
- getErrorOutput() - Method in class org.elasticsearch.cli.MockTerminal
-
Returns all output written to this terminal.
- getErrorWriter() - Method in class org.elasticsearch.cli.MockTerminal
- 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.common.util.concurrent.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 viaXContentParser.objectText()
. - getExpectedValue() - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
- getFailureCount() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- getFailureCount(String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- getFakeDiscoNode(String) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
- getFakeMasterServicePendingTaskCount() - Method in class org.elasticsearch.cluster.service.FakeThreadPoolMasterService
- getFeatureFlag() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
- getFeatures() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
- getField() - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
- getFieldFilter() - Method in class org.elasticsearch.index.mapper.MockFieldFilterPlugin
- getFile(String) - Method in class org.elasticsearch.common.settings.MockSecureSettings
- getFirstVersion() - Static method in class org.elasticsearch.test.VersionUtils
-
Returns the oldest released
Version
- getHasXPack() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- 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
- getHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractNXYSignificanceHeuristicTestCase
- getHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
- getHeuristic(boolean, boolean) - Method in class org.elasticsearch.search.aggregations.bucket.AbstractNXYSignificanceHeuristicTestCase
- getId() - Method in class org.elasticsearch.index.engine.DocIdSeqNoAndSource
- 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
- getIndexMetadataBuilderForIndex(Index) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- getIndexSettings() - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- getIndexSettings(String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- getIndexSettingsAsMap(String) - Method in class org.elasticsearch.test.rest.ESRestTestCase
- getInFlightDocCount(Engine) - Static method in class org.elasticsearch.index.engine.EngineTestCase
- 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
- getJsonSchemaFileName() - Method in class org.elasticsearch.test.AbstractSchemaValidationTestCase
-
Return the filename of the schema file used for testing.
- getKey(Object) - Method in interface org.elasticsearch.cluster.coordination.LinearizabilityChecker.KeyedSpec
-
extracts the key from the given keyed invocation input value
- getLatestDeferredExecutionTime() - Method in class org.elasticsearch.common.util.concurrent.DeterministicTaskQueue
- getListenerCaptor() - Method in class org.elasticsearch.transport.FakeTcpChannel
- getLocalAddress() - Method in class org.elasticsearch.transport.FakeTcpChannel
- getLocalDiscoNode() - Method in class org.elasticsearch.test.transport.MockTransportService
- getLocalEphemeral() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- getLocalNode() - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase.Cluster.ClusterNode
- getLocalNode() - Method in class org.elasticsearch.test.disruption.DisruptableMockTransport
- getLocalNodeId() - Method in class org.elasticsearch.test.client.NoOpNodeClient
- getLocalNodeId() - Method in class org.elasticsearch.test.rest.RestActionTestCase.VerifyingClient
- 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
- getLower() - Method in class org.elasticsearch.test.rest.yaml.section.VersionRange
- getLowerVersion() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
- getMajoritySide() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
- getMappers() - Method in class org.elasticsearch.test.TestGeoShapeFieldMapperPlugin
-
Deprecated.
- getMapperService() - Static 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.
- getMasterNodeInstance(Class<T>) - Method in class org.elasticsearch.test.InternalTestCluster
- getMasterVersion() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestClient
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.MockFieldMapper
- getMessageCaptor() - Method in class org.elasticsearch.transport.FakeTcpChannel
- getMetadata() - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- getMetadata() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- getMethod() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Request
- getMethods() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Path
- 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
- getMockScriptService() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Sub-tests that need scripting can override this method to provide a script service and pre-baked scripts
- 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.AbstractNamedWriteableTestCase
- 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
-
Deprecated.
- getNamedWriteables() - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
Implementors can override this if they want to provide a custom list of namedWriteables.
- 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
- getNodeIdForLogContext(DiscoveryNode) - Static method in class org.elasticsearch.common.util.concurrent.DeterministicTaskQueue
- 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
- getNumVersionLookups(Engine) - Static method in class org.elasticsearch.index.engine.EngineTestCase
-
Returns the number of times a version was looked up either from version map or from the index.
- getObjectsHoldingArbitraryContent() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Returns a map where the keys are object names that won't trigger a standard exception (an exception that contains the string "unknown field [newField]") through
AbstractQueryTestCase.testUnknownObjectException()
. - getOldClusterVersion() - Static method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
- getOperatingSystems() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
- getOriginalTransport() - Method in class org.elasticsearch.test.transport.MockTransportService
- getOs() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestClient
- 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.index.mapper.MockFieldMapper.Builder
- 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
- getParseMaximalWarnings() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- getParseMinimalWarnings() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- getParts() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Path
- getPath() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture.Request
- getPath() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Path
- getPath() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
- getPaths() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
- getPendingDeletions() - Method in class org.elasticsearch.test.store.MockFSDirectoryFactory.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.MapperServiceTestCase
- getPlugins() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- 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
- getPortRange() - Static method in class org.elasticsearch.test.ESTestCase
-
Returns a unique port range for this JVM starting from the computed base port
- 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 theVersion.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
- getPrimaryShard() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationAction
- getPrimaryTerm() - Method in class org.elasticsearch.index.engine.DocIdSeqNoAndSource
- getProcessors(Processor.Parameters) - Method in class org.elasticsearch.ingest.IngestTestPlugin
- getProfile() - Method in class org.elasticsearch.transport.FakeTcpChannel
- getProfileName() - Method in class org.elasticsearch.transport.TestTransportChannel
- getProfilers() - Method in class org.elasticsearch.test.TestSearchContext
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase.InternalAggCardinality
- getProtocol() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Override this to switch to testing https.
- 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.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
- getRandomTypes() - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
- getRandomValueForFieldName(String) - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
create a random value for either
AbstractBuilderTestCase.BOOLEAN_FIELD_NAME
,AbstractBuilderTestCase.INT_FIELD_NAME
,AbstractBuilderTestCase.DOUBLE_FIELD_NAME
,AbstractBuilderTestCase.TEXT_FIELD_NAME
orAbstractBuilderTestCase.DATE_FIELD_NAME
orAbstractBuilderTestCase.DATE_NANOS_FIELD_NAME
or a String value by default - getRange(HttpExchange) - Static method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- getRangeEnd(HttpExchange) - Static method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- getRangeStart(HttpExchange) - Static method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- getReaderCacheHelper() - Method in class org.elasticsearch.index.engine.EngineTestCase.MatchingDirectoryReader
- 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
- getRelativeTimeInMillis() - Method in class org.elasticsearch.test.TestSearchContext
- getRemoteAddress() - Method in class org.elasticsearch.transport.FakeTcpChannel
- getRemoteClusterClient(String) - Method in class org.elasticsearch.test.client.NoOpNodeClient
- getReplicas() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
- getReplicationTracker(IndexShard) - Static method in class org.elasticsearch.index.shard.IndexShardTestCase
- getRepositories(Environment, NamedXContentRegistry, ClusterService, BigArrays, RecoverySettings) - Method in class org.elasticsearch.snapshots.mockstore.MockRepository.Plugin
- getRepository() - Method in class org.elasticsearch.repositories.AbstractThirdPartyRepositoryTestCase
- getRepositoryData(String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- getRepositoryData(String, Version) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- getRepositoryData(ActionListener<RepositoryData>) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- getRepositoryData(Repository) - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- getRepositoryData(Repository) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- getRepositoryOnMaster(String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- getRepositoryOnNode(String, String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- getRequestDescription(long, String, DiscoveryNode) - Method in class org.elasticsearch.test.disruption.DisruptableMockTransport
- getRequestHandlers() - Method in class org.elasticsearch.test.transport.FakeTransport
- getRequestHandlers() - Method in class org.elasticsearch.test.transport.StubbableTransport
- getRequestMimeTypes() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
- getResponseException() - Method in exception org.elasticsearch.test.rest.yaml.ClientYamlTestResponseException
-
Exposes the origina
ResponseException
. - getResponseHandlers() - Method in class org.elasticsearch.test.transport.FakeTransport
- getResponseHandlers() - Method in class org.elasticsearch.test.transport.StubbableTransport
- getResponseMimeTypes() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
- 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
- getSampleValueForDocument() - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
Returns a sample value for the field, to be used in a document
- getSampleValueForQuery() - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
Returns a sample value for the field, to be used when querying the field.
- getSchemaLocation() - Method in class org.elasticsearch.test.AbstractSchemaValidationTestCase
-
Root folder for all schema files.
- getSchemaVersion() - Method in class org.elasticsearch.test.AbstractSchemaValidationTestCase
-
Version of the Json Schema Spec to be used by the test.
- getScriptEngine(Settings, Collection<ScriptContext<?>>) - Method in class org.elasticsearch.script.MockScriptPlugin
- getSearchExecutionContext() - Method in class org.elasticsearch.test.TestSearchContext
- getSearchExt(String) - Method in class org.elasticsearch.test.TestSearchContext
- getSearchPlugins() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Test cases should override this if they have plugins that need to be loaded, e.g.
- getSeqNo() - Method in class org.elasticsearch.index.engine.DocIdSeqNoAndSource
- 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.snapshots.mockstore.MockRepository.Plugin
- 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() - 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
- getSHA256Digest(String) - Method in class org.elasticsearch.common.settings.MockSecureSettings
- getShardDocUIDs(IndexShard) - Static method in class org.elasticsearch.index.shard.IndexShardTestCase
- getShardSnapshotStatus(SnapshotId, 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.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
- getSnapshot(String, String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- getSnapshotGlobalMetadata(SnapshotId) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- getSnapshotIndexMetaData(RepositoryData, SnapshotId, IndexId) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- getSnapshotInfo(GetSnapshotInfoContext) - 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
- getSource() - Method in class org.elasticsearch.index.engine.DocIdSeqNoAndSource
- getStability() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
- 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.FakeTransport
- 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
- getSupportedContexts() - Method in class org.elasticsearch.script.MockScriptEngine
- getSupportedSettings() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- getSupportedValuesSourceTypes() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Implementors should return a list of
ValuesSourceType
that the aggregator supports. - 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
- getTestFileStore(String) - Method in class org.elasticsearch.cluster.DiskUsageIntegTestCase
- getTestPath() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
- getTestRestCluster() - Method in class org.elasticsearch.test.rest.ESRestTestCase
- 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.common.util.concurrent.DeterministicTaskQueue
- getThreadPool(Function<Runnable, Runnable>) - Method in class org.elasticsearch.common.util.concurrent.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
- getTotalSpace() - Method in class org.elasticsearch.cluster.DiskUsageIntegTestCase.TestFileStore
- getToXContentParams() - Method in class org.elasticsearch.test.AbstractSchemaValidationTestCase
-
Params that have to be provided when calling
ToXContent.toXContent(XContentBuilder, ToXContent.Params)
- 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.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
- getTransportInterceptor(DiscoveryNode, ThreadPool) - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- getTransportInterceptors(NamedWriteableRegistry, ThreadContext) - Method in class org.elasticsearch.test.ESIntegTestCase.AssertActionNamePlugin
- getTransports(Settings, ThreadPool, PageCacheRecycler, CircuitBreakerService, NamedWriteableRegistry, NetworkService) - Method in class org.elasticsearch.transport.nio.MockNioTransportPlugin
- getType() - Method in class org.elasticsearch.ingest.TestProcessor
- getType() - Method in class org.elasticsearch.script.MockScriptEngine
- getUnallocatedSpace() - Method in class org.elasticsearch.cluster.DiskUsageIntegTestCase.TestFileStore
- getUnsafeClasses() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
- getUpper() - Method in class org.elasticsearch.test.rest.yaml.section.VersionRange
- getUpperVersion() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
- getUsableSpace() - Method in class org.elasticsearch.cluster.DiskUsageIntegTestCase.TestFileStore
- getValue(Object) - Method in interface org.elasticsearch.cluster.coordination.LinearizabilityChecker.KeyedSpec
-
extracts the key-less value from the given keyed invocation input value
- getValue(String) - Method in class org.elasticsearch.test.rest.yaml.Stash
-
Retrieves a value from the current stash.
- getVersion() - Method in class org.elasticsearch.index.engine.DocIdSeqNoAndSource
- getVersion() - Method in class org.elasticsearch.test.transport.StubbableTransport.WrappedConnection
- getVisibility() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
- 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.
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase.InternalAggCardinality
- getWriter() - Method in class org.elasticsearch.cli.MockTerminal
- 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(HttpExchange) - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase.ErroneousHttpHandler
- handle(HttpExchange) - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase.HttpStatsCollectorHandler
- handle(AbstractHttpFixture.Request) - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture
- handle(AbstractHttpFixture.Request) - Method in interface org.elasticsearch.test.fixture.AbstractHttpFixture.RequestHandler
- handleActive(ChannelContext<?>) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- handleAsError(HttpExchange) - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase.ErroneousHttpHandler
- handleClose(ChannelContext<?>) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- handleConnect(SocketChannelContext) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- handleError(long, TransportException) - Method in class org.elasticsearch.test.transport.MockTransport
-
simulate an error for the given requestId, unlike
MockTransport.handleLocalError(long, Throwable)
andMockTransport.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.MockTransport
-
simulate a local error for the given requestId, will be wrapped by a
SendRequestTransportException
- handleRead(SocketChannelContext) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- handleRegistration(ChannelContext<?>) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- handleRemoteError(long, Throwable) - Method in class org.elasticsearch.test.transport.MockTransport
-
simulate a remote error for the given requestId, will be wrapped by a
RemoteTransportException
- handleResponse(long, Response) - Method in class org.elasticsearch.test.transport.MockTransport
-
simulate a response for the given requestId
- handlers - Variable in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
- handleTask(Runnable) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- handleWrite(SocketChannelContext) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- handoffPrimaryContext(ReplicationTracker.PrimaryContext, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.AsyncRecoveryTarget
- hasAllKeys(String...) - Static method in class org.elasticsearch.test.hamcrest.CollectionAssertions
- hasBody() - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
- hasDeferredTasks() - Method in class org.elasticsearch.common.util.concurrent.DeterministicTaskQueue
- hasFetchSourceContext() - Method in class org.elasticsearch.test.TestSearchContext
- hashCode() - Method in class org.elasticsearch.index.engine.DocIdSeqNoAndSource
- hashCode() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Path
- 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.common.util.concurrent.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
- 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(SearchHighlightContext) - Method in class org.elasticsearch.test.TestSearchContext
- History() - Constructor for class org.elasticsearch.cluster.coordination.LinearizabilityChecker.History
- History(Collection<LinearizabilityChecker.Event>) - Constructor for class org.elasticsearch.cluster.coordination.LinearizabilityChecker.History
- 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.
- httpServer - Variable in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- httpServerUrl() - Static method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
- HttpStatsCollectorHandler(HttpHandler) - Constructor for class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase.HttpStatsCollectorHandler
I
- id - Variable in class org.elasticsearch.cluster.coordination.LinearizabilityChecker.Event
- 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
- INCLUDE_DEFAULTS - Static variable in class org.elasticsearch.index.mapper.MapperServiceTestCase
- incompatibleFutureVersion(Version) - Static method in class org.elasticsearch.test.VersionUtils
-
returns the first future incompatible version
- incrementVersion(ClusterState) - Method in class org.elasticsearch.cluster.service.FakeThreadPoolMasterService
- 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(String, String, Object...) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Syntactic sugar for:
- 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) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
- indexDocs(int) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
- indexExists(String) - Static method in class org.elasticsearch.test.ESIntegTestCase
-
Returns
true
iff the given index exists otherwisefalse
- 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
- indexOnPrimary(IndexRequest, IndexShard) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
-
indexes the given requests on the supplied primary, modifying it for replicas
- indexOnReplica(BulkShardRequest, ESIndexLevelReplicationTestCase.ReplicationGroup, IndexShard) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase
-
indexes the given requests on the supplied replica shard
- 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)
. - indexRandomDocs(String, int) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- 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...)
andESIntegTestCase.prepareCreate(String)
and friends. - IndexSettingsModule - Class in org.elasticsearch.test
- IndexSettingsModule(Index, Settings) - Constructor for class org.elasticsearch.test.IndexSettingsModule
- indexSettingsNoReplicas(int) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- 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
- indexTranslogOperations(List<Translog.Operation>, int, long, long, RetentionLeases, long, ActionListener<Long>) - Method in class org.elasticsearch.indices.recovery.AsyncRecoveryTarget
- inFipsJvm() - Static method in class org.elasticsearch.test.ESIntegTestCase
- inFipsJvm() - Static method in class org.elasticsearch.test.ESTestCase
- info() - Method in class org.elasticsearch.test.MockHttpTransport
- IngestDocumentMatcher - Class in org.elasticsearch.ingest
- IngestDocumentMatcher() - Constructor for class org.elasticsearch.ingest.IngestDocumentMatcher
- ingestNode() - Static method in class org.elasticsearch.test.NodeRoles
- ingestNode(Settings) - Static method in class org.elasticsearch.test.NodeRoles
- ingestOnlyNode() - Static method in class org.elasticsearch.test.NodeRoles
- ingestOnlyNode(Settings) - Static method in class org.elasticsearch.test.NodeRoles
- IngestTestPlugin - Class in org.elasticsearch.ingest
-
Adds an ingest processor to be used in tests.
- IngestTestPlugin() - Constructor for class org.elasticsearch.ingest.IngestTestPlugin
- init() - Method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
- 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, Version, String) - Method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
- initialize(Map<ActionType<? extends ActionResponse>, TransportAction<? extends ActionRequest, ? extends ActionResponse>>, Supplier<String>, RemoteClusterService, NamedWriteableRegistry) - Method in class org.elasticsearch.test.client.NoOpNodeClient
- 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
- initializeUseDefaultNumberOfShards() - Static method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
- initialState() - Method in interface org.elasticsearch.cluster.coordination.LinearizabilityChecker.SequentialSpec
-
Returns the initial state of the datatype
- initiateChannel(DiscoveryNode) - Method in class org.elasticsearch.transport.nio.MockNioTransport
- initValuesSourceRegistry() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- initWithSameId(ShardRouting, RecoverySource) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
- initWithSnapshotVersion(String, Path, Version) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
-
Workaround to simulate BwC situation: taking a snapshot without indices here so that we don't create any new version shard generations (the existence of which would short-circuit checks for the repo containing old version snapshots)
- 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 newXContentBuilder
The paths argument uses dot separated fieldnames and numbers for array indices, similar to what we do inObjectPath
. - 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.
- installFilesystemProvider() - Method in class org.elasticsearch.cluster.DiskUsageIntegTestCase
- installMock(FileSystem) - Static method in class org.elasticsearch.core.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.indices.EmptySystemIndices
- INSTANCE - Static variable in class org.elasticsearch.transport.LeakTracker
- instanceReader() - Method in class org.elasticsearch.test.AbstractWireSerializingTestCase
-
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.search.aggregations.BasePipelineAggregationTestCase
- 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
- InternalAggCardinality(String, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.AggregatorTestCase.InternalAggCardinality
- InternalAggregationTestCase<T extends org.elasticsearch.search.aggregations.InternalAggregation> - Class in org.elasticsearch.test
-
Implementors of this test case should be aware that the aggregation under test needs to be registered in the test's namedWriteableRegistry.
- InternalAggregationTestCase() - Constructor for class org.elasticsearch.test.InternalAggregationTestCase
- internalCluster() - Static method in class org.elasticsearch.test.ESIntegTestCase
- InternalMultiBucketAggregationTestCase<T extends org.elasticsearch.search.aggregations.InternalAggregation & org.elasticsearch.search.aggregations.bucket.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 org.elasticsearch.search.aggregations.bucket.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, 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, String, Collection<Class<? extends Plugin>>, Function<Client, Client>, boolean, 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 / orInternalTestCluster.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 - Enum constant in enum class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
- intPage(boolean) - Method in class org.elasticsearch.common.util.MockPageCacheRecycler
- intValue() - Method in class org.elasticsearch.script.ScoreAccessor
- INVOCATION - Enum constant in enum class org.elasticsearch.cluster.coordination.LinearizabilityChecker.EventType
- invoke(Object) - Method in class org.elasticsearch.cluster.coordination.LinearizabilityChecker.History
-
Appends a new invocation event to the history
- 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
- 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() - Static method in class org.elasticsearch.test.hamcrest.OptionalMatchers
- 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
- isLinearizable(LinearizabilityChecker.SequentialSpec, LinearizabilityChecker.History) - Method in class org.elasticsearch.cluster.coordination.LinearizabilityChecker
-
Convenience method for
LinearizabilityChecker.isLinearizable(SequentialSpec, History, Function)
that requires the history to be complete - isLinearizable(LinearizabilityChecker.SequentialSpec, LinearizabilityChecker.History, Function<Object, Object>) - Method in class org.elasticsearch.cluster.coordination.LinearizabilityChecker
-
Checks whether the provided history is linearizable with respect to the given sequential specification
- isLinearizable(LinearizabilityChecker.SequentialSpec, LinearizabilityChecker.History, Function<Object, Object>, BooleanSupplier) - Method in class org.elasticsearch.cluster.coordination.LinearizabilityChecker
-
Checks whether the provided history is linearizable with respect to the given sequential specification
- isLoaded() - Method in class org.elasticsearch.common.settings.MockSecureSettings
- isNotFoundResponseException(IOException) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- IsolateAllNodes(Set<String>) - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.IsolateAllNodes
- isolateMasterDisruption(NetworkDisruption.NetworkLinkDisruptionType) - Static method in class org.elasticsearch.test.ESIntegTestCase
-
Creates a disruption that isolates the current master node from all other nodes in the cluster.
- isOpen() - Method in class org.elasticsearch.transport.FakeTcpChannel
- isPresent() - Static method in class org.elasticsearch.test.hamcrest.OptionalMatchers
- isRawIndexingData() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.StringMessageRequest
- isReadOnly() - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- isResultDeterministic() - Method in class org.elasticsearch.script.MockDeterministicScript
- isResultDeterministic() - Method in class org.elasticsearch.script.MockScriptEngine.MockMetricAggCombineScriptFactory
- isResultDeterministic() - Method in class org.elasticsearch.script.MockScriptEngine.MockMetricAggInitScriptFactory
- isResultDeterministic() - Method in class org.elasticsearch.script.MockScriptEngine.MockMetricAggMapScriptFactory
- isResultDeterministic() - Method in class org.elasticsearch.script.MockScriptEngine.MockMetricAggReduceScriptFactory
- isResultDeterministic() - Method in class org.elasticsearch.script.MockScriptEngine.MockScoreScript
- isRunningAgainstAncientCluster() - Method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
- isRunningAgainstOldCluster() - Static method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
- isServerChannel() - Method in class org.elasticsearch.transport.FakeTcpChannel
- issueUrl() - Element in annotation interface org.elasticsearch.test.junit.annotations.TestIssueLogging
-
This property is used to link to the open test issue under investigation.
- 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
- isTuple(Matcher<? super V1>, Matcher<? super V2>) - Static method in class org.elasticsearch.test.hamcrest.TupleMatchers
-
Creates a matcher that matches iff: 1.
- isVersionCheck() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
- isXPackTemplate(String) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
-
Is this template one that is automatically created by xpack?
- 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
- JsonLogLine - Class in org.elasticsearch.common.logging
-
Represents a single log line in a json format.
- JsonLogLine() - Constructor for class org.elasticsearch.common.logging.JsonLogLine
- JsonLogsIntegTestCase - Class in org.elasticsearch.common.logging
-
Tests that extend this class verify that all json layout fields appear in the first few log lines after startup Fields available upon process startup:
type
,timestamp
,level
,component
,message
,node.name
,cluster.name
. - JsonLogsIntegTestCase() - Constructor for class org.elasticsearch.common.logging.JsonLogsIntegTestCase
- JsonLogsStream - Class in org.elasticsearch.common.logging
-
Returns a stream of json log lines.
- JsonMapView(Map<String, Object>) - Constructor for class org.elasticsearch.test.XContentTestUtils.JsonMapView
K
- keySet(ClusterState) - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- KEYWORD_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
- keywordField(String) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Make a DateFieldMapper.DateFieldType for a
date
.
L
- LARGE_SNAPSHOT_POOL_SETTINGS - Static variable in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- LeakTracker - Class in org.elasticsearch.transport
-
Leak tracking mechanism that allows for ensuring that a resource has been properly released before a given object is garbage collected.
- LeakTracker.Leak<T> - Class in org.elasticsearch.transport
- 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.PatternSeenEventExpectation
- level() - Method in class org.elasticsearch.common.logging.JsonLogLine
- lifecycleState() - Method in class org.elasticsearch.test.transport.StubbableTransport
- LIGHT_PROFILE - Static variable in class org.elasticsearch.transport.TestProfiles
-
A pre-built light connection profile that shares a single connection across all types.
- LimitedBreaker(String, ByteSizeValue) - Constructor for class org.elasticsearch.common.util.MockBigArrays.LimitedBreaker
- LinearizabilityChecker - Class in org.elasticsearch.cluster.coordination
-
Basic implementation of the Wing and Gong Graph Search Algorithm, following the descriptions in Gavin Lowe: Testing for linearizability Concurrency and Computation: Practice and Experience 29, 4 (2017).
- LinearizabilityChecker() - Constructor for class org.elasticsearch.cluster.coordination.LinearizabilityChecker
- LinearizabilityChecker.Event - Class in org.elasticsearch.cluster.coordination
- LinearizabilityChecker.EventType - Enum Class in org.elasticsearch.cluster.coordination
- LinearizabilityChecker.History - Class in org.elasticsearch.cluster.coordination
-
Sequence of invocations and responses, recording the run of a concurrent system.
- LinearizabilityChecker.KeyedSpec - Interface in org.elasticsearch.cluster.coordination
-
Sequential specification of a datatype that allows for keyed access, providing compositional checking (see
LinearizabilityChecker.SequentialSpec.partition(List)
). - LinearizabilityChecker.SequentialSpec - Interface in org.elasticsearch.cluster.coordination
-
Sequential specification of a datatype.
- linearRing(double[], double[], boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- listen() - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture
-
Opens a
HttpServer
and start listening on a provided or random port. - listen(InetAddress, boolean) - Method in class org.elasticsearch.test.fixture.AbstractHttpFixture
-
Opens a
HttpServer
and start listening on a provided or 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
- LOCAL_CLUSTER - Static variable in class org.elasticsearch.test.AbstractMultiClustersTestCase
- 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.PatternSeenEventExpectation
- 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
- longField(String) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Make a NumberFieldMapper.NumberFieldType for a
long
. - 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
- longValue() - Method in class org.elasticsearch.script.ScoreAccessor
- 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
- MapperScriptTestCase<FactoryType> - Class in org.elasticsearch.index.mapper
- MapperScriptTestCase() - Constructor for class org.elasticsearch.index.mapper.MapperScriptTestCase
- MapperServiceTestCase - Class in org.elasticsearch.index.mapper
-
Test case that lets you easilly build
MapperService
based on some mapping. - MapperServiceTestCase() - Constructor for class org.elasticsearch.index.mapper.MapperServiceTestCase
- MapperTestCase - Class in org.elasticsearch.index.mapper
-
Base class for testing
Mapper
s. - MapperTestCase() - Constructor for class org.elasticsearch.index.mapper.MapperTestCase
- MapperTestCase.ParameterChecker - Class in org.elasticsearch.index.mapper
- MapperTestUtils - Class in org.elasticsearch.index
- MapperTestUtils() - Constructor for class org.elasticsearch.index.MapperTestUtils
- mapping(CheckedConsumer<XContentBuilder, IOException>) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- mappingLookup(String) - Static method in class org.elasticsearch.index.engine.EngineTestCase
- mappingUpdate - Variable in class org.elasticsearch.index.engine.TranslogHandler
- mapStreamFrom(Path) - Static method in class org.elasticsearch.common.logging.JsonLogsStream
- mark(int) - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase.ZeroInputStream
- markSupported() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase.ZeroInputStream
- 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.
- masterNode() - Static method in class org.elasticsearch.test.NodeRoles
- masterNode(Settings) - Static method in class org.elasticsearch.test.NodeRoles
- masterOnlyNode() - Static method in class org.elasticsearch.test.NodeRoles
- masterOnlyNode(Settings) - Static method in class org.elasticsearch.test.NodeRoles
- masterVersion() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestExecutionContext
- 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.PatternSeenEventExpectation
- 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
- matchesSafely(String) - Method in class org.elasticsearch.test.hamcrest.RegexMatcher
- matchesSafely(ImmutableOpenMap<String, ?>) - Method in class org.elasticsearch.test.hamcrest.CollectionMatchers.ImmutableOpenMapHasAllKeysMatcher
- matchesSafely(ImmutableOpenMap<String, ?>) - 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
- MatchingDirectoryReader(DirectoryReader, Query) - Constructor for class org.elasticsearch.index.engine.EngineTestCase.MatchingDirectoryReader
- 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() - Element in annotation interface 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
- maybeInitWithOldSnapshotVersion(String, Path) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
-
Randomly write an empty snapshot of an older version to an empty repository to simulate an older repository metadata format.
- maybeOverrideConnectionProfile(ConnectionProfile) - Method in class org.elasticsearch.transport.nio.MockNioTransport
- maybeSet(Consumer<T>, T) - Static method in class org.elasticsearch.test.ESTestCase
-
helper to randomly perform on
consumer
withvalue
- maybeThrow(ThrowingLeafReaderWrapper.Flags) - Method in interface org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Thrower
-
Maybe throws an exception ;)
- maybeTrack(String, Headers) - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase.HttpStatsCollectorHandler
-
Tracks the given request if it matches the criteria.
- 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(String, MapperService, String) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
-
Merge a new mapping into the one in the provided
MapperService
. - merge(MockSecureSettings) - Method in class org.elasticsearch.common.settings.MockSecureSettings
-
Merge the given secure settings into this one.
- merge(MapperService, XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
-
Merge a new mapping into the one in the provided
MapperService
. - merge(MapperService, MapperService.MergeReason, String) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- merge(MapperService, MapperService.MergeReason, XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
-
Merge a new mapping into the one in the provided
MapperService
with a specificMergeReason
- MERGE_ENABLED - Static variable in class org.elasticsearch.test.InternalSettingsPlugin
- message - Variable in class org.elasticsearch.test.MockLogAppender.AbstractEventExpectation
- message() - Method in class org.elasticsearch.common.logging.JsonLogLine
- messageReceived(TransportRequestHandler<Request>, Request, TransportChannel, Task) - Method in interface org.elasticsearch.test.transport.StubbableTransport.RequestHandlingBehavior
- MetadataMapperTestCase - Class in org.elasticsearch.index.mapper
- MetadataMapperTestCase() - Constructor for class org.elasticsearch.index.mapper.MetadataMapperTestCase
- MetadataMapperTestCase.ParameterChecker - Class in org.elasticsearch.index.mapper
- metaMapping(XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperTestCase
- MIN_PRIVATE_PORT - Static variable in class org.elasticsearch.test.ESTestCase
- minimalMapping(XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperTestCase
- minimalStoreMapping(XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperTestCase
- minimumNodeVersion() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
-
Returns the minimum node version among all nodes of the cluster
- 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() - Element in annotation interface 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_CONTEXT - Static variable in class org.elasticsearch.index.mapper.FieldTypeTestCase
- MOCK_CONTEXT_DISALLOW_EXPENSIVE - Static variable in class org.elasticsearch.index.mapper.FieldTypeTestCase
- MOCK_NIO_TRANSPORT_NAME - Static variable in class org.elasticsearch.transport.nio.MockNioTransportPlugin
- MockAllocationService(AllocationDeciders, GatewayAllocator, ShardsAllocator, ClusterInfoService, SnapshotsInfoService) - Constructor for class org.elasticsearch.cluster.ESAllocationTestCase.MockAllocationService
- MockBigArrays - Class in org.elasticsearch.common.util
- MockBigArrays(PageCacheRecycler, ByteSizeValue) - Constructor for class org.elasticsearch.common.util.MockBigArrays
-
Create BigArrays with a configured limit.
- MockBigArrays(PageCacheRecycler, CircuitBreakerService) - Constructor for class org.elasticsearch.common.util.MockBigArrays
- MockBigArrays.LimitedBreaker - Class in org.elasticsearch.common.util
- MockBlobStore(BlobStore) - Constructor for class org.elasticsearch.snapshots.mockstore.MockRepository.MockBlobStore
- mockClusterService() - Static method in class org.elasticsearch.repositories.blobstore.BlobStoreTestUtil
-
Creates a mocked
ClusterService
for use inBlobStoreRepository
related tests that mocks out all the necessary functionality to makeBlobStoreRepository
work. - mockClusterService(RepositoryMetadata) - Static method in class org.elasticsearch.repositories.blobstore.BlobStoreTestUtil
-
Creates a mocked
ClusterService
for use inBlobStoreRepository
related tests that mocks out all the necessary functionality to makeBlobStoreRepository
work. - 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
- MockDeterministicScript - Class in org.elasticsearch.script
-
A mocked script used for testing purposes.
- MockDeterministicScript() - Constructor for class org.elasticsearch.script.MockDeterministicScript
- 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, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.MockFieldMapper
- MockFieldMapper(MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.MockFieldMapper
- MockFieldMapper(MappedFieldType, Map<String, NamedAnalyzer>) - Constructor for class org.elasticsearch.index.mapper.MockFieldMapper
- MockFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- 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
- MockFSDirectoryFactory - Class in org.elasticsearch.test.store
- MockFSDirectoryFactory() - Constructor for class org.elasticsearch.test.store.MockFSDirectoryFactory
- MockFSDirectoryFactory.ElasticsearchMockDirectoryWrapper - Class in org.elasticsearch.test.store
- MockFSIndexStore - Class in org.elasticsearch.test.store
- MockFSIndexStore() - Constructor for class org.elasticsearch.test.store.MockFSIndexStore
- MockFSIndexStore.TestPlugin - Class in org.elasticsearch.test.store
- MockGatewayMetaState - Class in org.elasticsearch.gateway
-
GatewayMetaState
constructor accepts a lot of arguments. - MockGatewayMetaState(DiscoveryNode, BigArrays) - Constructor for class org.elasticsearch.gateway.MockGatewayMetaState
- MockHttpTransport - Class in org.elasticsearch.test
-
A dummy http transport used by tests when not wanting to actually bind to a real address.
- MockHttpTransport() - Constructor for class org.elasticsearch.test.MockHttpTransport
- MockHttpTransport.TestPlugin - Class in org.elasticsearch.test
-
Marker plugin used by
MockNode
to enableMockHttpTransport
. - 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) - 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.EventuallySeenEventExpectation - Class in org.elasticsearch.test
- MockLogAppender.ExceptionSeenEventExpectation - Class in org.elasticsearch.test
- MockLogAppender.LoggingExpectation - Interface in org.elasticsearch.test
- MockLogAppender.PatternSeenEventExpectation - Class in org.elasticsearch.test
- MockLogAppender.SeenEventExpectation - Class in org.elasticsearch.test
- MockLogAppender.UnseenEventExpectation - Class in org.elasticsearch.test
- MockNioTransport - Class in org.elasticsearch.transport.nio
- MockNioTransport(Settings, Version, ThreadPool, NetworkService, PageCacheRecycler, NamedWriteableRegistry, CircuitBreakerService) - Constructor for class org.elasticsearch.transport.nio.MockNioTransport
- MockNioTransportPlugin - Class in org.elasticsearch.transport.nio
- MockNioTransportPlugin() - Constructor for class org.elasticsearch.transport.nio.MockNioTransportPlugin
- 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, boolean) - Constructor for class org.elasticsearch.node.MockNode
- MockPageCacheRecycler - Class in org.elasticsearch.common.util
- MockPageCacheRecycler(Settings) - Constructor for class org.elasticsearch.common.util.MockPageCacheRecycler
- MockRepository - Class in org.elasticsearch.snapshots.mockstore
- MockRepository(RepositoryMetadata, Environment, NamedXContentRegistry, ClusterService, BigArrays, RecoverySettings) - Constructor for class org.elasticsearch.snapshots.mockstore.MockRepository
- MockRepository.MockBlobStore - Class in org.elasticsearch.snapshots.mockstore
- MockRepository.Plugin - Class in org.elasticsearch.snapshots.mockstore
- MockScoreScript(MockDeterministicScript) - Constructor for class org.elasticsearch.script.MockScriptEngine.MockScoreScript
- 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<String, Function<Map<String, Object>, Object>>, Map<ScriptContext<?>, MockScriptEngine.ContextCompiler>) - 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.MockMetricAggCombineScriptFactory - Class in org.elasticsearch.script
- MockScriptEngine.MockMetricAggInitScript - Class in org.elasticsearch.script
- MockScriptEngine.MockMetricAggInitScriptFactory - Class in org.elasticsearch.script
- MockScriptEngine.MockMetricAggMapScript - Class in org.elasticsearch.script
- MockScriptEngine.MockMetricAggMapScriptFactory - Class in org.elasticsearch.script
- MockScriptEngine.MockMetricAggReduceScript - Class in org.elasticsearch.script
- MockScriptEngine.MockMetricAggReduceScriptFactory - Class in org.elasticsearch.script
- MockScriptEngine.MockScoreScript - 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
- MockScriptService - Class in org.elasticsearch.script
- MockScriptService(Settings, Map<String, ScriptEngine>, Map<String, ScriptContext<?>>) - Constructor for class org.elasticsearch.script.MockScriptService
- MockScriptService.TestPlugin - Class in org.elasticsearch.script
-
Marker plugin used by
MockNode
to enableMockScriptService
. - MockSearchService - Class in org.elasticsearch.search
- MockSearchService(ClusterService, IndicesService, ThreadPool, ScriptService, BigArrays, FetchPhase, ResponseCollectorService, CircuitBreakerService, ExecutorSelector) - Constructor for class org.elasticsearch.search.MockSearchService
- MockSearchService.TestPlugin - Class in org.elasticsearch.search
-
Marker plugin used by
MockNode
to enableMockSearchService
. - 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
- MockSinglePrioritizingExecutor - Class in org.elasticsearch.cluster.coordination
-
Mock single threaded
PrioritizedEsThreadPoolExecutor
based onDeterministicTaskQueue
, simulating the behaviour of an executor returned byEsExecutors.newSinglePrioritizing(java.lang.String, java.util.concurrent.ThreadFactory, org.elasticsearch.common.util.concurrent.ThreadContext, java.util.concurrent.ScheduledExecutorService, org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.StarvationWatcher)
. - MockSinglePrioritizingExecutor(String, DeterministicTaskQueue, ThreadPool) - Constructor for class org.elasticsearch.cluster.coordination.MockSinglePrioritizingExecutor
- 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
- 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
- MockTransport - Class in org.elasticsearch.test.transport
-
A basic transport implementation that allows to intercept requests that have been sent
- MockTransport() - Constructor for class org.elasticsearch.test.transport.MockTransport
- MockTransportClient - Class in org.elasticsearch.transport
-
Deprecated.
- MockTransportClient(Settings, Class<? extends Plugin>...) - Constructor for class org.elasticsearch.transport.MockTransportClient
-
Deprecated.
- MockTransportClient(Settings, Collection<Class<? extends Plugin>>) - Constructor for class org.elasticsearch.transport.MockTransportClient
-
Deprecated.
- MockTransportClient(Settings, Collection<Class<? extends Plugin>>, TransportClient.HostFailureListener) - Constructor for class org.elasticsearch.transport.MockTransportClient
-
Deprecated.
- 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
- 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
- multipleValuesScript() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- mustReduceOnSingleInternalAgg() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase.InternalAggCardinality
- 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.PatternSeenEventExpectation
- name() - Method in class org.elasticsearch.cluster.DiskUsageIntegTestCase.TestFileStore
- NAME - Static variable in class org.elasticsearch.script.MockScriptEngine
- NAME - Static variable in class org.elasticsearch.script.MockScriptPlugin
- NamedFormatter - Class in org.elasticsearch.common.util
-
A formatter that allows named placeholders e.g.
- 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.
- nestedParsedDocFactory() - Static method in class org.elasticsearch.index.engine.EngineTestCase
- Network - Annotation Interface 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.
- 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) theNetworkDisruption.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.NetworkLinkDisruptionType - Class in org.elasticsearch.test.disruption
-
Abstract class representing various types of network disruptions.
- NetworkDisruption.TwoPartitions - Class in org.elasticsearch.test.disruption
-
Creates two partitions with symmetric failures
- NetworkLinkDisruptionType() - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.NetworkLinkDisruptionType
- newAnalysisSettingsBuilder() - Method in class org.elasticsearch.test.ESTokenStreamTestCase
- newBlobStore() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- newBlobStore(String) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- newByteArray(long, boolean) - Method in class org.elasticsearch.common.util.MockBigArrays
- 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) - Method in class org.elasticsearch.node.MockNode
- newCommand() - Method in class org.elasticsearch.cli.CommandTestCase
-
Creates a Command to test execution.
- newDirectory(IndexSettings, ShardPath) - Method in class org.elasticsearch.test.store.MockFSDirectoryFactory
- newDoubleArray(long, boolean) - Method in class org.elasticsearch.common.util.MockBigArrays
- newEnvironment() - Method in class org.elasticsearch.test.ESTestCase
- newEnvironment(Settings) - Static method in class org.elasticsearch.env.TestEnvironment
- newEnvironment(Settings) - Method in class org.elasticsearch.test.ESTestCase
- newFactory(Map<String, Object>, Map<String, Object>, SearchLookup) - Method in class org.elasticsearch.script.MockScriptEngine.MockMetricAggMapScriptFactory
- newFactory(Map<String, Object>, SearchLookup) - Method in class org.elasticsearch.script.MockScriptEngine.MockScoreScript
- newFakeTcpTransportChannel(String, TcpChannel, ThreadPool, String, long, Version) - Static method in class org.elasticsearch.transport.TestTransportChannels
- newFloatArray(long, boolean) - Method in class org.elasticsearch.common.util.MockBigArrays
- newGet(boolean, ParsedDocument) - Method in class org.elasticsearch.index.engine.EngineTestCase
- newHttpTransport(NetworkModule) - Method in class org.elasticsearch.node.MockNode
- 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() - Static method in class org.elasticsearch.indices.TestIndexNameExpressionResolver
- 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(Map<String, Object>, List<Object>) - Method in class org.elasticsearch.script.MockScriptEngine.MockMetricAggReduceScriptFactory
- newInstance(Map<String, Object>, Map<String, Object>) - Method in class org.elasticsearch.script.MockScriptEngine.MockMetricAggCombineScriptFactory
- newInstance(Map<String, Object>, Map<String, Object>) - Method in class org.elasticsearch.script.MockScriptEngine.MockMetricAggInitScriptFactory
- newInstance(LeafReaderContext) - Method in class org.elasticsearch.script.MockScriptEngine.MockMetricAggMapScript
- newInstance(ThreadContext) - Static method in class org.elasticsearch.indices.TestIndexNameExpressionResolver
- newInstance(SystemIndices) - Static method in class org.elasticsearch.indices.TestIndexNameExpressionResolver
- newInstance(DocReader) - Method in class org.elasticsearch.script.MockScriptEngine.MockFilterScript
- 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<DiscoveryNodeRole>) - 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
- newReader(IndexReader) - Method in class org.elasticsearch.test.engine.MockEngineSupport
- newReadWriteEngine(EngineConfig) - Method in class org.elasticsearch.test.engine.MockEngineFactory
- newScriptService(Settings, Map<String, ScriptEngine>, Map<String, ScriptContext<?>>) - Method in class org.elasticsearch.node.MockNode
- newSearchService(ClusterService, IndicesService, ThreadPool, ScriptService, BigArrays, FetchPhase, ResponseCollectorService, CircuitBreakerService, ExecutorSelector) - 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, CheckedFunction<DirectoryReader, DirectoryReader, IOException>, EngineFactory, Runnable, RetentionLeaseSyncer, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
creates a new initializing shard.
- newShard(ShardRouting, IndexMetadata, CheckedFunction<DirectoryReader, DirectoryReader, IOException>, EngineFactory, 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, Settings, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
- newShard(ShardRouting, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
- newShard(ShardRouting, ShardPath, IndexMetadata, CheckedFunction<IndexSettings, Store, IOException>, CheckedFunction<DirectoryReader, DirectoryReader, IOException>, EngineFactory, Runnable, RetentionLeaseSyncer, IndexEventListener, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
creates a new initializing shard.
- newShard(ShardId, boolean, String, IndexMetadata, CheckedFunction<DirectoryReader, DirectoryReader, IOException>) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
creates a new initializing shard.
- newShard(ShardId, boolean, String, IndexMetadata, CheckedFunction<DirectoryReader, DirectoryReader, IOException>, 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(Settings) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
Creates a new empty shard 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.
- 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
- nextNodeIndex - Variable in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- nextState(Object, Object, Object) - Method in interface org.elasticsearch.cluster.coordination.LinearizabilityChecker.SequentialSpec
-
Next-state function, checking whether transitioning the datatype in the given state under the provided input and output is valid.
- 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.
- NODE_ID_LOG_CONTEXT_KEY - Static variable in class org.elasticsearch.common.util.concurrent.DeterministicTaskQueue
- 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.StubbableConnectionManager
- nodeEnvironments - Variable in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- nodeId() - Method in class org.elasticsearch.common.logging.JsonLogLine
- NodeMocksPlugin - Class in org.elasticsearch.node
- NodeMocksPlugin() - Constructor for class org.elasticsearch.node.NodeMocksPlugin
- nodeName() - Method in class org.elasticsearch.common.logging.JsonLogLine
- nodeNameMatcher() - Method in class org.elasticsearch.common.logging.JsonLogsIntegTestCase
-
The node name to expect in the log file.
- nodePlugins() - Method in class org.elasticsearch.cluster.DiskUsageIntegTestCase
- nodePlugins() - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- 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
- nodePlugins(String) - Method in class org.elasticsearch.test.AbstractMultiClustersTestCase
- NodeRoles - Class in org.elasticsearch.test
-
Utility methods for creating
Settings
instances defining a set ofDiscoveryNodeRole
. - NodeRoles() - Constructor for class org.elasticsearch.test.NodeRoles
- 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.repositories.AbstractThirdPartyRepositoryTestCase
- nodeSettings() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
Additional settings to add when creating the node.
- nodeSettings(int, Settings) - Method in class org.elasticsearch.cluster.DiskUsageIntegTestCase
- nodeSettings(int, Settings) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- nodeSettings(int, Settings) - Method in class org.elasticsearch.test.ESIntegTestCase
-
This method is used to obtain settings for the
N
th node in the cluster. - nodeSettings(int, Settings) - Method in class org.elasticsearch.test.NodeConfigurationSource
-
The settings for the node represented by the given ordinal, or null if there are no settings defined.
- 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
- nonDataNode() - Static method in class org.elasticsearch.test.NodeRoles
- nonDataNode(Settings) - Static method in class org.elasticsearch.test.NodeRoles
- nonDeterministicPluginScripts() - Method in class org.elasticsearch.script.MockScriptPlugin
- nonIngestNode() - Static method in class org.elasticsearch.test.NodeRoles
- nonIngestNode(Settings) - Static method in class org.elasticsearch.test.NodeRoles
- nonMasterClient() - Method in class org.elasticsearch.test.InternalTestCluster
-
Returns a node client to random node but not the master.
- nonMasterNode() - Static method in class org.elasticsearch.test.NodeRoles
- nonMasterNode(Settings) - Static method in class org.elasticsearch.test.NodeRoles
- nonRemoteClusterClientNode() - Static method in class org.elasticsearch.test.NodeRoles
- nonRemoteClusterClientNode(Settings) - Static method in class org.elasticsearch.test.NodeRoles
- nonRootDocuments() - Method in class org.elasticsearch.index.mapper.TestDocumentParserContext
- 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
. - noOpConfig(IndexSettings, Store, Path) - Method in class org.elasticsearch.index.engine.EngineTestCase
- noOpConfig(IndexSettings, Store, Path, LongSupplier) - Method in class org.elasticsearch.index.engine.EngineTestCase
- NoOpNodeClient - Class in org.elasticsearch.test.client
-
Client that always response with
null
to every request. - NoOpNodeClient(String) - Constructor for class org.elasticsearch.test.client.NoOpNodeClient
-
Create a new
TestThreadPool
for this client. - NoOpNodeClient(ThreadPool) - Constructor for class org.elasticsearch.test.client.NoOpNodeClient
-
Build with
ThreadPool
. - Norms - Enum constant in enum class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
- noRoles() - Static method in class org.elasticsearch.test.NodeRoles
- noRoles(Settings) - Static method in class org.elasticsearch.test.NodeRoles
- NOT_SUPPORTED - Enum constant in enum class 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.AbstractSchemaValidationTestCase
- NUMBER_OF_TEST_RUNS - Static variable in class org.elasticsearch.test.AbstractWireTestCase
- NUMBER_OF_TEST_RUNS - Static variable in class org.elasticsearch.test.AbstractXContentTestCase
- numberOfFiles(Path) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- 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() - Element in annotation interface 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() - Element in annotation interface 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 - Enum constant in enum class 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
- objectMappers() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
ObjectMapper
s to add to the lookup. - 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
- OLD_VERSION_SNAPSHOT_PREFIX - Static variable in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- onAllNodesStopped() - Method in class org.elasticsearch.test.InternalTestCluster.RestartCallback
- onBlackholedDuringSend(long, String, DisruptableMockTransport) - Method in class org.elasticsearch.test.disruption.DisruptableMockTransport
- onBlockDetected(ThreadInfo, ThreadInfo) - Method in class org.elasticsearch.test.disruption.LongGCDisruption
- onConnectedDuringSend(long, String, TransportRequest, DisruptableMockTransport) - Method in class org.elasticsearch.test.disruption.DisruptableMockTransport
- onDisconnectedDuringSend(long, String, DisruptableMockTransport) - Method in class org.elasticsearch.test.disruption.DisruptableMockTransport
- onIndexModule(IndexModule) - Method in class org.elasticsearch.test.MockIndexEventListener.TestPlugin
- onIndexModule(IndexModule) - Method in class org.elasticsearch.test.store.MockFSIndexStore.TestPlugin
- onlyRole(DiscoveryNodeRole) - Static method in class org.elasticsearch.test.NodeRoles
- onlyRole(Settings, DiscoveryNodeRole) - Static method in class org.elasticsearch.test.NodeRoles
- onlyRoles(Set<DiscoveryNodeRole>) - Static method in class org.elasticsearch.test.NodeRoles
- onlyRoles(Settings, Set<DiscoveryNodeRole>) - Static method in class org.elasticsearch.test.NodeRoles
- onNodeLog(DiscoveryNode, Runnable) - Static method in class org.elasticsearch.common.util.concurrent.DeterministicTaskQueue
- 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
- onSendRequest(long, String, TransportRequest, DiscoveryNode) - Method in class org.elasticsearch.test.transport.MockTransport
- onSendRequest(long, String, TransportRequest, DisruptableMockTransport) - Method in class org.elasticsearch.test.disruption.DisruptableMockTransport
- 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, ActionListener<Transport.Connection>) - Method in class org.elasticsearch.test.disruption.DisruptableMockTransport
- openConnection(DiscoveryNode, ConnectionProfile, ActionListener<Transport.Connection>) - Method in class org.elasticsearch.test.transport.FakeTransport
- openConnection(DiscoveryNode, ConnectionProfile, ActionListener<Transport.Connection>) - Method in class org.elasticsearch.test.transport.StubbableConnectionManager
- 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
- openPersistedStates - Variable in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- openReader(Path) - Method in class org.elasticsearch.common.logging.JsonLogsIntegTestCase
-
Open the log file.
- OPTIONAL - Enum constant in enum class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Body
- OptionalMatchers - Class in org.elasticsearch.test.hamcrest
- OptionalMatchers() - Constructor for class org.elasticsearch.test.hamcrest.OptionalMatchers
- org.elasticsearch.action.admin.indices.recovery - package org.elasticsearch.action.admin.indices.recovery
- org.elasticsearch.action.support - package org.elasticsearch.action.support
- 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.metadata - package org.elasticsearch.cluster.metadata
- org.elasticsearch.cluster.routing - package org.elasticsearch.cluster.routing
- org.elasticsearch.cluster.service - package org.elasticsearch.cluster.service
- org.elasticsearch.common.breaker - package org.elasticsearch.common.breaker
- org.elasticsearch.common.bytes - package org.elasticsearch.common.bytes
- org.elasticsearch.common.inject - package org.elasticsearch.common.inject
- org.elasticsearch.common.logging - package org.elasticsearch.common.logging
- org.elasticsearch.common.lucene.store - package org.elasticsearch.common.lucene.store
- org.elasticsearch.common.settings - package org.elasticsearch.common.settings
- org.elasticsearch.common.util - package org.elasticsearch.common.util
- org.elasticsearch.common.util.concurrent - package org.elasticsearch.common.util.concurrent
- org.elasticsearch.core - package org.elasticsearch.core
- org.elasticsearch.env - package org.elasticsearch.env
- org.elasticsearch.gateway - package org.elasticsearch.gateway
- org.elasticsearch.geo - package org.elasticsearch.geo
- 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.seqno - package org.elasticsearch.index.seqno
- 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 - package org.elasticsearch.indices
- org.elasticsearch.indices.analysis - package org.elasticsearch.indices.analysis
- org.elasticsearch.indices.recovery - package org.elasticsearch.indices.recovery
- 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.azure - package org.elasticsearch.repositories.azure
- 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.search.geo - package org.elasticsearch.search.geo
- org.elasticsearch.snapshots - package org.elasticsearch.snapshots
- org.elasticsearch.snapshots.mockstore - package org.elasticsearch.snapshots.mockstore
- org.elasticsearch.tasks - package org.elasticsearch.tasks
- org.elasticsearch.test - package org.elasticsearch.test
- org.elasticsearch.test.client - package org.elasticsearch.test.client
- 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.transport.nio - package org.elasticsearch.transport.nio
- org.elasticsearch.upgrades - package org.elasticsearch.upgrades
- os() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestExecutionContext
- overwriteEsVersion(Version) - Method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
-
Allows test suites to return another version then the lowest version returned from the cat node api.
P
- PAGE_SIZE - Static variable in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
- ParameterChecker() - Constructor for class org.elasticsearch.index.mapper.MapperTestCase.ParameterChecker
- ParameterChecker() - Constructor for class org.elasticsearch.index.mapper.MetadataMapperTestCase.ParameterChecker
- 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) - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
- 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.CloseToAssertion
- 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(DocumentParserContext) - 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
- parseQuery(String) - Method in class org.elasticsearch.test.AbstractQueryTestCase
- parseQuery(XContentParser) - Method in class org.elasticsearch.test.AbstractQueryTestCase
- parseQuery(AbstractQueryBuilder<?>) - Method in class org.elasticsearch.test.AbstractQueryTestCase
- parser() - Method in class org.elasticsearch.index.mapper.TestDocumentParserContext
- PARSER - Static variable in class org.elasticsearch.common.logging.JsonLogLine
- partition(List<LinearizabilityChecker.Event>) - Method in interface org.elasticsearch.cluster.coordination.LinearizabilityChecker.KeyedSpec
- partition(List<LinearizabilityChecker.Event>) - Method in interface org.elasticsearch.cluster.coordination.LinearizabilityChecker.SequentialSpec
-
For compositional checking, the history can be partitioned into sub-histories
- PASSWORD_SETTING - Static variable in class org.elasticsearch.snapshots.mockstore.MockRepository.Plugin
- path() - Method in class org.elasticsearch.index.mapper.TestDocumentParserContext
- PathUtilsForTesting - Class in org.elasticsearch.core
-
Exposes some package private stuff in PathUtils for framework purposes only!
- PathUtilsForTesting() - Constructor for class org.elasticsearch.core.PathUtilsForTesting
- pattern - Variable in class org.elasticsearch.test.MockLogAppender.PatternSeenEventExpectation
- PatternSeenEventExpectation(String, String, Level, String) - Constructor for class org.elasticsearch.test.MockLogAppender.PatternSeenEventExpectation
- pauseIndexing() - Method in class org.elasticsearch.test.BackgroundIndexer
-
Pausing indexing by setting current document limit to 0
- performOnPrimary(IndexShard, Request, ActionListener<ESIndexLevelReplicationTestCase.ReplicationAction.PrimaryResult>) - 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
- performSyncedFlush(String, boolean) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- Plugin() - Constructor for class org.elasticsearch.snapshots.mockstore.MockRepository.Plugin
- 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.
- plugins() - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
-
Plugins to add to the test.
- 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 fromESIntegTestCase.indexSettings()
. - prepareCreate(String, int) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Creates a new
CreateIndexRequestBuilder
with the settings obtained fromESIntegTestCase.indexSettings()
. - prepareCreate(String, int, Settings.Builder) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Creates a new
CreateIndexRequestBuilder
with the settings obtained fromESIntegTestCase.indexSettings()
. - prepareCreate(String, Settings.Builder) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Creates a new
CreateIndexRequestBuilder
with the settings obtained fromESIntegTestCase.indexSettings()
, augmented by the given builder - prepareForTranslogOperations(int, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.AsyncRecoveryTarget
- prepareSearch(String...) - Method in class org.elasticsearch.test.client.RandomizingClient
- preProcess(boolean) - Method in class org.elasticsearch.test.TestSearchContext
- preserveAutoFollowPatternsUponCompletion() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Returns whether to preserve auto-follow patterns.
- 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.
- preserveDataStreamsUponCompletion() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Determines if data streams are preserved upon completion of this test.
- preserveDataStreamsUponCompletion() - Method in class org.elasticsearch.upgrades.AbstractFullClusterRestartTestCase
- 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
- preserveILMPolicyIds() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
A set of ILM policies that should be preserved between runs.
- 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
- preserveSearchableSnapshotsIndicesUponCompletion() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Returns whether to preserve searchable snapshots indices.
- preserveSLMPoliciesUponCompletion() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Returns whether to preserve SLM Policies of this test.
- preserveSLMPoliciesUponCompletion() - 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
- PRIVATE - Enum constant in enum class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Visibility
- processRecoverySettings(ClusterSettings, RecoverySettings) - Method in class org.elasticsearch.node.MockNode
- profileBoundAddresses() - Method in class org.elasticsearch.test.transport.FakeTransport
- 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
- PROVIDED_NAME_SETTING - Static variable in class org.elasticsearch.test.InternalSettingsPlugin
- PUBLIC - Enum constant in enum class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Visibility
- publish(ClusterChangedEvent, MasterService.TaskOutputs, long) - Method in class org.elasticsearch.cluster.service.FakeThreadPoolMasterService
- putReaderContext(ReaderContext) - Method in class org.elasticsearch.search.MockSearchService
Q
- query() - Method in class org.elasticsearch.test.TestSearchContext
- queryCollectors() - Method in class org.elasticsearch.test.TestSearchContext
- queryResult() - Method in class org.elasticsearch.test.TestSearchContext
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
-
Delays requests by a random but fixed time value between
NetworkDisruption.NetworkDelay.DEFAULT_DELAY_MIN
andNetworkDisruption.NetworkDelay.DEFAULT_DELAY_MAX
. - 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.MockFSDirectoryFactory
- RANDOM_IO_EXCEPTION_RATE_SETTING - Static variable in class org.elasticsearch.test.store.MockFSDirectoryFactory
- RANDOM_SNAPSHOT_NAME_PREFIX - Static variable in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- 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
- randomAliasInstance() - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- 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
- randomAlt() - Static method in class org.elasticsearch.geo.GeometryTestUtils
- 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
- randomBigInteger() - Static method in class org.elasticsearch.test.ESTestCase
-
Returns a random BigInteger uniformly distributed over the range 0 to (2^64 - 1) inclusive Currently BigIntegers are only used for unsigned_long field type, where the max value is 2^64 - 1.
- randomBlobContent() - Static method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- randomBlobContent(int) - Static method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- 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.blobstore.ESBlobStoreRepositoryIntegTestCase
- randomCircle(boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomClusterSettings() - Static method in class org.elasticsearch.http.AbstractHttpServerTransportTestCase
- 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
. - randomDate() - Method in class org.elasticsearch.test.AbstractSerializingTestCase
- randomDateFormatterPattern() - Static method in class org.elasticsearch.test.ESTestCase
-
Generate a random valid date formatter pattern.
- 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.
- randomFetchTestFieldConfig(XContentBuilder) - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
- randomFetchTestFieldConfig(XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
Field configuration for
MapperTestCase.testFetch()
andMapperTestCase.testFetchMany()
. - randomFetchTestFormat() - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
A random format to use when tripping in
MapperTestCase.testFetch()
andMapperTestCase.testFetchMany()
. - randomFetchTestMapper() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- 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.
- randomFileExtension() - Static method in class org.elasticsearch.common.lucene.store.ESIndexInputTestCase
- 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
- randomGeometry(boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomGeometry(int, boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomGeometry(ShapeType, boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomGeometryCollection(boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomGeometryCollectionWithoutCircle(boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomGeometryWithoutCircle(int, boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomIndexCompatibleVersion(Random) - Static method in class org.elasticsearch.test.VersionUtils
-
Returns a random version index compatible with the current version.
- randomIndexInstances() - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- randomIndexOptions() - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- randomIndexSettings() - Static method in class org.elasticsearch.index.RandomCreateIndexGenerator
-
Returns a
Settings
instance which include random values forIndexMetadata.SETTING_NUMBER_OF_SHARDS
andIndexMetadata.SETTING_NUMBER_OF_REPLICAS
- 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
- randomInstance() - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- randomInstance(String) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- randomInstance(String, LongSupplier) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- randomInstance(LongSupplier) - Static method in class org.elasticsearch.cluster.metadata.DataStreamTestHelper
- randomInstant() - Method in class org.elasticsearch.test.AbstractSerializingTestCase
- 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
tomax
(inclusive). - randomIp(boolean) - Static method in class org.elasticsearch.test.ESTestCase
- 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
- randomLat() - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomLeafFieldName(Random) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
-
Returns a random leaf field name.
- randomLine(boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomList(int, int, Supplier<T>) - Static method in class org.elasticsearch.test.ESTestCase
- randomList(int, Supplier<T>) - Static method in class org.elasticsearch.test.ESTestCase
- randomLon() - Static method in class org.elasticsearch.geo.GeometryTestUtils
- 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
- randomMap(int, int, Supplier<Tuple<K, V>>) - Static method in class org.elasticsearch.test.ESTestCase
- 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
- randomMillisUpToYear9999() - Method in class org.elasticsearch.test.ESTestCase
-
generate a random epoch millis in a range 1 to 9999-12-31T23:59:59.999
- randomMinimumShouldMatch() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
- randomMockContext() - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
- randomMultiLine(boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomMultiPoint(boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomMultiPolygon(boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomName() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- randomNonNegativeByte() - Static method in class org.elasticsearch.test.ESTestCase
- 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
- randomNumericField() - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
- RandomObjects - Class in org.elasticsearch.test
- randomPipelineAggregators() - Static method in class org.elasticsearch.test.InternalAggregationTestCase
- randomPipelineTree(InternalAggregation) - Static method in class org.elasticsearch.test.InternalAggregationTestCase
- randomPoint() - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomPoint(boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomPolygon(boolean) - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomPositiveTimeValue() - Static method in class org.elasticsearch.test.ESTestCase
- randomReadAndSlice(IndexInput, int) - Method in class org.elasticsearch.common.lucene.store.ESIndexInputTestCase
-
Reads the contents of an
IndexInput
fromindexInput.getFilePointer()
tolength
using a wide variety of different access methods. - randomReaderWrapper() - Static method in class org.elasticsearch.index.engine.EngineTestCase
- 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
- randomRectangle() - Static method in class org.elasticsearch.geo.GeometryTestUtils
- randomRepoPath() - 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
- 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
- randomRepositoryName() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- randomRepositorySettings() - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- randomResultsToReduce(String, int) - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
Generate a list of inputs to reduce.
- randomRouting() - Static method in class org.elasticsearch.index.alias.RandomAliasActionsGenerator
- randomSearcherWrapper() - Static method in class org.elasticsearch.index.engine.EngineTestCase
- randomSearchRequest(Supplier<SearchSourceBuilder>) - Static method in class org.elasticsearch.search.RandomSearchRequestGenerator
-
Build a random search request.
- RandomSearchRequestGenerator - Class in org.elasticsearch.search
-
Builds random search requests.
- randomSearchSourceBuilder(Supplier<HighlightBuilder>, Supplier<SuggestBuilder>, Supplier<RescorerBuilder<?>>, Supplier<List<SearchExtBuilder>>, Supplier<CollapseBuilder>, Supplier<Map<String, Object>>) - 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 aToXContent
and parsed back using a parsing method likeReplicationResponse.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 aToXContent
and parsed back using a parsing method likeReplicationResponse.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 viaXContentParser.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, or the full original 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
- randomToken(Random) - Static method in class org.elasticsearch.test.RandomObjects
- randomUnassignedInfo(String) - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
- 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.
- randomUserMetadata() - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
-
Randomly either generates some random snapshot user metadata or returns
null
. - 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
betweenminVersion
andmaxVersion
(inclusive). - randomZone() - Static method in class org.elasticsearch.test.ESTestCase
-
generate a random TimeZone from the ones available in java.time
- rangeField(String, RangeType) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Make a NumberFieldMapper.NumberFieldType for a
range
. - read() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase.ZeroInputStream
- read(byte[], int, int) - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase.ZeroInputStream
- 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.blobstore.ESBlobStoreRepositoryIntegTestCase
- readDiffFrom(String, StreamInput) - Static method in class org.elasticsearch.test.TestCustomMetadata
- readerContext() - Method in class org.elasticsearch.test.TestSearchContext
- readException(SocketChannelContext, Exception) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- readFrom(Function<String, T>, StreamInput) - Static method in class org.elasticsearch.test.TestCustomMetadata
- readSecret(String) - Method in class org.elasticsearch.cli.MockTerminal
- readText(String) - Method in class org.elasticsearch.cli.MockTerminal
- readTimeoutExceptionMatcher() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- reason() - Element in annotation interface org.elasticsearch.test.junit.annotations.TestLogging
-
The reason this annotation is used to control logger behavior during a test.
- receiveFileInfo(List<String>, List<Long>, List<String>, List<Long>, int, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.AsyncRecoveryTarget
- record() - Method in class org.elasticsearch.transport.LeakTracker.Leak
-
Adds an access record that includes the current stack trace to the leak.
- recoverFromStore(IndexShard) - Static method in class org.elasticsearch.index.shard.IndexShardTestCase
- 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
makingRecoverySettingsChunkSizePlugin.CHUNK_SIZE_SETTING
dynamic. - RecoverySettingsChunkSizePlugin() - Constructor for class org.elasticsearch.node.RecoverySettingsChunkSizePlugin
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase.InternalAggCardinality
- 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.
- refresh(InternalClusterInfoService) - Static method in class org.elasticsearch.cluster.ClusterInfoServiceUtils
- refreshAllIndices() - Method in class org.elasticsearch.test.rest.ESRestTestCase
- refreshClusterInfo() - Static method in class org.elasticsearch.test.ESIntegTestCase
- 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
- registerConflictCheck(String, XContentBuilder, XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperTestCase.ParameterChecker
-
Register a check that a parameter update will cause a conflict
- registerConflictCheck(String, XContentBuilder, XContentBuilder) - Method in class org.elasticsearch.index.mapper.MetadataMapperTestCase.ParameterChecker
-
Register a check that a parameter update will cause a conflict
- registerConflictCheck(String, CheckedConsumer<XContentBuilder, IOException>) - Method in class org.elasticsearch.index.mapper.MapperTestCase.ParameterChecker
-
Register a check that a parameter update will cause a conflict, using the minimal mapping as a base
- registerConflictCheck(String, CheckedConsumer<XContentBuilder, IOException>) - Method in class org.elasticsearch.index.mapper.MetadataMapperTestCase.ParameterChecker
-
Register a check that a parameter update will cause a conflict, using the minimal mapping as a base
- registerParameters(MapperTestCase.ParameterChecker) - Method in class org.elasticsearch.index.mapper.MapperTestCase
- registerParameters(MetadataMapperTestCase.ParameterChecker) - Method in class org.elasticsearch.index.mapper.MetadataMapperTestCase
- registerPlugin() - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
If a test needs to register additional aggregation specs for namedWriteable, etc, this method can be overridden by the implementor.
- registerRepository(String, String, boolean, Settings) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- registerRepository(RestClient, String, String, boolean, Settings) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- registerUpdateCheck(XContentBuilder, XContentBuilder, Consumer<DocumentMapper>) - Method in class org.elasticsearch.index.mapper.MetadataMapperTestCase.ParameterChecker
- registerUpdateCheck(CheckedConsumer<XContentBuilder, IOException>, Consumer<FieldMapper>) - Method in class org.elasticsearch.index.mapper.MapperTestCase.ParameterChecker
-
Register a check that a parameter can be updated, using the minimal mapping as a base
- registerUpdateCheck(CheckedConsumer<XContentBuilder, IOException>, CheckedConsumer<XContentBuilder, IOException>, Consumer<FieldMapper>) - Method in class org.elasticsearch.index.mapper.MapperTestCase.ParameterChecker
-
Register a check that a parameter can be updated
- registrationException(ChannelContext<?>, Exception) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- reinitPrimaryShard() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
- reinitShard(IndexShard, ShardRouting, IndexMetadata, 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
- remoteClusterAlias() - Method in class org.elasticsearch.test.AbstractMultiClustersTestCase
- remoteClusterClientNode() - Static method in class org.elasticsearch.test.NodeRoles
- remoteClusterClientNode(Settings) - Static method in class org.elasticsearch.test.NodeRoles
- remove(int) - Method in class org.elasticsearch.cluster.coordination.LinearizabilityChecker.History
-
Removes the events with the corresponding id from the history
- 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
- REMOVED_MINIMUM_MASTER_NODES - Static variable in class org.elasticsearch.test.InternalTestCluster
- removeDisruption(MockTransportService, MockTransportService) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkLinkDisruptionType
-
Removes network disruption that was added by
NetworkDisruption.NetworkLinkDisruptionType.applyDisruption(org.elasticsearch.test.transport.MockTransportService, org.elasticsearch.test.transport.MockTransportService)
. - removeFilesystemProvider() - Method in class org.elasticsearch.cluster.DiskUsageIntegTestCase
- 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
- removeHeaderWarningAppender() - Method in class org.elasticsearch.test.ESTestCase
- 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
- removeReaderContext(long) - Method in class org.elasticsearch.search.MockSearchService
- removeReplica(IndexShard) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
- removeRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
- removeRoles(Set<DiscoveryNodeRole>) - Static method in class org.elasticsearch.test.NodeRoles
- removeRoles(Settings, Set<DiscoveryNodeRole>) - Static method in class org.elasticsearch.test.NodeRoles
- renewRetentionLease(String, long, String) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
- 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
- reportLeak() - Method in class org.elasticsearch.transport.LeakTracker
- repositorySettings(String) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- repositoryType() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- repositoryType() - Method in class org.elasticsearch.repositories.blobstore.ESFsBasedRepositoryIntegTestCase
- 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 toSystem.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.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
- requestToString(RestRequest) - Static method in class org.elasticsearch.test.rest.FakeRestRequest
- requestUniqueId(HttpExchange) - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase.ErroneousHttpHandler
- REQUIRED - Enum constant in enum class 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.
- reset() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase.ZeroInputStream
- reset() - Method in class org.elasticsearch.test.rest.RestActionTestCase.VerifyingClient
-
Clears any previously set verifier functions set by
RestActionTestCase.VerifyingClient.setExecuteVerifier(java.util.function.BiFunction<org.elasticsearch.action.ActionType<R>, org.elasticsearch.action.ActionRequest, R>)
and/orRestActionTestCase.VerifyingClient.setExecuteLocallyVerifier(java.util.function.BiFunction<org.elasticsearch.action.ActionType<?>, org.elasticsearch.action.ActionRequest, org.elasticsearch.action.ActionResponse>)
. - 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. - resetNodeIndexBeforeEachTest() - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- resetPortCounter() - Static method in class org.elasticsearch.test.ESTestCase
- resetPortCounterBeforeEachTest() - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- 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
- resolveCustomDataPath(String) - Static method in class org.elasticsearch.test.ESIntegTestCase
- 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(int, Object) - Method in class org.elasticsearch.cluster.coordination.LinearizabilityChecker.History
-
Appends a new response event to the history
- 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
- RESPONSE - Enum constant in enum class org.elasticsearch.cluster.coordination.LinearizabilityChecker.EventType
- responseAsMap(Response) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- responses() - Method in class org.elasticsearch.test.rest.FakeRestChannel
- 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
- RestActionTestCase.VerifyingClient - Class in org.elasticsearch.test.rest
-
A mocked
NodeClient
which can be easily reconfigured to verify arbitrary verification functions, and can be reset to allow reconfiguration partway through a test without having to construct a new object. - 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) - Method in class org.elasticsearch.test.InternalTestCluster
-
Restarts a node.
- restartNode(String, InternalTestCluster.RestartCallback) - Method in class org.elasticsearch.test.InternalTestCluster
-
Restarts a node and calls the callback during restart.
- restartNodesOnBrokenClusterState(ClusterState.Builder) - Method in class org.elasticsearch.test.ESIntegTestCase
- 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.
- 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
- restoreFileFromSnapshot(String, IndexId, BlobStoreIndexShardSnapshot.FileInfo, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.AsyncRecoveryTarget
- 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
- restoreSnapshot(String, String, boolean) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- resumeThreads(Set<Thread>) - Method in class org.elasticsearch.test.disruption.LongGCDisruption
- RetentionLeaseUtils - Class in org.elasticsearch.index.seqno
- reuseClusters() - Method in class org.elasticsearch.test.AbstractMultiClustersTestCase
- 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(InternalTestCluster.RestartCallback) - Method in class org.elasticsearch.test.InternalTestCluster
-
Restarts all nodes in a rolling restart fashion ie.
- rootDoc() - Method in class org.elasticsearch.index.mapper.TestDocumentParserContext
- 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.common.util.concurrent.DeterministicTaskQueue
- runAllTasks() - Method in class org.elasticsearch.common.util.concurrent.DeterministicTaskQueue
- runAllTasksInTimeOrder() - Method in class org.elasticsearch.common.util.concurrent.DeterministicTaskQueue
- runPostReplicationActions(ActionListener<Void>) - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationAction.PrimaryResult
- runRandomly() - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase.Cluster
- runRandomly() - Method in class org.elasticsearch.cluster.coordination.CoordinationStateTestCluster
- runRandomTask() - Method in class org.elasticsearch.common.util.concurrent.DeterministicTaskQueue
-
Runs an arbitrary runnable task.
- runtimeFieldMapping(CheckedConsumer<XContentBuilder, IOException>) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- runtimeMapping(CheckedConsumer<XContentBuilder, IOException>) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
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)
- sawSlowSuspendBug() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
-
Checks if during disruption we ran into a known JVM issue that makes
Thread.suspend()
calls block for multiple seconds was observed. - 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.common.util.concurrent.DeterministicTaskQueue
-
Schedule a task for future execution.
- scheduleNow(Runnable) - Method in class org.elasticsearch.common.util.concurrent.DeterministicTaskQueue
-
Schedule a task for immediate execution.
- scope() - Element in annotation interface org.elasticsearch.test.ESIntegTestCase.ClusterScope
-
Returns the scope.
- ScoreAccessor - Class in org.elasticsearch.script
-
A float encapsulation that dynamically accesses the score of a document.
- ScoreAccessor(Scorable) - Constructor for class org.elasticsearch.script.ScoreAccessor
- script(String) - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- scriptFields() - Method in class org.elasticsearch.test.TestSearchContext
- scrollContext() - Method in class org.elasticsearch.test.TestSearchContext
- searchAfter() - Method in class org.elasticsearch.test.TestSearchContext
- searchAfter(FieldDoc) - Method in class org.elasticsearch.test.TestSearchContext
- searchAndReduce(IndexSearcher, Query, AggregationBuilder, int, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- searchAndReduce(IndexSearcher, Query, AggregationBuilder, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- searchAndReduce(IndexSettings, IndexSearcher, Query, AggregationBuilder, int, boolean, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Collects all documents that match the provided query
Query
and returns the reducedInternalAggregation
. - searchAndReduce(IndexSettings, IndexSearcher, Query, AggregationBuilder, int, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Collects all documents that match the provided query
Query
and returns the reducedInternalAggregation
. - searchAndReduce(IndexSettings, IndexSearcher, Query, AggregationBuilder, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- searcher() - Method in class org.elasticsearch.test.TestSearchContext
- SearcherHelper - Class in org.elasticsearch.index.shard
- SearcherHelper() - Constructor for class org.elasticsearch.index.shard.SearcherHelper
- 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
- sendIncompleteContent(HttpExchange, byte[]) - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- sendMessage(BytesReference, ActionListener<Void>) - Method in class org.elasticsearch.transport.FakeTcpChannel
- 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(Exception) - Method in class org.elasticsearch.transport.TestTransportChannel
- sendResponse(RestResponse) - Method in class org.elasticsearch.test.rest.FakeRestChannel
- sendResponse(TransportResponse) - Method in class org.elasticsearch.transport.TestTransportChannel
- seqNoAndPrimaryTerm() - Method in class org.elasticsearch.test.TestSearchContext
- seqNoAndPrimaryTerm(boolean) - Method in class org.elasticsearch.test.TestSearchContext
- serializableScript() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- serverUrl() - Static method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
- 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
- setBlockAndFailOnReadIndexFiles() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- setBlockAndFailOnReadSnapFiles() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- setBlockAndFailOnWriteIndexFile() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- setBlockAndFailOnWriteShardLevelMeta() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- setBlockAndFailOnWriteSnapFiles() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- setBlockAndOnWriteShardLevelSnapFiles(String) - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- setBlockOnAnyFiles() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- setBlockOnceOnReadSnapshotInfoIfAlreadyBlocked() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
-
Enable blocking a single read of
SnapshotInfo
in case the repo is already blocked on another file. - setBlockOnDeleteIndexFile() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- setBlockOnReadIndexMeta() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- setBlockOnWriteIndexFile() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- setBlockOnWriteShardLevelMeta() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- setBootstrapMasterNodeIndex(int) - Method in class org.elasticsearch.test.InternalTestCluster
-
Sets
InternalTestCluster.bootstrapMasterNodeIndex
to the given value, seeInternalTestCluster.bootstrapMasterNodeWithSpecifiedIndex(List)
for the description of how this field is used. - setCatch(String) - Method in class org.elasticsearch.test.rest.yaml.section.DoSection
- setClusterName(String) - Method in class org.elasticsearch.common.logging.JsonLogLine
- setClusterReadOnly(boolean) - Static method in class org.elasticsearch.test.ESIntegTestCase
-
Sets or unsets the cluster read_only mode
- setClusterUuid(String) - Method in class org.elasticsearch.common.logging.JsonLogLine
- setComponent(String) - Method in class org.elasticsearch.common.logging.JsonLogLine
- 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
- setDiskUsageFunctionAndRefresh(BiFunction<DiscoveryNode, FsInfo.Path, FsInfo.Path>) - Method in class org.elasticsearch.cluster.MockInternalClusterInfoService
- setDisruptionScheme(ServiceDisruptionScheme) - Method in class org.elasticsearch.test.ESIntegTestCase
- setDisruptionScheme(ServiceDisruptionScheme) - Method in class org.elasticsearch.test.InternalTestCluster
- setExecuteLocallyVerifier(BiFunction<ActionType<?>, ActionRequest, ActionResponse>) - Method in class org.elasticsearch.test.rest.RestActionTestCase.VerifyingClient
-
Sets the function that will be called when
RestActionTestCase.VerifyingClient.executeLocally(ActionType, ActionRequest, TaskListener)
is called. - setExecuteVerifier(BiFunction<ActionType<R>, ActionRequest, R>) - Method in class org.elasticsearch.test.rest.RestActionTestCase.VerifyingClient
-
Sets the function that will be called when
RestActionTestCase.VerifyingClient.doExecute(ActionType, ActionRequest, ActionListener)
is called. - setExecutionDelayVariabilityMillis(long) - Method in class org.elasticsearch.common.util.concurrent.DeterministicTaskQueue
- setExpectSeen() - Method in class org.elasticsearch.test.MockLogAppender.EventuallySeenEventExpectation
- setFailOnIndexLatest(boolean) - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- setFailReadsAfterUnblock(boolean) - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- setFailureAssertion(Consumer<Exception>) - Method in class org.elasticsearch.test.BackgroundIndexer
-
Set a consumer that can be used to run assertions on failures during indexing.
- setFeatureFlag(String) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
- setFile(String, byte[]) - Method in class org.elasticsearch.common.settings.MockSecureSettings
- setFileSystem() - Static method in class org.elasticsearch.test.ESTestCase
- setHeaderWarningAppender() - Method in class org.elasticsearch.test.ESTestCase
- setIgnoreIndexingFailures(boolean) - Method in class org.elasticsearch.test.BackgroundIndexer
- setLevel(String) - Method in class org.elasticsearch.common.logging.JsonLogLine
- setMaxNumberOfBuckets(int) - Method in class org.elasticsearch.test.InternalMultiBucketAggregationTestCase
- setMessage(String) - Method in class org.elasticsearch.common.logging.JsonLogLine
- setMessageListener(TransportMessageListener) - Method in class org.elasticsearch.test.transport.FakeTransport
- setMessageListener(TransportMessageListener) - Method in class org.elasticsearch.test.transport.MockTransport
- setMessageListener(TransportMessageListener) - Method in class org.elasticsearch.test.transport.StubbableTransport
- setNanoTimeOverride(long) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.MockAllocationService
- setNewDelegate(IndexEventListener) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
- setNodeId(String) - Method in class org.elasticsearch.common.logging.JsonLogLine
- setNodeName(String) - Method in class org.elasticsearch.common.logging.JsonLogLine
- setNodeSelector(NodeSelector) - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
-
Set the selector that decides which node can run this request.
- setOnCheckCancelled(Function<SearchShardTask, SearchShardTask>) - Method in class org.elasticsearch.search.MockSearchService
- setOnCreateSearchContext(Consumer<SearchContext>) - Method in class org.elasticsearch.search.MockSearchService
- setOnPutContext(Consumer<ReaderContext>) - Method in class org.elasticsearch.search.MockSearchService
- setOnShardOperation(TransportRecoveryAction, Runnable) - Static method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryActionHelper
-
Helper method for tests to call
TransportRecoveryAction.setOnShardOperation(java.lang.Runnable)
. - 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
- setRequestMimeTypes(List<String>) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
- setRequestTimeout(TimeValue) - Method in class org.elasticsearch.test.BackgroundIndexer
- setResponseMimeTypes(List<String>) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
- setSearcher(ContextIndexSearcher) - 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
- setShardSizeFunctionAndRefresh(Function<ShardRouting, Long>) - Method in class org.elasticsearch.cluster.MockInternalClusterInfoService
- setSize(int) - Method in class org.elasticsearch.test.TestSearchContext
- setStability(String) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
- setStacktrace(List<String>) - Method in class org.elasticsearch.common.logging.JsonLogLine
- 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(SearchShardTask) - Method in class org.elasticsearch.test.TestSearchContext
- setTimestamp(String) - Method in class org.elasticsearch.common.logging.JsonLogLine
- settings(Version) - Static method in class org.elasticsearch.test.ESTestCase
-
Return consistent index settings for the provided index version.
- SETTINGS - Static variable in class org.elasticsearch.index.mapper.MapperServiceTestCase
- setTotalSpace(long) - Method in class org.elasticsearch.cluster.DiskUsageIntegTestCase.TestFileStore
- setType(String) - Method in class org.elasticsearch.common.logging.JsonLogLine
- setup() - Static method in class org.elasticsearch.core.PathUtilsForTesting
-
Sets a new default filesystem for testing
- setUp() - Method in class org.elasticsearch.common.lucene.store.ESIndexInputTestCase
- setUp() - Method in class org.elasticsearch.index.engine.EngineTestCase
- setUp() - Method in class org.elasticsearch.index.shard.IndexShardTestCase
- setUp() - Method in class org.elasticsearch.repositories.AbstractThirdPartyRepositoryTestCase
- setUp() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- setUp() - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
-
Setup for the whole base test class.
- 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
- setUpHttpServer() - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
- SetupSection - Class in org.elasticsearch.test.rest.yaml.section
-
Represents a setup section.
- SetupSection(SkipSection, List<ExecutableSection>) - Constructor for class org.elasticsearch.test.rest.yaml.section.SetupSection
- 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
- setValue(ClusterState, int, long) - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- setValue(ClusterState, long) - Static method in class org.elasticsearch.cluster.coordination.CoordinationStateTestCluster
- setVisibility(String) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
- SHARD_TARGET - Static variable in class org.elasticsearch.test.TestSearchContext
- 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
- 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. - shutdown() - Method in class org.elasticsearch.threadpool.TestThreadPool
- shutdownNow() - Method in class org.elasticsearch.threadpool.TestThreadPool
- SINGLE_SHARD_NO_REPLICA - Static variable in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- singleContext(ScriptContext<T>, Function<String, T>, Map<String, StoredScriptSource>) - Static method in class org.elasticsearch.script.MockScriptService
- SingleNodeDisruption - Class in org.elasticsearch.test.disruption
- SingleNodeDisruption(Random) - Constructor for class org.elasticsearch.test.disruption.SingleNodeDisruption
- singleValueScript() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- size() - Method in class org.elasticsearch.cluster.coordination.LinearizabilityChecker.History
-
Returns the number of recorded events
- 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(String) - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
- 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 - an operating system (full name, including specific Linux distributions) that might show a certain behavior
- SkipSection(String, List<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
- SNAPSHOT_INFO_SERVICE_WITH_NO_SHARD_SIZES - Static variable in class org.elasticsearch.cluster.ESAllocationTestCase
- snapshotShard(IndexShard, Snapshot, Repository) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
Snapshot a shard using a given repository.
- snapshotShard(SnapshotShardContext) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- snapshotThreadPoolStats(String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- sort() - Method in class org.elasticsearch.test.TestSearchContext
- sort(SortAndFormats) - Method in class org.elasticsearch.test.TestSearchContext
- SortedDocValues - Enum constant in enum class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
- SortedSetDocValues - Enum constant in enum class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
- source() - Method in class org.elasticsearch.test.TestSearchContext
- source(String) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- source(String, CheckedConsumer<XContentBuilder, IOException>, String) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- source(String, CheckedConsumer<XContentBuilder, IOException>, String, Map<String, String>) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- source(CheckedConsumer<XContentBuilder, IOException>) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- 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
- stabilise() - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase.Cluster
- STABLE - Enum constant in enum class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Stability
- stacktrace() - Method in class org.elasticsearch.common.logging.JsonLogLine
- start() - Method in class org.elasticsearch.test.transport.StubbableTransport
- start(int) - Method in class org.elasticsearch.test.BackgroundIndexer
-
Start indexing
- start(Settings, NodeEnvironment, NamedXContentRegistry) - Method in class org.elasticsearch.gateway.MockGatewayMetaState
- startAll() - Method in class org.elasticsearch.index.replication.ESIndexLevelReplicationTestCase.ReplicationGroup
- startBreaking() - Method in class org.elasticsearch.common.breaker.TestCircuitBreaker
- startClusters() - Method in class org.elasticsearch.test.AbstractMultiClustersTestCase
- startCoordinatingOnlyNode(Settings) - Method in class org.elasticsearch.test.InternalTestCluster
- startDataNodeWithLargeSnapshotPool() - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- 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
- startDeleteSnapshot(String, String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- 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
- startForcingRejections() - Method in class org.elasticsearch.threadpool.TestThreadPool
- startFullSnapshot(String, String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- startFullSnapshot(String, String, boolean) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- startFullSnapshot(Logger, String, String, boolean) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- startFullSnapshotBlockedOnDataNode(String, String, String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- startHttpServer() - Static method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
- startInitializingShardsAndReroute(AllocationService, ClusterState) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
Mark all initializing shards as started, then perform a reroute (which may start some other shards initializing).
- startInitializingShardsAndReroute(AllocationService, ClusterState, String) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
Mark all initializing shards for the given index as started, then perform a reroute (which may start some other shards initializing).
- startInitializingShardsAndReroute(AllocationService, ClusterState, RoutingNode) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
Mark all initializing shards on the given node as started, then perform a reroute (which may start some other shards initializing).
- 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
- startShardsAndReroute(AllocationService, ClusterState, List<ShardRouting>) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
Mark the given shards as started, then perform a reroute (which may start some other shards initializing).
- startShardsAndReroute(AllocationService, ClusterState, ShardRouting...) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
Mark the given shards as started, then perform a reroute (which may start some other shards initializing).
- 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
- state(int, String[], int) - Static method in class org.elasticsearch.action.support.replication.ClusterStateCreationUtils
-
Creates cluster state with the given indices, each index containing #(numberOfPrimaries) started primary shards and no replicas.
- state(String, boolean, ShardRoutingState, ShardRoutingState...) - Static method in class org.elasticsearch.action.support.replication.ClusterStateCreationUtils
-
Creates cluster state with and index that has one shard and #(replicaStates) replicas
- state(String, int, int) - Static method in class org.elasticsearch.action.support.replication.ClusterStateCreationUtils
-
Creates cluster state with an index that has #(numberOfPrimaries) primary shards in the started state and no replicas.
- state(DiscoveryNode, DiscoveryNode, DiscoveryNode...) - Static method in class org.elasticsearch.action.support.replication.ClusterStateCreationUtils
-
Creates a cluster state where local node and master node can be specified
- stateWithActivePrimary(String, boolean, int) - Static method in class org.elasticsearch.action.support.replication.ClusterStateCreationUtils
-
Creates cluster state with and index that has one shard and as many replicas as numberOfReplicas.
- stateWithActivePrimary(String, boolean, int, int) - Static method in class org.elasticsearch.action.support.replication.ClusterStateCreationUtils
-
Creates cluster state with and index that has one shard and as many replicas as numberOfReplicas.
- stateWithAssignedPrimariesAndOneReplica(String, int) - Static method in class org.elasticsearch.action.support.replication.ClusterStateCreationUtils
-
Creates cluster state with several shards and one replica and all shards STARTED.
- stateWithAssignedPrimariesAndReplicas(String[], int, int) - Static method in class org.elasticsearch.action.support.replication.ClusterStateCreationUtils
-
Creates cluster state with several indexes, shards and replicas and all shards STARTED.
- stateWithNoShard() - Static method in class org.elasticsearch.action.support.replication.ClusterStateCreationUtils
-
Creates a cluster state with no index
- stats() - Method in class org.elasticsearch.test.MockHttpTransport
- stop() - Method in class org.elasticsearch.test.BackgroundIndexer
-
Stop all background threads but don't wait for ongoing indexing operations to finish *
- stop() - Method in class org.elasticsearch.test.transport.StubbableTransport
- stopAndAwaitStopped() - Method in class org.elasticsearch.test.BackgroundIndexer
-
Stop all background threads and wait for ongoing indexing operations to finish *
- stopBreaking() - Method in class org.elasticsearch.common.breaker.TestCircuitBreaker
- stopClusters() - Static method in class org.elasticsearch.test.AbstractMultiClustersTestCase
- 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
- stopForcingRejections() - Method in class org.elasticsearch.threadpool.TestThreadPool
- stopHttpServer() - Static method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
- stopInternal() - Method in class org.elasticsearch.transport.nio.MockNioTransport
- stopNode(String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- stopNode(String) - Method in class org.elasticsearch.test.InternalTestCluster
-
Stops a specific node in the cluster.
- 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.
- 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
- storeReplica - Variable in class org.elasticsearch.index.engine.EngineTestCase
- StreamsUtils - Class in org.elasticsearch.test
- StreamsUtils() - Constructor for class org.elasticsearch.test.StreamsUtils
- STRING_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
- StringMessageRequest(String) - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.StringMessageRequest
- StringMessageRequest(StreamInput) - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.StringMessageRequest
- StubbableConnectionManager - Class in org.elasticsearch.test.transport
- StubbableConnectionManager(ConnectionManager) - 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.RequestHandlingBehavior<Request extends org.elasticsearch.transport.TransportRequest> - 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 - Enum constant in enum class 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() - Element in annotation interface org.elasticsearch.test.ESIntegTestCase.ClusterScope
-
Indicates whether the cluster can have dedicated master nodes.
- supportsMeta() - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
Override to disable testing
meta
in fields that don't support it. - 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.
- supportsSearchLookup() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- supportsStoredFields() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- supportsUnknownFields() - Method in class org.elasticsearch.test.AbstractBroadcastResponseTestCase
- supportsUnknownFields() - Method in class org.elasticsearch.test.AbstractSerializingTestCase
-
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
- TaskAssertions - Class in org.elasticsearch.test
- TaskCancelHelper - Class in org.elasticsearch.tasks
-
Helper class to expose
CancellableTask.cancel(java.lang.String)
for use in tests. - taskException(Exception) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- teardown() - Static method in class org.elasticsearch.core.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.repositories.AbstractThirdPartyRepositoryTestCase
- tearDown() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- 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
- tearDownController() - Method in class org.elasticsearch.test.rest.RestActionTestCase
- tearDownHttpServer() - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
- 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 - Enum constant in enum class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
- TermsEnum - Enum constant in enum class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
- TermVectors - Enum constant in enum class 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 - Enum constant in enum class org.elasticsearch.test.ESIntegTestCase.Scope
-
A test exclusive test cluster
- TEST_CLUSTER_NODE_PREFIX - Static variable in class org.elasticsearch.test.ESIntegTestCase
- TEST_WORKER_SYS_PROPERTY - Static variable in class org.elasticsearch.test.ESTestCase
- TEST_WORKER_VM_ID - Static variable in class org.elasticsearch.test.ESTestCase
- testAcceptedChannelCount() - 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
- testAssertions() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
-
Testing heuristic specific assertions Typically, this method would call either
AbstractSignificanceHeuristicTestCase.testBackgroundAssertions(SignificanceHeuristic, SignificanceHeuristic)
orAbstractSignificanceHeuristicTestCase.testAssertions(SignificanceHeuristic)
depending on which was appropriate - testAssertions(SignificanceHeuristic) - Method in class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
- testBackgroundAssertions(SignificanceHeuristic, SignificanceHeuristic) - Method in class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
- testBasicEquals() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
- testBasicScoreProperties() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractNXYSignificanceHeuristicTestCase
- testBasicScoreProperties() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
- testBasicScoreProperties(SignificanceHeuristic, boolean) - Method in class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
- testBindUnavailableAddress() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testCacheability() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Check that a query is generally cacheable.
- testCannotIndexDirectlyIntoScriptMapper() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- testCase(T, Query, CheckedConsumer<RandomIndexWriter, IOException>, Consumer<V>, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- testChannelCloseWhileConnecting() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testCharFilters() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
- TestCircuitBreaker - Class in org.elasticsearch.common.breaker
- TestCircuitBreaker() - Constructor for class org.elasticsearch.common.breaker.TestCircuitBreaker
- testCleanup() - Method in class org.elasticsearch.repositories.AbstractThirdPartyRepositoryTestCase
- 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.blobstore.ESBlobStoreRepositoryIntegTestCase
- testContainsShapeQuery() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- testCopyBytesRefSharesBytes() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
- testCopyToNotPermitted() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- testCreateSnapshot() - Method in class org.elasticsearch.repositories.AbstractThirdPartyRepositoryTestCase
- 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
- testDeleteBlobs() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- testDeprecatedBoost() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- 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
- testDistanceQuery() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- testDocument() - Static method in class org.elasticsearch.index.engine.EngineTestCase
- TestDocumentParserContext - Class in org.elasticsearch.index.mapper
-
Simplified version of
DocumentParserContext
to be used in tests. - TestDocumentParserContext(IndexSettings) - Constructor for class org.elasticsearch.index.mapper.TestDocumentParserContext
-
The shortest and easiest way to create a context, to be used when none of the constructor arguments are needed besides
IndexSettings
. - TestDocumentParserContext(MappingLookup, IndexSettings, IndexAnalyzers, Function<DateFormatter, MappingParserContext>, SourceToParse) - Constructor for class org.elasticsearch.index.mapper.TestDocumentParserContext
-
More verbose way to create a context, to be used when one or more constructor arguments are needed as final methods that depend on them are called while executing tests.
- testDocumentWithTextField() - Static method in class org.elasticsearch.index.engine.EngineTestCase
- testDocumentWithTextField(String) - Static method in class org.elasticsearch.index.engine.EngineTestCase
- testDocValuesDisabled() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- testEdgeCases() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- testElementsPresentOnAllLinesOfLog() - Method in class org.elasticsearch.common.logging.JsonLogsIntegTestCase
- testEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
- testEmptyName() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- testEmptyToBytesRefIterator() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
- testEnvelopeSpanningDateline() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- 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
- testEqualsAndHashcode() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
- testEqualsAndHashcode() - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
- 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 are equal.
- testErrorMessage() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- TestEventHandler - Class in org.elasticsearch.transport.nio
- TestEventListener() - Constructor for class org.elasticsearch.test.MockIndexEventListener.TestEventListener
- testExistsQuery() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- testExistsQueryMinimalMapping() - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
This test verifies that the exists query created is the appropriate one, and aligns with the data structures being created for a document with a value for the field.
- testFailToSendIllegalStateException() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testFailToSendTransportException() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testFailure(Failure) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter
- testFailuresDeduplication() - Method in class org.elasticsearch.test.AbstractBroadcastResponseTestCase
- testFetch() - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
Asserts that fetching a single value from doc values and from the native
MappedFieldType.valueFetcher(org.elasticsearch.index.query.SearchExecutionContext, java.lang.String)
produce the same results. - testFetchMany() - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
Asserts that fetching many values from doc values and from the native
MappedFieldType.valueFetcher(org.elasticsearch.index.query.SearchExecutionContext, java.lang.String)
produce the same results. - testFinished(Description) - Method in class org.elasticsearch.test.junit.listeners.LoggingListener
- testFinished(Description) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter
- 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.search.aggregations.BasePipelineAggregationTestCase
-
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.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
- testGeometryCollectionRelations() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- TestGeoShapeFieldMapperPlugin - Class in org.elasticsearch.test
-
Deprecated.
- TestGeoShapeFieldMapperPlugin() - Constructor for class org.elasticsearch.test.TestGeoShapeFieldMapperPlugin
-
Deprecated.
- testGet() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
- testGetInt() - 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
- testIndexAndDocValuesFalseNotPermitted() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- testIndexDisabled() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- testIndexedShapeReference() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- testIndexedShapeReferenceSourceDisabled() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- testIndexingDataCompression() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- TestIndexNameExpressionResolver - Class in org.elasticsearch.indices
-
A utility class that simplifies the creation of
IndexNameExpressionResolver
instances in tests to avoid repetition of creating the constructor arguments for a default instance. - testIndexOf() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
- testIndexPointsCircle() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- testIndexPointsFilterRectangle() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- testIndexPointsIndexedRectangle() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- testIndexPointsMultiPolygon() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- testIndexPointsPolygon() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- testIndexPointsRectangle() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- testIndexRectangleSpanningDateLine() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- testIndexTimeFieldData() - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
Checks that field data from this field produces the same values for query-time scripts and for index-time scripts
- testIndexTimeStoredFieldsAccess() - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
Checks that loading stored fields for this field produces the same set of values for query time scripts and index time scripts
- testIndicesDeletedFromRepository() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- testInputStreamSkip() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
- TestIssueLogging - Annotation Interface in org.elasticsearch.test.junit.annotations
-
Annotation used to set a custom log level when investigating test failures.
- 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.blobstore.ESBlobStoreRepositoryIntegTestCase
- testListChildren() - Method in class org.elasticsearch.repositories.AbstractThirdPartyRepositoryTestCase
- testLocalNodeConnection() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- TestLogging - Annotation Interface in org.elasticsearch.test.junit.annotations
-
Annotation used to set a custom log level for controlling logging behavior in tests.
- testMergePipelineTreeForBWCSerialization() - Method in class org.elasticsearch.test.InternalAggregationTestCase
- testMergePipelineTreeTwice() - Method in class org.elasticsearch.test.InternalAggregationTestCase
- testMessageListeners() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testMeta() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- testMinimalSerializesToItself() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- testMinimalToMaximal() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- testMissingDirectoriesNotCreatedInReadonlyRepository() - Method in class org.elasticsearch.repositories.blobstore.ESFsBasedRepositoryIntegTestCase
- testMockFailToSendNoConnectRule() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testMockUnresponsiveRule() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testMultiFieldsNotPermitted() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- testMultipleSnapshotAndRollback() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- testMultipleValues() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- testMultiPolygonSpanningDateline() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- 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
- testNodeIdAndClusterIdConsistentOnceAvailable() - Method in class org.elasticsearch.common.logging.JsonLogsIntegTestCase
- 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
- testNullInput() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- testNullShape() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- testNullValue() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
- testOnScriptErrorContinue() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- testOnScriptErrorParameterRequiresScript() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- testOrderByEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
- testOtherDocCount(String...) - Method in class org.elasticsearch.search.aggregations.bucket.AbstractTermsTestCase
- testParsedDocument(String, String, LuceneDocument, BytesReference, Mapping) - Static method in class org.elasticsearch.index.engine.EngineTestCase
- testParsedDocument(String, String, LuceneDocument, BytesReference, Mapping, boolean) - Static method in class org.elasticsearch.index.engine.EngineTestCase
- testParseFailure() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
- testParseFromAggBuilder() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
- testParseFromString() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
- TestPlugin() - Constructor for class org.elasticsearch.cluster.MockInternalClusterInfoService.TestPlugin
- TestPlugin() - Constructor for class org.elasticsearch.script.MockScriptService.TestPlugin
- TestPlugin() - Constructor for class org.elasticsearch.search.MockSearchService.TestPlugin
- TestPlugin() - Constructor for class org.elasticsearch.test.MockHttpTransport.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
- testPointQuery() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
-
tests querying a random geometry collection with a point
- testPolygonSpanningDateline() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- TestProcessor - Class in org.elasticsearch.ingest
-
Processor used for testing, keeps track of how many times it is invoked and accepts a
Consumer
ofIngestDocument
to be called when executed. - TestProcessor(RuntimeException) - Constructor for class org.elasticsearch.ingest.TestProcessor
- TestProcessor(String, String, String, RuntimeException) - Constructor for class org.elasticsearch.ingest.TestProcessor
- TestProcessor(String, String, String, Consumer<IngestDocument>) - Constructor for class org.elasticsearch.ingest.TestProcessor
- TestProcessor(String, 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
- TestProfiles - Class in org.elasticsearch.transport
- testProfileSettings() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testProfilesIncludesDefault() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testQueryLinearRing() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- testQueryMultiPoint() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- testQueryPoint() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- testQueryRandomGeoCollection() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- testQueryWithinMultiLine() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- 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.
- testRandomGeoCollectionQuery() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- testRandomReads() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
- testReadBlobWithNoHttpResponse() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- testReadBlobWithPrematureConnectionClose() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- testReadBlobWithReadTimeouts() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- testReadBlobWithRetries() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- testReadNonexistentBlobThrowsNoSuchFileException() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- testReadNonExistingPath() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- testReadOnly() - Method in class org.elasticsearch.repositories.blobstore.ESFsBasedRepositoryIntegTestCase
- testReadRangeBlobWithRetries() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- testRectangleSpanningDateline() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- testReduce() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
- testReduceRandom() - Method in class org.elasticsearch.test.InternalAggregationTestCase
- testRegisterHandlerTwice() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testRegisterSpecConsistency() - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- testRejectEarlyIncomingRequests() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testRejectScriptErrors() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- testRepeatableTests() - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- TestRequest - Class in org.elasticsearch.transport
- TestRequest() - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.TestRequest
- TestRequest(String) - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.TestRequest
- TestRequest(String) - Constructor for class org.elasticsearch.transport.TestRequest
- TestRequest(StreamInput) - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.TestRequest
- TestRequest(StreamInput) - Constructor for class org.elasticsearch.transport.TestRequest
- testRequestStats() - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
- TestResponse - Class in org.elasticsearch.transport
- TestResponse(String) - Constructor for class org.elasticsearch.transport.TestResponse
- TestResponse(StreamInput) - Constructor for class org.elasticsearch.transport.TestResponse
- testResponseHeadersArePreserved() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- 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.
- testSchema() - Method in class org.elasticsearch.test.AbstractSchemaValidationTestCase
- 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(IndexService) - Constructor for class org.elasticsearch.test.TestSearchContext
- TestSearchContext(SearchExecutionContext) - Constructor for class org.elasticsearch.test.TestSearchContext
- TestSearchContext(SearchExecutionContext, IndexShard, ContextIndexSearcher) - Constructor for class org.elasticsearch.test.TestSearchContext
- TestSearchContext(SearchExecutionContext, IndexShard, ContextIndexSearcher, ScrollContext) - 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.search.aggregations.BasePipelineAggregationTestCase
-
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
- testShapeFetchingPath() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- testShapeFilterWithDefinedGeoCollection() - Method in class org.elasticsearch.search.geo.GeoShapeQueryTestCase
- 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
- testSnapshotAndRestore(boolean) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- testSnapshotWithLargeSegmentFiles() - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
-
Test the snapshot and restore of an index which has large segments files.
- 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
- testStoredScriptsNotPermitted() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- 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
- testStreamResponse() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
- testSupportedFieldTypes() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
This test will validate that an aggregator succeeds or fails to run against all the field types that are registered in
IndicesModule
(e.g. - 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
- testTextSearchInfoConsistency() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- 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, Settings, ExecutorBuilder<?>...) - Constructor for class org.elasticsearch.threadpool.TestThreadPool
- TestThreadPool(String, ExecutorBuilder<?>...) - 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 theQueryBuilder
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
- testToXContent() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- testToXContent() - Method in class org.elasticsearch.test.AbstractBroadcastResponseTestCase
- testTracerLog() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- TestTransportChannel - Class in org.elasticsearch.transport
- TestTransportChannel(ActionListener<TransportResponse>) - Constructor for class org.elasticsearch.transport.TestTransportChannel
- TestTransportChannels - Class in org.elasticsearch.transport
- TestTransportChannels() - Constructor for class org.elasticsearch.transport.TestTransportChannels
- testTransportProfilesWithPortAndHost() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testTransportStats() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testTransportStatsWithException() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- testTypesAndWholeTypes() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
- 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
- testUpdates() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- testUpdates() - Method in class org.elasticsearch.index.mapper.MetadataMapperTestCase
- testValidOutput() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Generic test that checks that the
Strings.toString()
method renders the XContent correctly. - 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
- testWithInQueryLine() - Method in class org.elasticsearch.search.geo.GeoPointShapeQueryTestCase
- testWriteRead() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- testWriteToOutputStream() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
- TEXT_ALIAS_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
- TEXT_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractBuilderTestCase
- 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 Class in org.elasticsearch.test.engine
-
Flags passed to
ThrowingLeafReaderWrapper.Thrower.maybeThrow(org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags)
when the corresponding method is called. - 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
- 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
- timestamp() - Method in class org.elasticsearch.common.logging.JsonLogLine
- 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
- toMapExcludingPeerRecoveryRetentionLeases(RetentionLeases) - Static method in class org.elasticsearch.index.seqno.RetentionLeaseUtils
-
A utility method to convert a retention lease collection to a map from retention lease ID to retention lease and exclude the automatically-added peer-recovery retention leases
- toMultiPoint(Geometry) - Static method in class org.elasticsearch.geo.GeometryTestUtils
-
Extracts all vertices of the supplied geometry
- topMapping(CheckedConsumer<XContentBuilder, IOException>) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- 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 providedXContentType
. - toString() - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase.Cluster.ClusterNode
- toString() - Method in class org.elasticsearch.cluster.coordination.LinearizabilityChecker.Event
- toString() - Method in class org.elasticsearch.cluster.coordination.LinearizabilityChecker.History
- toString() - Method in class org.elasticsearch.common.logging.JsonLogLine
- toString() - Method in class org.elasticsearch.index.engine.DocIdSeqNoAndSource
- 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
- 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.rest.yaml.section.VersionRange
- toString() - Method in class org.elasticsearch.test.TestCustomMetadata
- toString() - Method in class org.elasticsearch.test.transport.StubbableTransport.WrappedConnection
- toString() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.TestRequest
- toString() - Method in class org.elasticsearch.transport.LeakTracker.Leak
- 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 thisObjectPath
. - track(T) - Method in class org.elasticsearch.transport.LeakTracker
-
Track the given object.
- trackRequest(String) - Method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase.HttpStatsCollectorHandler
- trackScores() - Method in class org.elasticsearch.test.TestSearchContext
- trackScores(boolean) - Method in class org.elasticsearch.test.TestSearchContext
- trackTotalHitsUpTo() - Method in class org.elasticsearch.test.TestSearchContext
- trackTotalHitsUpTo(int) - 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() - Element in annotation interface 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
- TransportRecoveryActionHelper - Class in org.elasticsearch.action.admin.indices.recovery
-
Helper methods for
TransportRecoveryAction
. - TransportRecoveryActionHelper() - Constructor for class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryActionHelper
- 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
- TupleMatchers - Class in org.elasticsearch.test.hamcrest
- TupleMatchers() - Constructor for class org.elasticsearch.test.hamcrest.TupleMatchers
- 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
- type - Variable in class org.elasticsearch.cluster.coordination.LinearizabilityChecker.Event
- type() - Method in class org.elasticsearch.common.logging.JsonLogLine
- type() - Method in class org.elasticsearch.index.mapper.MapperScriptTestCase
- typeName() - Method in class org.elasticsearch.index.mapper.MapperTestCase
- typeName() - Method in class org.elasticsearch.index.mapper.MockFieldMapper.FakeFieldType
- types() - Method in class org.elasticsearch.index.mapper.AbstractNumericFieldMapperTestCase
U
- unblock() - Method in class org.elasticsearch.snapshots.mockstore.MockRepository
- unblockAllDataNodes(String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- unblockNode(String, String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- unregister(Task) - Method in class org.elasticsearch.test.tasks.MockTaskManager
- UNRESPONSIVE - Static variable in class org.elasticsearch.test.disruption.NetworkDisruption
-
Simulates an unresponsive target node by dropping requests sent from source to target node.
- unresponsiveExceptionType() - Method in class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase
- UnseenEventExpectation(String, String, Level, String) - Constructor for class org.elasticsearch.test.MockLogAppender.UnseenEventExpectation
- unsupportedMappedFieldTypes() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
A method that allows implementors to specifically blacklist particular field types (based on their content_name).
- updateClusterState(Function<ClusterState, ClusterState>) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- 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
- updateState(ClusterState) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- USE_MOCK_TASK_MANAGER_SETTING - Static variable in class org.elasticsearch.test.tasks.MockTaskManager
- useIgnoreMultipleMatchingTemplatesWarningsHandler(Request) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- USERNAME_SETTING - Static variable in class org.elasticsearch.snapshots.mockstore.MockRepository.Plugin
V
- validate() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
- validate(Collection<AggregationBuilder>, AF) - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
-
Helper for testing validation.
- validate(Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>, AF) - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
-
Helper for testing validation.
- validate(AggregationBuilder, AF) - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
-
Helper for testing validation.
- validate(PipelineAggregationBuilder.ValidationContext, AF) - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
-
Helper for testing validation.
- validateClusterFormed() - Method in class org.elasticsearch.test.InternalTestCluster
-
ensure a cluster is formed with all published nodes.
- validateClusterForming() - Method in class org.elasticsearch.test.InternalTestCluster.RestartCallback
-
returns true if the restart should also validate the cluster has reformed
- value - Variable in class org.elasticsearch.cluster.coordination.LinearizabilityChecker.Event
- value() - Element in annotation interface org.elasticsearch.test.junit.annotations.TestIssueLogging
-
A comma-separated list of key-value pairs of logger:level.
- value() - Element in annotation interface org.elasticsearch.test.junit.annotations.TestLogging
-
A comma-separated list of key-value pairs of logger:level.
- value(ClusterState) - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- value(ClusterState) - Static method in class org.elasticsearch.cluster.coordination.CoordinationStateTestCluster
- value(ClusterState, int) - Method in class org.elasticsearch.cluster.coordination.AbstractCoordinatorTestCase
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.MockFieldMapper.FakeFieldType
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.coordination.LinearizabilityChecker.EventType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.test.disruption.DisruptableMockTransport.ConnectionStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.test.ESIntegTestCase.Scope
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Body
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Stability
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Visibility
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class org.elasticsearch.cluster.coordination.LinearizabilityChecker.EventType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.test.disruption.DisruptableMockTransport.ConnectionStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.test.ESIntegTestCase.Scope
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Body
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Stability
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi.Visibility
-
Returns an array containing the constants of this enum class, in the order they are declared.
- valuesSourceRegistry - Variable in class org.elasticsearch.search.aggregations.AggregatorTestCase
- verify(String, DiscoveryNode) - Method in class org.elasticsearch.index.shard.RestoreOnlyRepository
- verifyingClient - Variable in class org.elasticsearch.test.rest.RestActionTestCase
- VerifyingClient(String) - Constructor for class org.elasticsearch.test.rest.RestActionTestCase.VerifyingClient
- verifyNoLeakedListeners() - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- verifyOutputFieldNames(T, V) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- 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
- version1 - Static variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
- VersionRange - Class in org.elasticsearch.test.rest.yaml.section
- VersionRange(Version, Version) - Constructor for class org.elasticsearch.test.rest.yaml.section.VersionRange
- 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
- visualize(LinearizabilityChecker.SequentialSpec, LinearizabilityChecker.History, Function<Object, Object>) - Static method in class org.elasticsearch.cluster.coordination.LinearizabilityChecker
-
Return a visual representation of the history
W
- waitForActiveLicense(RestClient) - Static method in class org.elasticsearch.test.rest.ESRestTestCase
-
Wait for the license to be applied and active.
- waitForAllSnapshotsWiped() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Returns whether to wait to make absolutely certain that all snapshots have been deleted.
- waitForBlock(String, String) - Method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- waitForBlockOnAnyDataNode(String) - Static method in class org.elasticsearch.snapshots.AbstractSnapshotIntegTestCase
- 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.
- waitUntil(BooleanSupplier) - Static method in class org.elasticsearch.test.ESTestCase
-
Periodically execute the supplied function until it returns true, or a timeout is reached.
- waitUntil(BooleanSupplier, long, TimeUnit) - Static method in class org.elasticsearch.test.ESTestCase
-
Periodically execute the supplied function until it returns true, or until the specified maximum wait time has elapsed.
- warningsShouldFailRequest(List<String>) - Method in class org.elasticsearch.test.rest.ESRestTestCase.VersionSensitiveWarningsHandler
- wholeTypes() - Method 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
- wipeAllIndices() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- wipeAllTemplates(Set<String>) - Method in class org.elasticsearch.test.TestCluster
-
Removes all templates, except the templates defined in the exclude
- wipeDataStreams() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
- 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.
- wipeSearchableSnapshotsIndices() - Method in class org.elasticsearch.test.rest.ESRestTestCase
- wipeSnapshots() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Wipe fs snapshots we created one by one and all repositories so that the next test can create the repositories fresh and they'll start empty.
- wipeTemplates(String...) - Method in class org.elasticsearch.test.TestCluster
-
Deletes index templates, support wildcard notation.
- withAggregationContext(MapperService, List<SourceToParse>, CheckedConsumer<AggregationContext, IOException>) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- withAggregationContext(ValuesSourceRegistry, MapperService, List<SourceToParse>, Query, CheckedConsumer<AggregationContext, IOException>) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- withAggregator(AggregationBuilder, Query, CheckedConsumer<RandomIndexWriter, IOException>, CheckedBiConsumer<IndexSearcher, Aggregator, IOException>, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- 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
- withInboundException(Exception) - Method in class org.elasticsearch.test.rest.FakeRestRequest.Builder
- withIndex(CheckedConsumer<RandomIndexWriter, IOException>, CheckedConsumer<IndexSearcher, IOException>) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- withLuceneIndex(MapperService, CheckedConsumer<RandomIndexWriter, IOException>, CheckedConsumer<IndexReader, IOException>) - Method in class org.elasticsearch.index.mapper.MapperServiceTestCase
- withMethod(RestRequest.Method) - Method in class org.elasticsearch.test.rest.FakeRestRequest.Builder
- withNonMergingIndex(CheckedConsumer<RandomIndexWriter, IOException>, CheckedConsumer<IndexSearcher, IOException>) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- 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(InetSocketAddress) - Method in class org.elasticsearch.test.rest.FakeRestRequest.Builder
- wrap(HttpHandler, Logger) - Static method in class org.elasticsearch.repositories.blobstore.ESMockAPIBasedRepositoryIntegTestCase
-
Wrap a
HttpHandler
to log any thrown exception using the givenLogger
. - WRAP_READER_RATIO - Static variable in class org.elasticsearch.test.engine.MockEngineSupport
-
Allows tests to wrap an index reader randomly with a given ratio.
- wrapAckListener(ClusterStatePublisher.AckListener) - Method in class org.elasticsearch.cluster.service.FakeThreadPoolMasterService
- wrapAsRestResponseListener(ActionListener<Response>) - Static method in class org.elasticsearch.action.support.ActionTestUtils
- wrapClient(Client) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
- wrapDirectoryReader(DirectoryReader) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Override to wrap the DirectoryReader for aggs like
NestedAggregationBuilder
. - wrapInMockESDirectoryReader(DirectoryReader) - Static method in class org.elasticsearch.search.aggregations.AggregatorTestCase
- wrapSearcher(Engine.Searcher) - Method in class org.elasticsearch.test.engine.MockEngineSupport
- wrapSearcher(Engine.Searcher, CheckedFunction<DirectoryReader, DirectoryReader, IOException>) - Static method in class org.elasticsearch.index.shard.SearcherHelper
- 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 currentTerms
instance or any other instance obtained from it. - writableRegistry() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
- writableRegistry() - Method in class org.elasticsearch.test.ESTestCase
-
The
NamedWriteableRegistry
to use for this test. - writeableRegistry() - Method in class org.elasticsearch.test.transport.MockTransport
- writeBlob(BlobContainer, String, BytesArray) - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- writeBlob(BlobContainer, String, BytesArray, boolean) - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- writeException(SocketChannelContext, Exception) - Method in class org.elasticsearch.transport.nio.TestEventHandler
- writeField(XContentBuilder) - Method in class org.elasticsearch.index.mapper.MapperTestCase
-
Writes the field and a sample value for it to the provided
XContentBuilder
. - writeFileChunk(StoreFileMetadata, long, ReleasableBytesReference, boolean, int, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.AsyncRecoveryTarget
- writePluginProperties(Path, String...) - Static method in class org.elasticsearch.plugins.PluginTestUtil
- writeRandomBlob(BlobContainer, String, int) - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
- 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
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TestRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TestResponse
X
- XCONTENT_REGISTRY - Static variable in interface org.elasticsearch.test.rest.yaml.section.ExecutableSection
-
NamedXContentRegistry
that parses the default list ofExecutableSection
s available for tests. - xContentRegistry() - Method in class org.elasticsearch.search.aggregations.BasePipelineAggregationTestCase
- xContentRegistry() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractSignificanceHeuristicTestCase
- 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>, ToXContent.Params, 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
- XContentTestUtils - Class in org.elasticsearch.test
- XContentTestUtils.JsonMapView - Class in org.elasticsearch.test
Y
- yesAllocationDeciders() - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
Z
- ZeroInputStream(long) - Constructor for class org.elasticsearch.repositories.blobstore.AbstractBlobContainerRetriesTestCase.ZeroInputStream
All Classes|All Packages|Constant Field Values|Deprecated API|Serialized Form