- 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
-
- AbstractBytesReferenceTestCase - Class in org.elasticsearch.common.bytes
-
- AbstractBytesReferenceTestCase() - Constructor for class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- 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
-
- AbstractNioChannel<S extends java.nio.channels.SelectableChannel & java.nio.channels.NetworkChannel> - Class in org.elasticsearch.transport.nio.channel
-
This is a basic channel abstraction used by the
NioTransport
.
- AbstractNumericTestCase - Class in org.elasticsearch.search.aggregations.metrics
-
- AbstractNumericTestCase() - Constructor for class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- AbstractQueryTestCase<QB extends org.elasticsearch.index.query.AbstractQueryBuilder<QB>> - Class in org.elasticsearch.test
-
- AbstractQueryTestCase() - Constructor for class org.elasticsearch.test.AbstractQueryTestCase
-
- 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
-
- AbstractSimpleTransportTestCase - Class in org.elasticsearch.transport
-
- AbstractSimpleTransportTestCase() - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- AbstractSimpleTransportTestCase.StringMessageRequest - Class in org.elasticsearch.transport
-
- AbstractSimpleTransportTestCase.TestRequest - Class in org.elasticsearch.transport
-
- AbstractSimpleTransportTestCase.Version0Request - Class in org.elasticsearch.transport
-
- AbstractSimpleTransportTestCase.Version1Request - Class in org.elasticsearch.transport
-
- AbstractStreamableTestCase<T extends org.elasticsearch.common.io.stream.Streamable> - Class in org.elasticsearch.test
-
- AbstractStreamableTestCase() - Constructor for class org.elasticsearch.test.AbstractStreamableTestCase
-
- AbstractStreamableXContentTestCase<T extends org.elasticsearch.common.xcontent.ToXContent & org.elasticsearch.common.io.stream.Streamable> - Class in org.elasticsearch.test
-
- AbstractStreamableXContentTestCase() - Constructor for class org.elasticsearch.test.AbstractStreamableXContentTestCase
-
- AbstractTermsTestCase - Class in org.elasticsearch.search.aggregations.bucket
-
- AbstractTermsTestCase() - Constructor for class org.elasticsearch.search.aggregations.bucket.AbstractTermsTestCase
-
- AbstractWireSerializingTestCase<T extends org.elasticsearch.common.io.stream.Writeable> - Class in org.elasticsearch.test
-
- AbstractWireSerializingTestCase() - Constructor for class org.elasticsearch.test.AbstractWireSerializingTestCase
-
- accept(Executor) - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
-
- acceptChannel(NioServerSocketChannel) - Method in class org.elasticsearch.transport.nio.AcceptorEventHandler
-
This method is called when a server channel signals it is ready to accept a connection.
- acceptedChannelOpened(NioSocketChannel) - Method in class org.elasticsearch.transport.nio.OpenChannels
-
- acceptException(NioServerSocketChannel, Exception) - Method in class org.elasticsearch.transport.nio.AcceptorEventHandler
-
This method is called when an attempt to accept a connection throws an exception.
- AcceptingSelector - Class in org.elasticsearch.transport.nio
-
- AcceptingSelector(AcceptorEventHandler) - Constructor for class org.elasticsearch.transport.nio.AcceptingSelector
-
- AcceptingSelector(AcceptorEventHandler, Selector) - Constructor for class org.elasticsearch.transport.nio.AcceptingSelector
-
- acceptNioChannel(NioServerSocketChannel, SocketSelector, Consumer<NioChannel>) - Method in class org.elasticsearch.transport.nio.channel.ChannelFactory
-
- AcceptorEventHandler - Class in org.elasticsearch.transport.nio
-
Event handler designed to handle events from server sockets
- AcceptorEventHandler(Logger, OpenChannels, Supplier<SocketSelector>) - Constructor for class org.elasticsearch.transport.nio.AcceptorEventHandler
-
- accessed(long) - Method in class org.elasticsearch.test.TestSearchContext
-
- action - Variable in class org.elasticsearch.test.transport.CapturingTransport.CapturedRequest
-
- activeDisruption - Variable in class org.elasticsearch.test.disruption.NetworkDisruption
-
- addBody(Map<String, Object>) - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
-
- addDelegate(TransportService, MockTransportService.DelegateTransport) - Method in class org.elasticsearch.test.transport.MockTransportService
-
Adds a new delegate transport that is used for communication with the given transport service.
- addDelegate(TransportAddress, MockTransportService.DelegateTransport) - Method in class org.elasticsearch.test.transport.MockTransportService
-
Adds a new delegate transport that is used for communication with the given transport address.
- addDoSection(DoSection) - Method in class org.elasticsearch.test.rest.yaml.section.SetupSection
-
- addDoSection(DoSection) - Method in class org.elasticsearch.test.rest.yaml.section.TeardownSection
-
- addExecutableSection(ExecutableSection) - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSection
-
- addExpectation(MockLogAppender.LoggingExpectation) - Method in class org.elasticsearch.test.MockLogAppender
-
- 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(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(TransportService, String...) - Method in class org.elasticsearch.test.transport.MockTransportService
-
Adds a rule that will cause matching operations to throw ConnectTransportExceptions
- addFailToSendNoConnectRule(TransportAddress, 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
- addFailToSendNoConnectRule(TransportAddress, Set<String>) - Method in class org.elasticsearch.test.transport.MockTransportService
-
Adds a rule that will cause matching operations to throw ConnectTransportExceptions
- addHeaders(Map<String, String>) - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
-
- additionalSettings() - Method in class org.elasticsearch.test.discovery.TestZenDiscovery.TestPlugin
-
- additionalSettings() - Method in class org.elasticsearch.test.store.MockFSIndexStore.TestPlugin
-
- addKnownAllocation(ShardRouting) - Method in class org.elasticsearch.test.gateway.TestGatewayAllocator
-
manually add a specific shard to the allocations the gateway keeps track of
- addLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.test.transport.CapturingTransport
-
- addLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- addListener(MockTaskManagerListener) - Method in class org.elasticsearch.test.tasks.MockTaskManager
-
- addMockTransportService() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Iff this returns true mock transport implementations are used for the test runs.
- addModifier(FieldTypeTestCase.Modifier) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
-
Add a mutation that will be tested for all expected semantics of equality and compatibility.
- 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.
- addRegisteredChannel(NioChannel) - Method in class org.elasticsearch.transport.nio.ESSelector
-
- addRescore(RescoreSearchContext) - Method in class org.elasticsearch.test.TestSearchContext
-
- addressesFromString(String, int) - Method in class org.elasticsearch.test.transport.CapturingTransport
-
- addressesFromString(String, int) - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- addSearchExt(SearchExtBuilder) - Method in class org.elasticsearch.test.TestSearchContext
-
- addSecretInput(String) - Method in class org.elasticsearch.cli.MockTerminal
-
- addSet(String, String) - Method in class org.elasticsearch.test.rest.yaml.section.SetSection
-
- addTestSection(ClientYamlTestSection) - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
-
- addTestZenDiscovery() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Iff this returns true test zen discovery implementations is used for the test runs.
- addTextInput(String) - Method in class org.elasticsearch.cli.MockTerminal
-
- addTracer(MockTransportService.Tracer) - Method in class org.elasticsearch.test.transport.MockTransportService
-
- 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(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(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.
- 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.
- admin() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Returns a random admin client.
- adminClient() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
-
Get the client used for test administrative actions.
- after() - Method in class org.elasticsearch.test.ESTestCase
-
- afterClass() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
- afterClass() - Static method in class org.elasticsearch.test.ESIntegTestCase
-
- afterIfFailed(List<Throwable>) - Method in class org.elasticsearch.test.ESTestCase
-
Called when a test fails, supplying the errors it generated.
- afterIfFailed(List<Throwable>) - Method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
-
- afterIfSuccessful() - Method in class org.elasticsearch.test.ESTestCase
-
called after a test is finished, but only if successful
- afterIndexCreated(IndexService) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
-
- afterIndexRemoved(Index, IndexSettings, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
-
- afterIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
-
- afterIndexShardCreated(IndexShard) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
-
- afterIndexShardDeleted(ShardId, Settings) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
-
- afterIndexShardStarted(IndexShard) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
-
- afterInternal(boolean) - Method in class org.elasticsearch.test.ESIntegTestCase
-
- afterTest() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
- afterTest() - Method in class org.elasticsearch.test.ExternalTestCluster
-
- afterTest() - Method in class org.elasticsearch.test.InternalTestCluster
-
- afterTest() - Method in class org.elasticsearch.test.TestCluster
-
This method should be executed during tear down, after each test (but after assertAfterTest)
- aggregations() - Method in class org.elasticsearch.test.TestSearchContext
-
- aggregations(SearchContextAggregations) - Method in class org.elasticsearch.test.TestSearchContext
-
- AggregatorTestCase - Class in org.elasticsearch.search.aggregations
-
Base class for testing Aggregator
implementations.
- AggregatorTestCase() - Constructor for class org.elasticsearch.search.aggregations.AggregatorTestCase
-
- aliasFilter() - Method in class org.elasticsearch.test.TestSearchContext
-
- allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.DelayedShardsMockGatewayAllocator
-
- allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.test.gateway.NoopGatewayAllocator
-
- allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.test.gateway.TestGatewayAllocator
-
- allowNodes(String, int) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Restricts the given index to be allocated on n
nodes using the allocation deciders.
- allReleasedVersions() - Static method in class org.elasticsearch.test.VersionUtils
-
Returns an immutable, sorted list containing all released versions.
- allUnreleasedVersions() - Static method in class org.elasticsearch.test.VersionUtils
-
Returns an immutable, sorted list containing all unreleased versions.
- allVersions() - Static method in class org.elasticsearch.test.VersionUtils
-
Returns an immutable, sorted list containing all versions, both released and unreleased.
- AnalysisFactoryTestCase - Class in org.elasticsearch.indices.analysis
-
Alerts us if new analysis components are added to Lucene, so we don't miss them.
- AnalysisFactoryTestCase(AnalysisPlugin) - Constructor for class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
-
- AnalysisFactoryTestCase.MovedToAnalysisCommon - Class in org.elasticsearch.indices.analysis
-
Marker class for components that have moved to the analysis-common modules.
- AnalysisTestsHelper - Class in org.elasticsearch.index.analysis
-
- AnalysisTestsHelper() - Constructor for class org.elasticsearch.index.analysis.AnalysisTestsHelper
-
- ApiCallSection - Class in org.elasticsearch.test.rest.yaml.section
-
Represents a test fragment that contains the information needed to call an api
- ApiCallSection(String) - Constructor for class org.elasticsearch.test.rest.yaml.section.ApiCallSection
-
- append(LogEvent) - Method in class org.elasticsearch.test.MockLogAppender
-
- appendAllOpts(Description) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
-
- appendClientYamlSuiteProperties() - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
-
- appendEnvironmentSettings() - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
-
- appendESProperties() - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
-
- appendOpt(String, String) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
-
Append a single VM option.
- appendProperties(String...) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
-
- applyDisruption(MockTransportService, MockTransportService) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDelay
-
- applyDisruption(MockTransportService, MockTransportService) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDisconnect
-
- applyDisruption(MockTransportService, MockTransportService) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkLinkDisruptionType
-
Applies network disruption for requests send from the node represented by the source transport service to the node represented
by the target transport service.
- applyDisruption(MockTransportService, MockTransportService) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkUnresponsive
-
- applyFailedShards(RoutingAllocation, List<FailedShard>) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.DelayedShardsMockGatewayAllocator
-
- applyFailedShards(RoutingAllocation, List<FailedShard>) - Method in class org.elasticsearch.test.gateway.NoopGatewayAllocator
-
- applyFailedShards(RoutingAllocation, List<FailedShard>) - Method in class org.elasticsearch.test.gateway.TestGatewayAllocator
-
- applyStartedShards(RoutingAllocation, List<ShardRouting>) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.DelayedShardsMockGatewayAllocator
-
- applyStartedShards(RoutingAllocation, List<ShardRouting>) - Method in class org.elasticsearch.test.gateway.NoopGatewayAllocator
-
- applyStartedShards(RoutingAllocation, List<ShardRouting>) - Method in class org.elasticsearch.test.gateway.TestGatewayAllocator
-
- applyStartedShardsUntilNoChange(ClusterState, AllocationService) - Method in class org.elasticsearch.cluster.ESAllocationTestCase
-
- applyToCluster(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.NetworkDisruption
-
- applyToCluster(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.NoOpDisruptionScheme
-
- 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 class org.elasticsearch.test.disruption.NoOpDisruptionScheme
-
- applyToNode(String, InternalTestCluster) - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
-
- applyToNode(String, InternalTestCluster) - Method in class org.elasticsearch.test.disruption.SingleNodeDisruption
-
- areAllSupported(List<String>) - Static method in class org.elasticsearch.test.rest.yaml.Features
-
Tells whether all the features provided as argument are supported
- assertAcked(AcknowledgedRequestBuilder<?, ?, ?>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertAcked(AcknowledgedResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertAcked(DeleteIndexRequestBuilder) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertAcked(DeleteIndexResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- 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.
- 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
- assertAllExpectationsMatched() - Method in class org.elasticsearch.test.MockLogAppender
-
- assertAllIndicesRemovedAndDeletionCompleted(Iterable<IndicesService>) - Method in class org.elasticsearch.test.ESTestCase
-
- assertAllShardsOnNodes(String, String...) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Asserts that all shards are allocated on nodes matching the given node pattern.
- assertAllSuccessful(BroadcastResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertAllSuccessful(SearchResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertArrayEquals(StackTraceElement[], StackTraceElement[]) - Static method in class org.elasticsearch.test.ESTestCase
-
Compares two stack traces, ignoring module (which is not yet serialized)
- assertBinding(Module, Class, Class) - Method in class org.elasticsearch.common.inject.ModuleTestCase
-
Configures the module and asserts "clazz" is bound to "to".
- assertBindingFailure(Module, String...) - Method in class org.elasticsearch.common.inject.ModuleTestCase
-
Attempts to configure the module, and asserts an IllegalArgumentException
is
caught, containing the given messages
- assertBlocked(ActionRequestBuilder) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Executes the request and fails if the request has not been blocked.
- 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
- 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
.
- assertBooleanSubQuery(Query, Class<T>, int) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertBusy(CheckedRunnable<Exception>) - Static method in class org.elasticsearch.test.ESTestCase
-
Runs the code block for 10 seconds waiting for no assertion to trip.
- assertBusy(CheckedRunnable<Exception>, long, TimeUnit) - Static method in class org.elasticsearch.test.ESTestCase
-
Runs the code block for the provided interval, waiting for no assertions to trip.
- assertCompatible(String, MappedFieldType, MappedFieldType, boolean) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
-
- assertConcreteMappingsOnAll(String, String, String...) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Waits till a (pattern) field name mappings concretely exists on all nodes.
- assertDiffApplication(T, T, Diff<T>) - Static method in class org.elasticsearch.test.DiffableTestUtils
-
Asserts that changes are applied correctly, i.e.
- assertDirectoryExists(Path) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Check if a directory exists
- assertDisjunctionSubQuery(Query, Class<T>, int) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertDocCount(IndexShard, int) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
- assertDocs(IndexShard, String...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
- assertEquals(StackTraceElement, StackTraceElement) - Static method in class org.elasticsearch.test.ESTestCase
-
Compares two stack trace elements, ignoring module (which is not yet serialized)
- assertEqualsWithErrorMessageFromXContent(T, T) - Static method in class org.elasticsearch.test.ESTestCase
-
Assert that two objects are equals, calling ToXContent.toXContent(XContentBuilder, ToXContent.Params)
to print out their
differences if they aren't equal.
- assertExists(GetResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertFailures(SearchResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertFailures(SearchRequestBuilder, RestStatus, Matcher<String>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertFieldTypeEquals(String, MappedFieldType, MappedFieldType) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
-
- assertFieldTypeNotEquals(String, MappedFieldType, MappedFieldType) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
-
- assertFifthHit(SearchResponse, Matcher<SearchHit>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertFileContent(Path, String, String) - Static method in class org.elasticsearch.common.io.FileTestUtils
-
Check that a file contains a given String
- assertFileExists(Path) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Check if a file exists
- assertFileNotExists(Path) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Check if a file does not exist
- assertFirstHit(SearchResponse, Matcher<SearchHit>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertFourthHit(SearchResponse, Matcher<SearchHit>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertFromXContent(T, ParsedAggregation) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
-
- assertFromXContent(T, ParsedAggregation) - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
- assertHighlight(SearchResponse, int, String, int, Matcher<String>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertHighlight(SearchResponse, int, 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
-
- assertHighlight(SearchHit, String, int, int, Matcher<String>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertHitCount(SearchResponse, long) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertIndexTemplateExists(GetIndexTemplatesResponse, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Assert that an index template exists
- assertIndexTemplateMissing(GetIndexTemplatesResponse, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Assert that an index template is missing
- assertIngestDocument(Object, Object) - Static method in class org.elasticsearch.ingest.IngestDocumentMatcher
-
Helper method to assert the equivalence between two IngestDocuments.
- AssertingTransportInterceptor - Class in org.elasticsearch.transport
-
- AssertingTransportInterceptor(Settings, NamedWriteableRegistry) - Constructor for class org.elasticsearch.transport.AssertingTransportInterceptor
-
- AssertingTransportInterceptor.TestPlugin - Class in org.elasticsearch.transport
-
- 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.
- assertInstanceBindingWithAnnotation(Module, Class<T>, Predicate<T>, Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.ModuleTestCase
-
- 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
-
- assertMapInstanceBinding(Module, Class<K>, Class<V>, Map<K, V>) - Method in class org.elasticsearch.common.inject.ModuleTestCase
-
Configures the module, and ensures a map exists between the "keyType" and "valueType",
and that all of the "expected" values are bound.
- assertMapMultiBinding(Module, Class, Class) - Method in class org.elasticsearch.common.inject.ModuleTestCase
-
Configures the module and checks a Map<String, Class> of the "to" class
is bound to "theClass".
- assertMappingOnMaster(String, String, String...) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Waits for the given mapping type to exists on the master node.
- assertMatched() - Method in interface org.elasticsearch.test.MockLogAppender.LoggingExpectation
-
- assertMatched() - Method in class org.elasticsearch.test.MockLogAppender.SeenEventExpectation
-
- assertMatched() - Method in class org.elasticsearch.test.MockLogAppender.UnseenEventExpectation
-
- assertNoFailures() - Method in class org.elasticsearch.test.BackgroundIndexer
-
- assertNoFailures(SearchResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertNoFailures(BulkResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertNoFailures(BroadcastResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertNoInFlightContext() - Static method in class org.elasticsearch.search.MockSearchService
-
Throw an AssertionError
if there are still in-flight contexts.
- assertNoPendingHandshakes(Transport) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- assertNoSearchHits(SearchResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertNotBound(Module, Class) - Method in class org.elasticsearch.common.inject.ModuleTestCase
-
Configures the module and asserts "clazz" is not bound to anything.
- assertNotCompatible(String, MappedFieldType, MappedFieldType, boolean, String...) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
-
- assertNotHighlighted(SearchResponse, int, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertNoTimeout(ClusterHealthRequestBuilder) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertNoTimeout(ClusterHealthResponse) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertNumHandshakes(long, Transport) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- assertOrderedSearchHits(SearchResponse, String...) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertParsedInstance(XContentType, BytesReference, T) - Method in class org.elasticsearch.test.AbstractSerializingTestCase
-
- assertParsedQuery(String, QueryBuilder) - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Parses the query provided as string argument and compares it with the expected result provided as argument as a QueryBuilder
- assertPathHasBeenCleared(Path) - Method in class org.elasticsearch.test.ESTestCase
-
Asserts that there are no files in the specified path
- assertReduced(T, List<T>) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
-
- assertReduced(T, List<T>) - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
- assertResultsAndLogOnFailure(long, SearchResponse) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Ensures the result counts are as expected, and logs the results if different
- assertSearchHit(SearchResponse, int, Matcher<SearchHit>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertSearchHit(SearchHit, 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
-
- assertSerialization(QueryBuilder) - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
- assertSerialization(QueryBuilder, Version) - Static 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.AbstractStreamableTestCase
-
Serialize the given instance and asserts that both are equal
- assertSerialization(T) - Method in class org.elasticsearch.test.AbstractWireSerializingTestCase
-
Serialize the given instance and asserts that both are equal
- assertSerialization(T, Version) - Method in class org.elasticsearch.test.AbstractWireSerializingTestCase
-
- assertSerialization(T, NamedWriteableRegistry, Writeable.Reader<T>) - Static method in class org.elasticsearch.test.DiffableTestUtils
-
Asserts that testInstance can be correctly.
- assertSetMultiBinding(Module, Class, Class...) - Method in class org.elasticsearch.common.inject.ModuleTestCase
-
Configures the module and checks a Set of the "to" class
is bound to "classes".
- assertSettingDeprecationsAndWarnings(Setting<?>[], String...) - Method in class org.elasticsearch.test.ESTestCase
-
Convenience method to assert warnings for settings deprecations and general deprecation warnings.
- assertSortedSegments(String, Sort) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Asserts that all segments are sorted with the provided Sort
.
- assertSortValues(SearchResponse, Object[]...) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertSuccessfulRestore(RestoreSnapshotRequestBuilder) - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
-
- assertSuccessfulRestore(RestoreSnapshotResponse) - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
-
- assertSuccessfulSnapshot(CreateSnapshotRequestBuilder) - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
-
- assertSuccessfulSnapshot(CreateSnapshotResponse) - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
-
- assertSuggestion(Suggest, int, int, String, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertSuggestion(Suggest, int, String, String...) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Assert suggestion returns exactly the provided text.
- 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.
- 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) - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
- assertTermQuery(Query, String, String) - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
- assertThirdHit(SearchResponse, Matcher<SearchHit>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertThrows(ActionRequestBuilder<?, ?, ?>, Class<E>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Run the request from a given builder and check that it throws an exception of the right type
- assertThrows(ActionRequestBuilder<?, ?, ?>, Class<E>, RestStatus) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Run the request from a given builder and check that it throws an exception of the right type, with a given RestStatus
- assertThrows(ActionRequestBuilder<?, ?, ?>, Class<E>, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Run the request from a given builder and check that it throws an exception of the right type
- assertThrows(ActionFuture, Class<E>) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Run future.actionGet() and check that it throws an exception of the right type
- assertThrows(ActionFuture, Class<E>, RestStatus) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Run future.actionGet() and check that it throws an exception of the right type, with a given RestStatus
- assertThrows(ActionFuture, Class<E>, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Run future.actionGet() and check that it throws an exception of the right type
- assertThrows(ActionFuture, Class<E>, RestStatus, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Run future.actionGet() and check that it throws an exception of the right type, optionally checking the exception's rest status
- assertThrows(ActionRequestBuilder<?, ?, ?>, RestStatus) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertThrows(ActionRequestBuilder<?, ?, ?>, RestStatus, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertThrows(ActionFuture, RestStatus) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertThrows(ActionFuture, RestStatus, String) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertToXContentEquivalent(BytesReference, BytesReference, XContentType) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
Asserts that the provided BytesReference
s created through
ToXContent.toXContent(XContentBuilder, ToXContent.Params)
hold the same content.
- assertVersionSerializable(Streamable) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertVersionSerializable(Version, Streamable) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertVersionSerializable(Version, Streamable, NamedWriteableRegistry) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertVersionSerializable(Version, Exception) - Static method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- assertWarnings(String...) - Method in class org.elasticsearch.test.ESTestCase
-
- await() - Method in class org.elasticsearch.test.rest.FakeRestChannel
-
- awaitBusy(BooleanSupplier) - Static method in class org.elasticsearch.test.ESTestCase
-
- awaitBusy(BooleanSupplier, long, TimeUnit) - Static method in class org.elasticsearch.test.ESTestCase
-
- awaitClose() - Method in class org.elasticsearch.transport.nio.channel.CloseFuture
-
- awaitClose(long, TimeUnit) - Method in class org.elasticsearch.transport.nio.channel.CloseFuture
-
- awaitConnectionComplete(long, TimeUnit) - Method in class org.elasticsearch.transport.nio.channel.ConnectFuture
-
- callApi(String, Map<String, String>, HttpEntity, Map<String, String>) - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestClient
-
Calls an api with the provided parameters and body
- 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.
- 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, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.TestAllocateDecision
-
- canAllocate(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.TestAllocateDecision
-
- canAllocate(RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.TestAllocateDecision
-
- cancel(boolean) - Method in class org.elasticsearch.transport.nio.channel.CloseFuture
-
- CapturedRequest(DiscoveryNode, long, String, TransportRequest) - Constructor for class org.elasticsearch.test.transport.CapturingTransport.CapturedRequest
-
- 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
-
- channelClosed(NioChannel) - Method in class org.elasticsearch.transport.nio.OpenChannels
-
- ChannelFactory - Class in org.elasticsearch.transport.nio.channel
-
- ChannelFactory(TcpTransport.ProfileSettings, TcpReadHandler) - Constructor for class org.elasticsearch.transport.nio.channel.ChannelFactory
-
- charFilter - Variable in class org.elasticsearch.test.ESTestCase.TestAnalysis
-
- checkEqualsAndHashCode(T, EqualsHashCodeTestUtils.CopyFunction<T>) - Static method in class org.elasticsearch.test.EqualsHashCodeTestUtils
-
Perform common equality and hashCode checks on the input object
- checkEqualsAndHashCode(T, EqualsHashCodeTestUtils.CopyFunction<T>, EqualsHashCodeTestUtils.MutateFunction<T>) - Static method in class org.elasticsearch.test.EqualsHashCodeTestUtils
-
Perform common equality and hashCode checks on the input object
- checkGeneratedJson(String, QueryBuilder) - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
Call this method to check a valid json string representing the query under test against
it's generated json.
- checkIndex(Logger, Store, ShardId) - Static method in class org.elasticsearch.test.store.MockFSDirectoryService
-
- checkIndexFailed - Static variable in class org.elasticsearch.test.ESTestCase
-
MockFSDirectoryService sets this:
- checkStaticState() - Static method in class org.elasticsearch.test.ESTestCase
-
- CHUNK_SIZE_SETTING - Static variable in class org.elasticsearch.node.RecoverySettingsChunkSizePlugin
-
The chunk size.
- cleanUpCluster() - Method in class org.elasticsearch.test.ESIntegTestCase
-
- cleanUpCluster() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Clean up after the test case.
- clear() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestExecutionContext
-
Clears the last obtained response and the stashed fields
- clear() - Method in class org.elasticsearch.test.rest.yaml.Stash
-
Clears the previously stashed values
- clear() - Method in class org.elasticsearch.test.transport.CapturingTransport
-
clears captured requests
- ClearableTransport(Transport) - Constructor for class org.elasticsearch.test.transport.MockTransportService.ClearableTransport
-
- clearAllRules() - Method in class org.elasticsearch.test.transport.MockTransportService
-
Clears all the registered rules.
- clearData(String) - Method in class org.elasticsearch.test.InternalTestCluster.RestartCallback
-
If this returns true
all data for the node with the given node name will be cleared including
gateways and all index data.
- clearDisruptionScheme() - Method in class org.elasticsearch.test.ESIntegTestCase
-
- clearDisruptionScheme() - Method in class org.elasticsearch.test.InternalTestCluster
-
- clearDisruptionScheme(boolean) - Method in class org.elasticsearch.test.InternalTestCluster
-
- clearQueuedWriteOps(Exception) - Method in class org.elasticsearch.transport.nio.channel.TcpWriteContext
-
- clearQueuedWriteOps(Exception) - Method in interface org.elasticsearch.transport.nio.channel.WriteContext
-
- clearRule() - Method in class org.elasticsearch.test.transport.MockTransportService.ClearableTransport
-
- clearRule(TransportService) - Method in class org.elasticsearch.test.transport.MockTransportService
-
Clears the rule associated with the provided transport service.
- clearRule(TransportAddress) - Method in class org.elasticsearch.test.transport.MockTransportService
-
Clears the rule associated with the provided transport address.
- clearScroll(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Clears the given scroll Ids
- clearStatic() - Static method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
-
- clearTracers() - Method in class org.elasticsearch.test.transport.MockTransportService
-
- client() - Static method in class org.elasticsearch.test.ESIntegTestCase
-
- client(String) - 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(String) - Method in class org.elasticsearch.test.InternalTestCluster
-
Returns a node client to a given node.
- client(Predicate<Settings>) - Method in class org.elasticsearch.test.InternalTestCluster
-
Returns a random node that applies to the given predicate.
- client() - 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 - Static variable in interface org.elasticsearch.transport.nio.channel.NioChannel
-
- CLIENT_RETRY_TIMEOUT - Static variable in class org.elasticsearch.test.rest.ESRestTestCase
-
- CLIENT_SOCKET_TIMEOUT - Static variable in class org.elasticsearch.test.rest.ESRestTestCase
-
- clientChannelOpened(NioSocketChannel) - Method in class org.elasticsearch.transport.nio.OpenChannels
-
- clients() - Static method in class org.elasticsearch.test.ESIntegTestCase
-
- ClientYamlSuiteRestApi - Class in org.elasticsearch.test.rest.yaml.restspec
-
Specification of an Elasticsearch endpoint used by the YAML specs to generate REST requests.
- ClientYamlSuiteRestApi.Body - Enum in org.elasticsearch.test.rest.yaml.restspec
-
- ClientYamlSuiteRestApiParser - Class in org.elasticsearch.test.rest.yaml.restspec
-
- ClientYamlSuiteRestApiParser() - Constructor for class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApiParser
-
- ClientYamlSuiteRestPath - Class in org.elasticsearch.test.rest.yaml.restspec
-
- ClientYamlSuiteRestPath(List<String>) - Constructor for class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestPath
-
- ClientYamlSuiteRestPath(String) - Constructor for class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestPath
-
- ClientYamlSuiteRestSpec - Class in org.elasticsearch.test.rest.yaml.restspec
-
Holds the specification used to turn do
actions in the YAML suite into REST api calls.
- ClientYamlTestCandidate - Class in org.elasticsearch.test.rest.yaml
-
- ClientYamlTestCandidate(ClientYamlTestSuite, ClientYamlTestSection) - Constructor for class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
-
- ClientYamlTestClient - Class in org.elasticsearch.test.rest.yaml
-
- ClientYamlTestClient(ClientYamlSuiteRestSpec, RestClient, List<HttpHost>, Version) - Constructor for class org.elasticsearch.test.rest.yaml.ClientYamlTestClient
-
- 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.
- ClientYamlTestResponseException - Exception in org.elasticsearch.test.rest.yaml
-
Exception obtained from a REST call in case the response code indicated an error.
- 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) - 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) - Constructor for class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
-
- clone() - Method in class org.elasticsearch.index.mapper.MockFieldMapper.FakeFieldType
-
- close() - Method in class org.elasticsearch.common.settings.MockSecureSettings
-
- close() - Method in class org.elasticsearch.test.BackgroundIndexer
-
- close() - Method in class org.elasticsearch.test.client.NoOpClient
-
- close() - Method in class org.elasticsearch.test.discovery.MockZenPing
-
- close() - Method in class org.elasticsearch.test.ExternalTestCluster
-
- close() - Method in class org.elasticsearch.test.InternalTestCluster
-
- close() - Method in class org.elasticsearch.test.PosixPermissionsResetter
-
- close() - Method in class org.elasticsearch.test.TestCluster
-
Closes the current cluster
- close() - Method in class org.elasticsearch.test.transport.CapturingTransport
-
- close() - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- close() - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
-
- close() - Method in class org.elasticsearch.transport.nio.ESSelector
-
- close(boolean) - Method in class org.elasticsearch.transport.nio.ESSelector
-
- close() - Method in class org.elasticsearch.transport.nio.NioClient
-
- close() - Method in class org.elasticsearch.transport.nio.OpenChannels
-
- closeAsync() - Method in class org.elasticsearch.transport.nio.channel.AbstractNioChannel
-
Schedules a channel to be closed by the selector event loop with which it is registered.
- closeAsync() - Method in interface org.elasticsearch.transport.nio.channel.NioChannel
-
- closeChannels(List<MockTcpTransport.MockChannel>, boolean) - Method in class org.elasticsearch.transport.MockTcpTransport
-
- closeChannels(List<NioChannel>, boolean) - Method in class org.elasticsearch.transport.nio.NioTransport
-
- closeClients() - Static method in class org.elasticsearch.test.rest.ESRestTestCase
-
- closeFromSelector() - Method in class org.elasticsearch.transport.nio.channel.AbstractNioChannel
-
Closes the channel synchronously.
- closeFromSelector() - Method in interface org.elasticsearch.transport.nio.channel.NioChannel
-
- closeFromSelector() - Method in class org.elasticsearch.transport.nio.channel.NioSocketChannel
-
- CloseFuture - Class in org.elasticsearch.transport.nio.channel
-
- CloseFuture() - Constructor for class org.elasticsearch.transport.nio.channel.CloseFuture
-
- closeInternal() - Method in class org.elasticsearch.test.DummyShardLock
-
- closeNonSharedNodes(boolean) - Method in class org.elasticsearch.test.InternalTestCluster
-
- closeSelectorException(IOException) - Method in class org.elasticsearch.transport.nio.EventHandler
-
This method handles an IOException that was thrown during a call to Selector.close()
.
- closeServerChannels() - Method in class org.elasticsearch.transport.nio.OpenChannels
-
- closeShards(IndexShard...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
- closeShards(Iterable<IndexShard>) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
- cluster - Variable in class org.elasticsearch.test.disruption.NetworkDisruption
-
- cluster - Variable in class org.elasticsearch.test.disruption.SingleNodeDisruption
-
- cluster() - Static method in class org.elasticsearch.test.ESIntegTestCase
-
- ClusterDiscoveryConfiguration - Class in org.elasticsearch.test.discovery
-
- ClusterDiscoveryConfiguration(int, Settings) - Constructor for class org.elasticsearch.test.discovery.ClusterDiscoveryConfiguration
-
- ClusterDiscoveryConfiguration.UnicastZen - Class in org.elasticsearch.test.discovery
-
- clusterName(String, long) - Static method in class org.elasticsearch.test.InternalTestCluster
-
- clusterService() - Method in class org.elasticsearch.test.ESIntegTestCase
-
- clusterService() - Method in class org.elasticsearch.test.InternalTestCluster
-
Returns a reference to a random node's ClusterService
- clusterService(String) - Method in class org.elasticsearch.test.InternalTestCluster
-
Returns a reference to a node's ClusterService
.
- ClusterServiceUtils - Class in org.elasticsearch.test
-
- ClusterServiceUtils() - Constructor for class org.elasticsearch.test.ClusterServiceUtils
-
- collapse(CollapseContext) - Method in class org.elasticsearch.test.TestSearchContext
-
- collapse() - 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.ImmutableOpenMapHasKeyMatcher - Class in org.elasticsearch.test.hamcrest
-
- command - Variable in class org.elasticsearch.cli.CommandTestCase
-
The last command that was executed.
- CommandTestCase - Class in org.elasticsearch.cli
-
A base test case for cli tools.
- CommandTestCase() - Constructor for class org.elasticsearch.cli.CommandTestCase
-
- compare(String, Object, Object) - Method in class org.elasticsearch.test.NotEqualMessageBuilder
-
Compare two values.
- compareLists(List<Object>, List<Object>) - Method in class org.elasticsearch.test.NotEqualMessageBuilder
-
Compare two lists.
- compareMaps(Map<String, Object>, Map<String, Object>) - Method in class org.elasticsearch.test.NotEqualMessageBuilder
-
Compare two maps.
- compareTo(ClientYamlTestSection) - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSection
-
- compile(Script, ScriptContext<FactoryType>) - Method in class org.elasticsearch.ingest.TestTemplateService
-
- compile(String, String, ScriptContext<T>, Map<String, String>) - Method in class org.elasticsearch.script.MockScriptEngine
-
- configure() - Method in class org.elasticsearch.test.IndexSettingsModule
-
- connectException(NioSocketChannel, Exception) - Method in class org.elasticsearch.transport.nio.SocketEventHandler
-
This method is called when an attempt to connect a channel throws an exception.
- connectFailed() - Method in class org.elasticsearch.transport.nio.channel.ConnectFuture
-
- ConnectFuture - Class in org.elasticsearch.transport.nio.channel
-
- ConnectFuture() - Constructor for class org.elasticsearch.transport.nio.channel.ConnectFuture
-
- connectToChannels(DiscoveryNode, ConnectionProfile, Consumer<MockTcpTransport.MockChannel>) - Method in class org.elasticsearch.transport.MockTcpTransport
-
- connectToChannels(DiscoveryNode, NioSocketChannel[], TimeValue, Consumer<NioChannel>) - Method in class org.elasticsearch.transport.nio.NioClient
-
- connectToChannels(DiscoveryNode, ConnectionProfile, Consumer<NioChannel>) - Method in class org.elasticsearch.transport.nio.NioTransport
-
- connectToNode(DiscoveryNode, ConnectionProfile, CheckedBiConsumer<Transport.Connection, ConnectionProfile, IOException>) - Method in class org.elasticsearch.test.transport.CapturingTransport
-
- connectToNode(DiscoveryNode, ConnectionProfile, CheckedBiConsumer<Transport.Connection, ConnectionProfile, IOException>) - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- 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.
- content() - Method in class org.elasticsearch.test.rest.FakeRestRequest
-
- contentType() - Method in class org.elasticsearch.index.mapper.MockFieldMapper
-
- continueIndexing() - Method in class org.elasticsearch.test.BackgroundIndexer
-
Continue indexing after it has paused.
- continueIndexing(int) - Method in class org.elasticsearch.test.BackgroundIndexer
-
Continue indexing after it has paused.
- convertToMap(ToXContent) - Static method in class org.elasticsearch.test.XContentTestUtils
-
- coordOnlyNodeClient() - Method in class org.elasticsearch.test.InternalTestCluster
-
Returns a client to a coordinating only node
- copy(T) - Method in interface org.elasticsearch.test.EqualsHashCodeTestUtils.CopyFunction
-
- copyIndex(Logger, Path, String, Path...) - Static method in class org.elasticsearch.test.OldIndexUtils
-
- copyInstance(T, Version) - Method in class org.elasticsearch.test.AbstractStreamableTestCase
-
Round trip instance
through binary serialization, setting the wire compatibility version to version
.
- copyInstance(T) - Method in class org.elasticsearch.test.AbstractWireSerializingTestCase
-
- copyInstance(T, Version) - Method in class org.elasticsearch.test.AbstractWireSerializingTestCase
-
- copyInstance(T, NamedWriteableRegistry, Writeable.Reader<T>) - Static method in class org.elasticsearch.test.DiffableTestUtils
-
Simulates sending diffs over the wire
- copyToBytesFromClasspath(String) - Static method in class org.elasticsearch.test.StreamsUtils
-
- copyToStringFromClasspath(ClassLoader, String) - Static method in class org.elasticsearch.test.StreamsUtils
-
- copyToStringFromClasspath(String) - Static method in class org.elasticsearch.test.StreamsUtils
-
- copyWriteable(T, NamedWriteableRegistry, Writeable.Reader<T>) - Static method in class org.elasticsearch.test.ESTestCase
-
Create a copy of an original Writeable
object by running it through a BytesStreamOutput
and
reading it in again using a provided Writeable.Reader
.
- corruptFile(Random, Path...) - Static method in class org.elasticsearch.test.CorruptionUtils
-
Corrupts a random file at a random position
- CorruptionUtils - Class in org.elasticsearch.test
-
- crash() - Method in class org.elasticsearch.test.store.MockFSDirectoryService.ElasticsearchMockDirectoryWrapper
-
- CRASH_INDEX_SETTING - Static variable in class org.elasticsearch.test.store.MockFSDirectoryService
-
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.MyFilterTokenFilterFactory
-
- create(Map<String, Processor.Factory>, String, Map<String, Object>) - Method in class org.elasticsearch.ingest.TestProcessor.Factory
-
- createAdapter() - Method in class org.elasticsearch.test.transport.MockTransportService
-
- createAggregator(AggregationBuilder, IndexSearcher, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
- createAggregatorFactory(AggregationBuilder, IndexSearcher, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Create a factory for the given aggregation builder.
- 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, ClusterSettings, Random) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
- createAllocationService(Settings, ClusterInfoService) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
- createAllocationService(Settings, GatewayAllocator) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
- createBigArrays(Settings, CircuitBreakerService) - Method in class org.elasticsearch.node.MockNode
-
- createBlankInstance() - Method in class org.elasticsearch.test.AbstractStreamableTestCase
-
Creates an empty instance to use when deserialising the
Streamable
.
- 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
-
- createClusterService(ClusterState, ThreadPool) - Static method in class org.elasticsearch.test.ClusterServiceUtils
-
- createClusterStatePublisher(ClusterApplier) - Static method in class org.elasticsearch.test.ClusterServiceUtils
-
- createDefaultFieldType() - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
-
Create a default constructed fieldtype
- createExecutableScript(Map<String, Object>) - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
-
- createFromResponse(Response) - Static method in class org.elasticsearch.test.rest.yaml.ObjectPath
-
- createFromXContent(XContent, BytesReference) - Static method in class org.elasticsearch.test.rest.yaml.ObjectPath
-
- createGuiceModules() - Method in class org.elasticsearch.test.MockIndexEventListener.TestPlugin
-
- createIndex(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Creates one or more indices and asserts that the indices are acknowledged.
- createIndex(String) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
Create a new index on the singleton node with empty index settings.
- 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, String, XContentBuilder) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
Create a new index on the singleton node with the provided index settings.
- 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, CreateIndexRequestBuilder) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
- createIndexSettings() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
- createMasterService(ThreadPool, ClusterState) - Static method in class org.elasticsearch.test.ClusterServiceUtils
-
- createMasterService(ThreadPool, DiscoveryNode) - Static method in class org.elasticsearch.test.ClusterServiceUtils
-
- createNewService(Settings, Version, ThreadPool, ClusterSettings) - Static method in class org.elasticsearch.test.transport.MockTransportService
-
- createNewService(Settings, Transport, Version, ThreadPool, ClusterSettings) - Static method in class org.elasticsearch.test.transport.MockTransportService
-
- createParameters() - Static method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
-
- createParser(XContentBuilder) - 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, InputStream) - 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, BytesReference) - Method in class org.elasticsearch.test.ESTestCase
-
Create a new XContentParser
.
- createRestClient(RestClientBuilder.HttpClientConfigCallback) - Static method in class org.elasticsearch.test.ESIntegTestCase
-
- createRestClient(RestClientBuilder.HttpClientConfigCallback, String) - Static method in class org.elasticsearch.test.ESIntegTestCase
-
- createSearchContext(IndexSearcher, IndexSettings) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
- createSearchContext(IndexService) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
Create a new search context.
- createSearchScript(Map<String, Object>, SearchLookup) - Method in class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
-
- createShardContext() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
- createTaskManager() - Method in class org.elasticsearch.test.transport.MockTransportService
-
- createTestAggregatorBuilder() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
-
- createTestAnalysis(Index, Settings, AnalysisPlugin...) - Static method in class org.elasticsearch.test.ESTestCase
-
Creates an TestAnalysis with all the default analyzers configured.
- createTestAnalysis(Index, Settings, 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, AnalysisPlugin...) - Static method in class org.elasticsearch.index.analysis.AnalysisTestsHelper
-
- createTestAnalysisFromSettings(Settings, Path, AnalysisPlugin...) - Static method in class org.elasticsearch.index.analysis.AnalysisTestsHelper
-
- createTestInstance(String, long, InternalAggregations, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
-
- createTestInstance(String, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
-
- createTestInstance() - Method in class org.elasticsearch.test.AbstractStreamableTestCase
-
Creates a random test instance to use in the tests.
- createTestInstance() - Method in class org.elasticsearch.test.AbstractWireSerializingTestCase
-
Creates a random test instance to use in the tests.
- createTestInstance(String, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
- createTestInstance() - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
- createTestQueryBuilder() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
- createTestRepository(String) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
-
- createUnmappedInstance(String, List<PipelineAggregator>, Map<String, Object>) - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
Return an instance on an unmapped field.
- createUnmappedInstance(String) - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
Return an instance on an unmapped field.
- currentClusterStateVersion - Static variable in class org.elasticsearch.index.shard.IndexShardTestCase
-
- currentNanoTime() - Method in class org.elasticsearch.cluster.ESAllocationTestCase.MockAllocationService
-
- ElasticsearchAssertions - Class in org.elasticsearch.test.hamcrest
-
- ElasticsearchAssertions() - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchAssertions
-
- ElasticsearchAssertions.ExceptionWrapper - Class in org.elasticsearch.test.hamcrest
-
- ElasticsearchMatchers - Class in org.elasticsearch.test.hamcrest
-
- ElasticsearchMatchers() - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchMatchers
-
- ElasticsearchMatchers.SearchHitHasIdMatcher - Class in org.elasticsearch.test.hamcrest
-
- ElasticsearchMatchers.SearchHitHasIndexMatcher - Class in org.elasticsearch.test.hamcrest
-
- ElasticsearchMatchers.SearchHitHasScoreMatcher - Class in org.elasticsearch.test.hamcrest
-
- ElasticsearchMatchers.SearchHitHasTypeMatcher - Class in org.elasticsearch.test.hamcrest
-
- ElasticsearchMockDirectoryWrapper(Random, Directory, boolean) - Constructor for class org.elasticsearch.test.store.MockFSDirectoryService.ElasticsearchMockDirectoryWrapper
-
- EMPTY - Static variable in class org.elasticsearch.test.NodeConfigurationSource
-
- EMPTY - Static variable in class org.elasticsearch.test.rest.yaml.section.SetupSection
-
- EMPTY - Static variable in class org.elasticsearch.test.rest.yaml.section.SkipSection
-
- EMPTY - Static variable in class org.elasticsearch.test.rest.yaml.section.TeardownSection
-
- EMPTY - Static variable in class org.elasticsearch.test.rest.yaml.Stash
-
- EMPTY_CALLBACK - Static variable in class org.elasticsearch.test.InternalTestCluster
-
- 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
- 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.
- ensureAllArraysAreReleased() - Static method in class org.elasticsearch.common.util.MockBigArrays
-
- ensureAllPagesAreReleased() - Static method in class org.elasticsearch.common.util.MockPageCacheRecycler
-
- ensureAllSearchContextsReleased() - Method in class org.elasticsearch.test.ESTestCase
-
- ensureAtLeastNumDataNodes(int) - Method in class org.elasticsearch.test.InternalTestCluster
-
Ensures that at least n
data nodes are present in the cluster.
- ensureAtMostNumDataNodes(int) - Method in class org.elasticsearch.test.InternalTestCluster
-
Ensures that at most n
are up and running.
- ensureCheckIndexPassed() - Method in class org.elasticsearch.test.ESTestCase
-
- ensureClusterSizeConsistency() - Method in class org.elasticsearch.test.ESIntegTestCase
-
- ensureClusterStateConsistency() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Verifies that all nodes that have the same version of the cluster state as master have same cluster state
- ensureEstimatedStats() - Method in class org.elasticsearch.test.ExternalTestCluster
-
- ensureEstimatedStats() - Method in class org.elasticsearch.test.InternalTestCluster
-
- ensureEstimatedStats() - Method in class org.elasticsearch.test.TestCluster
-
Ensures that any breaker statistics are reset to 0.
- ensureFullyConnectedCluster(InternalTestCluster) - Static method in class org.elasticsearch.test.disruption.NetworkDisruption
-
Ensures that all nodes in the cluster are connected to each other.
- ensureFullyConnectedCluster() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Ensures that all nodes in the cluster are connected to each other.
- ensureGreen(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.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.ESSingleNodeTestCase
-
Ensures the cluster has a green state via the cluster health API.
- 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
-
- 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, TimeValue) - Method in class org.elasticsearch.test.ESIntegTestCase
-
- ensureStableCluster(int, String) - Method in class org.elasticsearch.test.ESIntegTestCase
-
- ensureStableCluster(int, TimeValue, boolean, String) - Method in class org.elasticsearch.test.ESIntegTestCase
-
- ensureYellow(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Ensures the cluster has a yellow state via the cluster health API.
- entityAsMap(Response) - 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.test.rest.yaml.section.ClientYamlTestSection
-
- equals(Object) - Method in class org.elasticsearch.test.TestCustomMetaData
-
- EqualsHashCodeTestUtils - Class in org.elasticsearch.test
-
Utility class that encapsulates standard checks and assertions around testing the equals() and hashCode()
methods of objects that implement them.
- EqualsHashCodeTestUtils() - Constructor for class org.elasticsearch.test.EqualsHashCodeTestUtils
-
- EqualsHashCodeTestUtils.CopyFunction<T> - Interface in org.elasticsearch.test
-
A function that makes a copy of its input argument
- EqualsHashCodeTestUtils.MutateFunction<T> - Interface in org.elasticsearch.test
-
A function that creates a copy of its input argument that is different from its
input in exactly one aspect (e.g.
- errors() - Method in class org.elasticsearch.test.rest.FakeRestChannel
-
- ESAllocationTestCase - Class in org.elasticsearch.cluster
-
- ESAllocationTestCase() - Constructor for class org.elasticsearch.cluster.ESAllocationTestCase
-
- ESAllocationTestCase.DelayedShardsMockGatewayAllocator - Class in org.elasticsearch.cluster
-
Mocks behavior in ReplicaShardAllocator to remove delayed shards from list of unassigned shards so they don't get reassigned yet.
- ESAllocationTestCase.MockAllocationService - Class in org.elasticsearch.cluster
-
A lock AllocationService
allowing tests to override time
- ESAllocationTestCase.TestAllocateDecision - Class in org.elasticsearch.cluster
-
- EsBaseDirectoryTestCase - Class in org.elasticsearch.index.store
-
Extends Lucene's BaseDirectoryTestCase with ES test behavior.
- EsBaseDirectoryTestCase() - Constructor for class org.elasticsearch.index.store.EsBaseDirectoryTestCase
-
- ESBlobStoreContainerTestCase - Class in org.elasticsearch.repositories
-
Generic test case for blob store container implementation.
- ESBlobStoreContainerTestCase() - Constructor for class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
-
- ESBlobStoreRepositoryIntegTestCase - Class in org.elasticsearch.repositories.blobstore
-
Basic integration tests for blob-based repository validation.
- ESBlobStoreRepositoryIntegTestCase() - Constructor for class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
-
- ESBlobStoreTestCase - Class in org.elasticsearch.repositories
-
Generic test case for blob store implementation.
- ESBlobStoreTestCase() - Constructor for class org.elasticsearch.repositories.ESBlobStoreTestCase
-
- ESClientYamlSuiteTestCase - Class in org.elasticsearch.test.rest.yaml
-
Runs a suite of yaml tests shared with all the official Elasticsearch clients against against an elasticsearch cluster.
- ESClientYamlSuiteTestCase(ClientYamlTestCandidate) - Constructor for class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
-
- 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.ClusterScope - Annotation Type in org.elasticsearch.test
-
- ESIntegTestCase.NumShards - Class in org.elasticsearch.test
-
- ESIntegTestCase.Scope - Enum in org.elasticsearch.test
-
- ESIntegTestCase.SuiteScopeTestCase - Annotation Type in org.elasticsearch.test
-
If a test is annotated with
ESIntegTestCase.SuiteScopeTestCase
the checks and modifications that are applied to the used test cluster are only done after all tests
of this class are executed.
- ESIntegTestCase.TestSeedPlugin - Class in org.elasticsearch.test
-
- ESIntegTestCase.ThirdParty - Annotation Type in org.elasticsearch.test
-
Annotation for third-party integration tests.
- ESRestTestCase - Class in org.elasticsearch.test.rest
-
Superclass for tests that interact with an external test cluster using Elasticsearch's RestClient
.
- ESRestTestCase() - Constructor for class org.elasticsearch.test.rest.ESRestTestCase
-
- ESSelector - Class in org.elasticsearch.transport.nio
-
- 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(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, 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(Object, String) - Static method in class org.elasticsearch.test.rest.yaml.ObjectPath
-
- 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.ObjectPath
-
Returns the object corresponding to the provided path if present, null otherwise
- EventHandler - Class in org.elasticsearch.transport.nio
-
- EventHandler(Logger) - Constructor for class org.elasticsearch.transport.nio.EventHandler
-
- ExceptionWrapper(Exception) - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchAssertions.ExceptionWrapper
-
- ExceptionWrapper() - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchAssertions.ExceptionWrapper
-
- 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(String...) - Method in class org.elasticsearch.cli.CommandTestCase
-
Runs the command with the given args.
- execute(IngestDocument) - Method in class org.elasticsearch.ingest.TestProcessor
-
- execute() - Method in class org.elasticsearch.ingest.TestTemplateService.MockTemplateScript
-
- 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
-
- executeGet(GetRequest) - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Override this to handle Client.get(GetRequest)
calls from parsers / builders
- executeMultiTermVectors(MultiTermVectorsRequest) - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Override this to handle Client.get(GetRequest)
calls from parsers / builders
- expectedMessageLength() - Method in class org.elasticsearch.transport.nio.channel.TcpFrameDecoder
-
- expectedTimeToHeal() - Method in class org.elasticsearch.test.disruption.BlockClusterStateProcessing
-
- 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 class org.elasticsearch.test.disruption.NoOpDisruptionScheme
-
- expectedTimeToHeal() - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
-
- expectedTimeToHeal() - Method in class org.elasticsearch.test.disruption.SlowClusterStateProcessing
-
- explain() - Method in class org.elasticsearch.test.TestSearchContext
-
- explain(boolean) - Method in class org.elasticsearch.test.TestSearchContext
-
- EXTERNAL_CLUSTER_PREFIX - Static variable in class org.elasticsearch.test.ExternalTestCluster
-
- externalClusterClientSettings() - Method in class org.elasticsearch.test.ESIntegTestCase
-
- ExternalTestCluster - Class in org.elasticsearch.test
-
External cluster to run the tests against.
- ExternalTestCluster(Path, Settings, Collection<Class<? extends Plugin>>, TransportAddress...) - Constructor for class org.elasticsearch.test.ExternalTestCluster
-
- extraAssertReduced(T, List<T>) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
-
- extractTransportAddresses(TransportService) - Static method in class org.elasticsearch.test.transport.MockTransportService
-
- generateRandomNames(int) - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
-
- generateRandomStringArray(int, int, boolean, boolean) - Static method in class org.elasticsearch.test.ESTestCase
-
- generateRandomStringArray(int, int, boolean) - Static method in class org.elasticsearch.test.ESTestCase
-
- genericChannelException(NioSocketChannel, Exception) - Method in class org.elasticsearch.transport.nio.SocketEventHandler
-
This method is called when handling an event from a channel fails due to an unexpected exception.
- genericServerChannelException(NioServerSocketChannel, Exception) - Method in class org.elasticsearch.transport.nio.AcceptorEventHandler
-
This method is called when handling an event from a channel fails due to an unexpected exception.
- GEO_POINT_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractQueryTestCase
-
- GEO_SHAPE_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractQueryTestCase
-
- GeohashGenerator() - Constructor for class org.elasticsearch.test.ESTestCase.GeohashGenerator
-
- get(String, String, String) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Syntactic sugar for:
- get(int) - Method in class org.elasticsearch.transport.nio.NetworkBytesReference
-
- get() - Method in class org.elasticsearch.transport.nio.RoundRobinSelectorSupplier
-
- getAcceptedChannels() - Method in class org.elasticsearch.transport.nio.OpenChannels
-
- getActualValue(ClientYamlTestExecutionContext) - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
-
- getAdminExecutionContext() - Method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
-
- 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)
.
- getAlternateVersions() - Method in class org.elasticsearch.test.AbstractSerializingTestCase
-
Returns alternate string representation of the instance that need to be
tested as they are never used as output of the test instance.
- getAlternateVersions() - Method in class org.elasticsearch.test.AbstractStreamableXContentTestCase
-
Returns alternate string representation of the instance that need to be
tested as they are never used as output of the test instance.
- getApi() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
-
- getApi(String) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestSpec
-
- getApi() - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
-
- getApi() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
-
- getApiCallSection() - Method in class org.elasticsearch.test.rest.yaml.section.DoSection
-
- getApis() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestSpec
-
- getAutoManageMinMasterNode() - Method in class org.elasticsearch.test.InternalTestCluster
-
returns true if the ElectMasterService.DISCOVERY_ZEN_MINIMUM_MASTER_NODES_SETTING
setting is auto managed by this cluster
- getBinaryDocValues(String) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
-
- getBlockDetectionIntervalInMillis() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
-
- getBodies() - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
-
- getBody() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestResponse
-
Returns the body properly parsed depending on the content type.
- getBodyAsString() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestResponse
-
Returns the body as a string
- getBridgeNode() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.Bridge
-
- getBwcIndicesPath() - Method in class org.elasticsearch.test.ESTestCase
-
- getByteReferences() - Method in class org.elasticsearch.transport.nio.WriteOperation
-
- 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
-
- getChannel() - Method in class org.elasticsearch.transport.nio.WriteOperation
-
- getChannelFactory() - Method in class org.elasticsearch.transport.nio.channel.NioServerSocketChannel
-
- 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.
- 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.
- getCloseException() - Method in class org.elasticsearch.transport.nio.channel.CloseFuture
-
- getCloseFuture() - Method in class org.elasticsearch.transport.nio.channel.AbstractNioChannel
-
- getCloseFuture() - Method in interface org.elasticsearch.transport.nio.channel.NioChannel
-
- 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
- getConnectFuture() - Method in class org.elasticsearch.transport.nio.channel.NioSocketChannel
-
- getConnection(DiscoveryNode) - Method in class org.elasticsearch.test.transport.CapturingTransport
-
- getConnection(DiscoveryNode) - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- getCopyFunction() - Method in class org.elasticsearch.test.AbstractStreamableTestCase
-
- getCopyPermissions() - Method in class org.elasticsearch.test.PosixPermissionsResetter
-
- getCoreCacheHelper() - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
-
- getCurrentTypes() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
-
- getCurrentTypes() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
- getCurrentVersion() - Method in class org.elasticsearch.transport.MockTcpTransport
-
- 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(ShardRouting) - Method in class org.elasticsearch.cluster.MockInternalClusterInfoService.DevNullClusterInfo
-
- getDataPath(String) - Method in class org.elasticsearch.test.ESTestCase
-
Returns a Path
pointing to the class path relative resource given
as the first argument.
- getDefaultNamedXContents() - Static method in class org.elasticsearch.test.InternalAggregationTestCase
-
- getDefaultSettings() - Method in class org.elasticsearch.test.InternalTestCluster
-
- getDiscoveryTypes(ThreadPool, TransportService, NamedWriteableRegistry, MasterService, ClusterApplier, ClusterSettings, UnicastHostsProvider, AllocationService) - Method in class org.elasticsearch.test.discovery.TestZenDiscovery.TestPlugin
-
- getDisruptedLinks() - Method in class org.elasticsearch.test.disruption.NetworkDisruption
-
- getDoSections() - Method in class org.elasticsearch.test.rest.yaml.section.SetupSection
-
- getDoSections() - Method in class org.elasticsearch.test.rest.yaml.section.TeardownSection
-
- getEngine(IndexShard) - Static method in class org.elasticsearch.index.shard.IndexShardTestCase
-
Helper method to access (package-protected) engine from tests
- getEsVersion() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestClient
-
- getException() - Method in class org.elasticsearch.transport.nio.channel.ConnectFuture
-
- getExecutableSections() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSection
-
- getExpectedValue() - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
-
- getExpectedWarningHeaders() - Method in class org.elasticsearch.test.rest.yaml.section.DoSection
-
Warning headers that we expect from this response.
- getFailures() - Method in class org.elasticsearch.test.BackgroundIndexer
-
- getFakeDiscoNode(String) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
- getFeatures() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
-
- getField() - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
-
- getFile(String) - Method in class org.elasticsearch.common.settings.MockSecureSettings
-
- getFinalPaths(Map<String, String>) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
-
Finds the best matching rest path given the current parameters and replaces
placeholders with their corresponding values received as arguments
- getFirstVersion() - Static method in class org.elasticsearch.test.VersionUtils
-
Returns the oldest released Version
- getForField(MappedFieldType) - Method in class org.elasticsearch.test.TestSearchContext
-
- getHeaders() - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
-
- 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.AbstractQueryTestCase
-
- getIndexDir(Logger, String, String, Path) - Static method in class org.elasticsearch.test.OldIndexUtils
-
- getInstance(Class<T>, String) - Method in class org.elasticsearch.test.InternalTestCluster
-
Returns a reference to the given nodes instances of the given class >T<
- getInstance(Class<T>) - Method in class org.elasticsearch.test.InternalTestCluster
-
Returns a reference to a random 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
-
- getListener() - Method in class org.elasticsearch.transport.nio.WriteOperation
-
- getLocalAddress(MockTcpTransport.MockChannel) - Method in class org.elasticsearch.transport.MockTcpTransport
-
- getLocalAddress() - Method in class org.elasticsearch.transport.nio.channel.AbstractNioChannel
-
- getLocalAddress() - Method in interface org.elasticsearch.transport.nio.channel.NioChannel
-
- getLocalAddress(NioChannel) - Method in class org.elasticsearch.transport.nio.NioTransport
-
- getLocalAddresses() - Method in class org.elasticsearch.test.transport.CapturingTransport
-
- getLocalAddresses() - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- getLocalDiscoNode() - Method in class org.elasticsearch.test.transport.MockTransportService
-
- 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
-
- getLowerVersion() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
-
- getMajoritySide() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
-
- getMappingUpdater(IndexShard, String) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
- 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.
- getMethods() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
-
- getMinoritySide() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
-
- getMockPlugins() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Return the mock plugins the cluster should use
- getMutateFunction() - Method in class org.elasticsearch.test.AbstractStreamableTestCase
-
- 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.AbstractStreamableTestCase
-
Get the NamedWriteableRegistry
to use when de-serializing the object.
- getNamedWriteableRegistry() - Method in class org.elasticsearch.test.AbstractWireSerializingTestCase
-
Get the NamedWriteableRegistry
to use when de-serializing the object.
- getNamedWriteableRegistry() - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
- getNamedXContents() - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
- getNetworkLinkDisruptionType() - Method in class org.elasticsearch.test.disruption.NetworkDisruption
-
- getNodeConfigSource() - Method in class org.elasticsearch.test.ESIntegTestCase
-
- getNodeNames() - Method in class org.elasticsearch.test.InternalTestCluster
-
- 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
-
- getNumOpenServerConnections() - Method in class org.elasticsearch.transport.MockTcpTransport
-
- getNumOpenServerConnections() - Method in class org.elasticsearch.transport.nio.NioTransport
-
- getNumPages(BytesReference) - Static method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- getNumShards(String) - Method in class org.elasticsearch.test.ESIntegTestCase
-
- getObjectMapper(String) - Method in class org.elasticsearch.test.TestSearchContext
-
- getObjectsHoldingArbitraryContent() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
- getOriginalTransport() - Method in class org.elasticsearch.test.transport.MockTransportService
-
- getOriginNanoTime() - Method in class org.elasticsearch.test.TestSearchContext
-
- getOutput() - Method in class org.elasticsearch.cli.MockTerminal
-
Returns all output written to this terminal.
- getParams() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
-
- getParams() - Method in class org.elasticsearch.test.rest.yaml.section.ApiCallSection
-
- getPath() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
-
- getPathParts() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
-
- getPathParts() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestPath
-
- getPaths() - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
-
- 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.search.aggregations.BaseAggregationTestCase
-
- getPlugins() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
- getPlugins() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
The plugin classes that should be added to the node.
- getPlugins() - Method in class org.elasticsearch.test.InternalTestCluster
-
- getPreConfiguredCharFilters() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
-
- getPreConfiguredTokenFilters() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
-
Map containing pre-configured token filters that should be available
after installing this plugin.
- getPreConfiguredTokenizers() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
-
Map containing pre-configured tokenizers that should be available
after installing this plugin.
- getPreviousMinorVersion() - Static method in class org.elasticsearch.test.VersionUtils
-
Returns the released Version
before the Version.CURRENT
where the minor version is less than the currents minor version.
- getPreviousVersion(Version) - Static method in class org.elasticsearch.test.VersionUtils
-
Get the released version before version
.
- getPreviousVersion() - Static method in class org.elasticsearch.test.VersionUtils
-
Get the released version before Version.CURRENT
.
- getProcessors(Processor.Parameters) - Method in class org.elasticsearch.ingest.IngestTestPlugin
-
- getProfile() - Method in class org.elasticsearch.transport.nio.channel.AbstractNioChannel
-
- getProfile() - Method in interface org.elasticsearch.transport.nio.channel.NioChannel
-
- getProfilers() - Method in class org.elasticsearch.test.TestSearchContext
-
- getProtocol() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Override this to switch to testing https.
- getQueryShardContext() - Method in class org.elasticsearch.test.TestSearchContext
-
- getRandomFieldName() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
Helper method to return a mapped or a random field
- getRandomQueryText() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
- getRandomRewriteMethod() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
Helper method to return a random rewrite method
- getRandomValueForFieldName(String) - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
- getRawChannel() - Method in class org.elasticsearch.transport.nio.channel.AbstractNioChannel
-
- getRawChannel() - Method in interface org.elasticsearch.transport.nio.channel.NioChannel
-
- getReadByteBuffer() - Method in class org.elasticsearch.transport.nio.NetworkBytesReference
-
- getReadContext() - Method in class org.elasticsearch.transport.nio.channel.NioSocketChannel
-
- 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
-
- getReadIndex() - Method in class org.elasticsearch.transport.nio.NetworkBytesReference
-
- getReadRemaining() - Method in class org.elasticsearch.transport.nio.NetworkBytesReference
-
- getReason() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
-
- getReasonPhrase() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestResponse
-
- getRegisteredChannels() - Method in class org.elasticsearch.transport.nio.ESSelector
-
- getRemoteAddress() - Method in class org.elasticsearch.test.rest.FakeRestRequest
-
- getRemoteAddress() - Method in class org.elasticsearch.transport.nio.channel.NioSocketChannel
-
- getResponseException() - Method in exception org.elasticsearch.test.rest.yaml.ClientYamlTestResponseException
-
Exposes the origina ResponseException
.
- getRestClient() - Static method in class org.elasticsearch.test.ESIntegTestCase
-
Returns an instance of RestClient
pointing to the current test cluster.
- getRestTestResponse() - Method in exception org.elasticsearch.test.rest.yaml.ClientYamlTestResponseException
-
Exposes the obtained response body
- getScriptEngine(Settings, Collection<ScriptContext<?>>) - Method in class org.elasticsearch.script.MockScriptPlugin
-
- getSearchExt(String) - Method in class org.elasticsearch.test.TestSearchContext
-
- getSelectionKey() - Method in class org.elasticsearch.transport.nio.channel.AbstractNioChannel
-
- getSelectionKey() - Method in interface org.elasticsearch.transport.nio.channel.NioChannel
-
- getSelector() - Method in class org.elasticsearch.transport.nio.channel.AbstractNioChannel
-
- getSelector() - Method in interface org.elasticsearch.transport.nio.channel.NioChannel
-
- getSelector() - Method in class org.elasticsearch.transport.nio.channel.NioSocketChannel
-
- getSettingNames() - Method in class org.elasticsearch.common.settings.MockSecureSettings
-
- getSettings() - Method in class org.elasticsearch.index.MockEngineFactoryPlugin
-
- getSettings() - Method in class org.elasticsearch.node.RecoverySettingsChunkSizePlugin
-
- getSettings() - Method in class org.elasticsearch.test.discovery.TestZenDiscovery.TestPlugin
-
- getSettings() - Method in class org.elasticsearch.test.ESIntegTestCase.TestSeedPlugin
-
- getSettings() - Method in class org.elasticsearch.test.InternalSettingsPlugin
-
- getSettings() - Method in class org.elasticsearch.test.MockIndexEventListener.TestPlugin
-
- getSettings() - Static method in class org.elasticsearch.test.OldIndexUtils
-
- getSettings() - Method in class org.elasticsearch.test.store.MockFSIndexStore.TestPlugin
-
- getSettings() - Method in class org.elasticsearch.test.transport.MockTransportService.TestPlugin
-
- getSetupSection() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
-
- getSetupSection() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
-
- getShardDocUIDs(IndexShard) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
- 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
-
- getSocketEventHandler() - Method in class org.elasticsearch.transport.nio.NioTransport
-
- getSortedDocValues(String) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
-
- getSortedSetDocValues(String) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
-
- getStash() - Method in class org.elasticsearch.test.rest.yaml.section.SetSection
-
- getStats() - Method in class org.elasticsearch.test.transport.CapturingTransport
-
- getStats() - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- getStatusCode() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestResponse
-
- getString(String) - Method in class org.elasticsearch.common.settings.MockSecureSettings
-
- getSuiteFailureMarker() - Static method in class org.elasticsearch.test.ESTestCase
-
Returns the suite failure marker: internal use only!
- getSuitePath() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
-
- getSupportedMethods(Set<String>) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestApi
-
Returns the supported http methods given the rest parameters provided
- getSuspendingTimeoutInMillis() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
-
- getTag() - Method in class org.elasticsearch.ingest.TestProcessor
-
- getTask() - Method in class org.elasticsearch.test.TestSearchContext
-
- getTeardownSection() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
-
- getTeardownSection() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
-
- getTermVectors(int) - Method in class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
-
- getTestPath() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
-
- getTestSection() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
-
- getTestSections() - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
-
- getTokenFilters() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
-
- getTokenizers() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
-
- getTransportInterceptors(NamedWriteableRegistry, ThreadContext) - Method in class org.elasticsearch.transport.AssertingTransportInterceptor.TestPlugin
-
- getTransports(Settings, ThreadPool, BigArrays, CircuitBreakerService, NamedWriteableRegistry, NetworkService) - Method in class org.elasticsearch.transport.MockTcpTransportPlugin
-
- getType() - Method in class org.elasticsearch.ingest.TestProcessor
-
- getType() - Method in class org.elasticsearch.script.MockScriptEngine
-
- getUnsafeClasses() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
-
- getUpperVersion() - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
-
- getValue(String) - Method in class org.elasticsearch.test.rest.yaml.Stash
-
Retrieves a value from the current stash.
- 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.
- getWriteByteBuffer() - Method in class org.elasticsearch.transport.nio.NetworkBytesReference
-
- getWriteContext() - Method in class org.elasticsearch.transport.nio.channel.NioSocketChannel
-
- getWriteIndex() - Method in class org.elasticsearch.transport.nio.NetworkBytesReference
-
- getWriter() - Method in class org.elasticsearch.cli.MockTerminal
-
- getWriteRemaining() - Method in class org.elasticsearch.transport.nio.NetworkBytesReference
-
- getZenPing() - Method in class org.elasticsearch.test.discovery.TestZenDiscovery
-
- GradleMessageBuilder(StringBuilder) - Constructor for class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter.GradleMessageBuilder
-
- GreaterThanAssertion - Class in org.elasticsearch.test.rest.yaml.section
-
Represents a gt assert section:
- GreaterThanAssertion(XContentLocation, String, Object) - Constructor for class org.elasticsearch.test.rest.yaml.section.GreaterThanAssertion
-
- GreaterThanEqualToAssertion - Class in org.elasticsearch.test.rest.yaml.section
-
Represents a gte assert section:
- gte: { fields._ttl: 0 }
- GreaterThanEqualToAssertion(XContentLocation, String, Object) - Constructor for class org.elasticsearch.test.rest.yaml.section.GreaterThanEqualToAssertion
-
- groupStats() - Method in class org.elasticsearch.test.TestSearchContext
-
- groupStats(List<String>) - Method in class org.elasticsearch.test.TestSearchContext
-
- makeStats(String, DiskUsage) - Static method in class org.elasticsearch.cluster.MockInternalClusterInfoService
-
Create a fake NodeStats for the given node and usage
- 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.AbstractQueryTestCase
-
- MAPPED_LEAF_FIELD_NAMES - Static variable in class org.elasticsearch.test.AbstractQueryTestCase
-
- mapperService() - Method in class org.elasticsearch.test.TestSearchContext
-
- mapperServiceMock() - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
sub-tests that need a more complex mock can overwrite this
- MapperTestUtils - Class in org.elasticsearch.index
-
- MapperTestUtils() - Constructor for class org.elasticsearch.index.MapperTestUtils
-
- MASTER_DATA_ROLES - Static variable in class org.elasticsearch.cluster.ESAllocationTestCase
-
- masterClient() - Method in class org.elasticsearch.test.InternalTestCluster
-
Returns a node client to the current master node.
- match(LogEvent) - Method in class org.elasticsearch.test.MockLogAppender.AbstractEventExpectation
-
- match(LogEvent) - Method in interface org.elasticsearch.test.MockLogAppender.LoggingExpectation
-
- MatchAssertion - Class in org.elasticsearch.test.rest.yaml.section
-
Represents a match assert section:
- match: { get.fields._routing: "5" }
- MatchAssertion(XContentLocation, String, Object) - Constructor for class org.elasticsearch.test.rest.yaml.section.MatchAssertion
-
- matches(String) - Static method in class org.elasticsearch.test.hamcrest.RegexMatcher
-
- matches(String, int) - Static method in class org.elasticsearch.test.hamcrest.RegexMatcher
-
- matches(Set<String>) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestPath
-
- matchesSafely(ImmutableOpenMap) - Method in class org.elasticsearch.test.hamcrest.CollectionMatchers.ImmutableOpenMapHasKeyMatcher
-
- matchesSafely(SearchHit) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasIdMatcher
-
- matchesSafely(SearchHit) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasIndexMatcher
-
- matchesSafely(SearchHit) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasScoreMatcher
-
- matchesSafely(SearchHit) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasTypeMatcher
-
- matchesSafely(String) - Method in class org.elasticsearch.test.hamcrest.RegexMatcher
-
- 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
-
- maxValue - Static variable in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- maxValues - Static variable in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- maybeSet(Consumer<T>, T) - Static method in class org.elasticsearch.test.ESTestCase
-
helper to randomly perform on consumer
with value
- maybeThrow(ThrowingLeafReaderWrapper.Flags) - Method in interface org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Thrower
-
Maybe throws an exception ;)
- maybeWrapReaderEs(DirectoryReader) - Static method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Added to randomly run with more assertions on the index reader level,
like LuceneTestCase.wrapReader(IndexReader)
, which can't be used because it also
wraps in the IndexReader with other implementations that we can't handle.
- merge(MockSecureSettings) - Method in class org.elasticsearch.common.settings.MockSecureSettings
-
Merge the given secure settings into this one.
- MERGE_ENABLED - Static variable in class org.elasticsearch.test.InternalSettingsPlugin
-
- message - Variable in class org.elasticsearch.test.MockLogAppender.AbstractEventExpectation
-
- method() - Method in class org.elasticsearch.test.rest.FakeRestRequest
-
- minimumNumberOfReplicas() - Method in class org.elasticsearch.test.ESIntegTestCase
-
- minimumNumberOfShards() - Method in class org.elasticsearch.test.ESIntegTestCase
-
- minimumScore(float) - Method in class org.elasticsearch.test.TestSearchContext
-
- minimumScore() - Method in class org.elasticsearch.test.TestSearchContext
-
- minValue - Static variable in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- minValues - Static variable in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- MOCK_TCP_TRANSPORT_NAME - Static variable in class org.elasticsearch.transport.MockTcpTransportPlugin
-
- MockAllocationService(Settings, AllocationDeciders, GatewayAllocator, ShardsAllocator, ClusterInfoService) - Constructor for class org.elasticsearch.cluster.ESAllocationTestCase.MockAllocationService
-
- MockBigArrays - Class in org.elasticsearch.common.util
-
- MockBigArrays(Settings, CircuitBreakerService) - Constructor for class org.elasticsearch.common.util.MockBigArrays
-
- MockChannel(Socket, InetSocketAddress, String, Consumer<MockTcpTransport.MockChannel>) - Constructor for class org.elasticsearch.transport.MockTcpTransport.MockChannel
-
Constructs a new MockChannel instance intended for handling the actual incoming / outgoing traffic.
- MockChannel(ServerSocket, String) - Constructor for class org.elasticsearch.transport.MockTcpTransport.MockChannel
-
Constructs a new MockChannel instance intended for accepting requests.
- MockCompiledScript(String, Map<String, String>, String, Function<Map<String, Object>, Object>) - Constructor for class org.elasticsearch.script.MockScriptEngine.MockCompiledScript
-
- MockContext(Random, boolean, Class<? extends FilterDirectoryReader>, Settings) - Constructor for class org.elasticsearch.test.engine.MockEngineSupport.MockContext
-
- MockEngineFactory - Class in org.elasticsearch.test.engine
-
- MockEngineFactory(Class<? extends FilterDirectoryReader>) - Constructor for class org.elasticsearch.test.engine.MockEngineFactory
-
- MockEngineFactoryPlugin - Class in org.elasticsearch.index
-
- 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
-
- MockExecutableScript(Map<String, Object>, Function<Map<String, Object>, Object>) - Constructor for class org.elasticsearch.script.MockScriptEngine.MockExecutableScript
-
- MockFieldMapper - Class in org.elasticsearch.index.mapper
-
- MockFieldMapper(String) - Constructor for class org.elasticsearch.index.mapper.MockFieldMapper
-
- MockFieldMapper(String, MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.MockFieldMapper
-
- MockFieldMapper.FakeFieldType - Class in org.elasticsearch.index.mapper
-
- MockFSDirectoryService - Class in org.elasticsearch.test.store
-
- MockFSDirectoryService(IndexSettings, IndexStore, ShardPath) - Constructor for class org.elasticsearch.test.store.MockFSDirectoryService
-
- MockFSDirectoryService.ElasticsearchMockDirectoryWrapper - Class in org.elasticsearch.test.store
-
- MockFSIndexStore - Class in org.elasticsearch.test.store
-
- MockFSIndexStore.TestPlugin - Class in org.elasticsearch.test.store
-
- MockIndexEventListener - Class in org.elasticsearch.test
-
- 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
-
Fake ClusterInfoService class that allows updating the nodes stats disk
usage with fake values
- MockInternalClusterInfoService(Settings, ClusterService, ThreadPool, NodeClient, Consumer<ClusterInfo>) - Constructor for class org.elasticsearch.cluster.MockInternalClusterInfoService
-
- MockInternalClusterInfoService.DevNullClusterInfo - Class in org.elasticsearch.cluster
-
ClusterInfo that always points to DevNull.
- MockInternalClusterInfoService.TestPlugin - Class in org.elasticsearch.cluster
-
This is a marker plugin used to trigger MockNode to use this mock info service.
- 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.LoggingExpectation - Interface in org.elasticsearch.test
-
- MockLogAppender.SeenEventExpectation - Class in org.elasticsearch.test
-
- MockLogAppender.UnseenEventExpectation - Class in org.elasticsearch.test
-
- 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>>, Path) - Constructor for class org.elasticsearch.node.MockNode
-
- MockNode(Environment, Collection<Class<? extends Plugin>>) - Constructor for class org.elasticsearch.node.MockNode
-
- MockPageCacheRecycler - Class in org.elasticsearch.common.util
-
- 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(String, Map<String, Function<Map<String, Object>, Object>>) - Constructor for class org.elasticsearch.script.MockScriptEngine
-
- MockScriptEngine() - Constructor for class org.elasticsearch.script.MockScriptEngine
-
- MockScriptEngine.MockCompiledScript - Class in org.elasticsearch.script
-
- MockScriptEngine.MockExecutableScript - Class in org.elasticsearch.script
-
- MockScriptEngine.MockSearchScript - Class in org.elasticsearch.script
-
- MockScriptPlugin - Class in org.elasticsearch.script
-
- MockScriptPlugin() - Constructor for class org.elasticsearch.script.MockScriptPlugin
-
- mockScriptService() - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
overwrite in tests that need it
- MockSearchScript(SearchLookup, Map<String, Object>, Function<Map<String, Object>, Object>) - Constructor for class org.elasticsearch.script.MockScriptEngine.MockSearchScript
-
- MockSearchService - Class in org.elasticsearch.search
-
- MockSearchService(ClusterService, IndicesService, ThreadPool, ScriptService, BigArrays, FetchPhase) - Constructor for class org.elasticsearch.search.MockSearchService
-
- MockSearchService.TestPlugin - Class in org.elasticsearch.search
-
- MockSecureSettings - Class in org.elasticsearch.common.settings
-
A mock implementation of secure settings for tests to use.
- MockSecureSettings() - Constructor for class org.elasticsearch.common.settings.MockSecureSettings
-
- MockTaskManager - Class in org.elasticsearch.test.tasks
-
A mock task manager that allows adding listeners for events
- MockTaskManager(Settings) - Constructor for class org.elasticsearch.test.tasks.MockTaskManager
-
- MockTaskManagerListener - Interface in org.elasticsearch.test.tasks
-
Listener for task registration/unregistration
- MockTcpTransport - Class in org.elasticsearch.transport
-
This is a socket based blocking TcpTransport implementation that is used for tests
that need real networking.
- MockTcpTransport(Settings, ThreadPool, BigArrays, CircuitBreakerService, NamedWriteableRegistry, NetworkService) - Constructor for class org.elasticsearch.transport.MockTcpTransport
-
- MockTcpTransport(Settings, ThreadPool, BigArrays, CircuitBreakerService, NamedWriteableRegistry, NetworkService, Version) - Constructor for class org.elasticsearch.transport.MockTcpTransport
-
- MockTcpTransport.MockChannel - Class in org.elasticsearch.transport
-
- MockTcpTransportPlugin - Class in org.elasticsearch.transport
-
- MockTcpTransportPlugin() - Constructor for class org.elasticsearch.transport.MockTcpTransportPlugin
-
- MockTerminal - Class in org.elasticsearch.cli
-
A terminal for tests which captures all output, and
can be plugged with fake input.
- MockTerminal() - Constructor for class org.elasticsearch.cli.MockTerminal
-
- MockTransportClient - Class in org.elasticsearch.transport
-
- MockTransportClient(Settings, Class<? extends Plugin>...) - Constructor for class org.elasticsearch.transport.MockTransportClient
-
- MockTransportClient(Settings, Collection<Class<? extends Plugin>>) - Constructor for class org.elasticsearch.transport.MockTransportClient
-
- MockTransportClient(Settings, Collection<Class<? extends Plugin>>, TransportClient.HostFailureListener) - Constructor for class org.elasticsearch.transport.MockTransportClient
-
- MockTransportService - Class in org.elasticsearch.test.transport
-
A mock transport service that allows to simulate different network topology failures.
- MockTransportService(Settings, Transport, ThreadPool, TransportInterceptor, ClusterSettings) - Constructor for class org.elasticsearch.test.transport.MockTransportService
-
Build the service.
- MockTransportService(Settings, Transport, ThreadPool, TransportInterceptor, Function<BoundTransportAddress, DiscoveryNode>, ClusterSettings) - Constructor for class org.elasticsearch.test.transport.MockTransportService
-
Build the service.
- MockTransportService.ClearableTransport - Class in org.elasticsearch.test.transport
-
The delegate transport instances defined in this class mock various kinds of disruption types.
- MockTransportService.DelegateTransport - Class in org.elasticsearch.test.transport
-
A pure delegate transport.
- MockTransportService.TestPlugin - Class in org.elasticsearch.test.transport
-
- MockTransportService.Tracer - Class in org.elasticsearch.test.transport
-
- MockZenPing - Class in org.elasticsearch.test.discovery
-
A ZenPing
implementation which returns results based on an static in-memory map.
- MockZenPing(Settings, PingContextProvider) - Constructor for class org.elasticsearch.test.discovery.MockZenPing
-
- Modifier(String, boolean) - Constructor for class org.elasticsearch.index.mapper.FieldTypeTestCase.Modifier
-
- modify(MappedFieldType) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase.Modifier
-
Modifies the property
- ModuleTestCase - Class in org.elasticsearch.common.inject
-
Base testcase for testing Module
implementations.
- ModuleTestCase() - Constructor for class org.elasticsearch.common.inject.ModuleTestCase
-
- moveToStarted(ShardRouting) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
-
- moveToUnassigned(ShardRouting, UnassignedInfo) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
-
- mutate(T) - Method in interface org.elasticsearch.test.EqualsHashCodeTestUtils.MutateFunction
-
- mutateInstance(T) - Method in class org.elasticsearch.search.aggregations.InternalSingleBucketAggregationTestCase
-
- mutateInstance(T) - Method in class org.elasticsearch.test.AbstractWireSerializingTestCase
-
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
-
- NAME - Static variable in class org.elasticsearch.script.MockScriptEngine
-
- NAME - Static variable in class org.elasticsearch.script.MockScriptPlugin
-
- name - Variable in class org.elasticsearch.test.MockLogAppender.AbstractEventExpectation
-
- nameFilter(String...) - Static method in class org.elasticsearch.test.InternalTestCluster
-
Returns a predicate that only accepts settings of nodes with one of the given names.
- needs_score() - Method in class org.elasticsearch.script.MockScriptEngine.MockSearchScript
-
- Network - Annotation Type in org.elasticsearch.test.junit.annotations
-
Annotation used to set if internet network connectivity is required to run the test.
- NetworkBytesReference - Class in org.elasticsearch.transport.nio
-
- NetworkBytesReference(BytesArray, int, int) - Constructor for class org.elasticsearch.transport.nio.NetworkBytesReference
-
- NetworkDelay(TimeValue) - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDelay
-
Delays requests by a fixed time value.
- NetworkDisconnect() - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDisconnect
-
- NetworkDisruption - Class in org.elasticsearch.test.disruption
-
- NetworkDisruption(NetworkDisruption.DisruptedLinks, NetworkDisruption.NetworkLinkDisruptionType) - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption
-
- NetworkDisruption.Bridge - Class in org.elasticsearch.test.disruption
-
Creates two partitions with symmetric failures and a bridge node that can connect to both of the partitions
- NetworkDisruption.DisruptedLinks - Class in org.elasticsearch.test.disruption
-
Represents a set of nodes with connections between nodes that are to be disrupted
- NetworkDisruption.IsolateAllNodes - Class in org.elasticsearch.test.disruption
-
- NetworkDisruption.NetworkDelay - Class in org.elasticsearch.test.disruption
-
Simulates slow or congested network.
- NetworkDisruption.NetworkDisconnect - Class in org.elasticsearch.test.disruption
-
Simulates a network disconnect.
- NetworkDisruption.NetworkLinkDisruptionType - Class in org.elasticsearch.test.disruption
-
Abstract class representing various types of network disruptions.
- NetworkDisruption.NetworkUnresponsive - Class in org.elasticsearch.test.disruption
-
Simulates an unresponsive target node by dropping requests sent from source to target node.
- NetworkDisruption.TwoPartitions - Class in org.elasticsearch.test.disruption
-
Creates two partitions with symmetric failures
- NetworkLinkDisruptionType() - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.NetworkLinkDisruptionType
-
- NetworkUnresponsive() - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.NetworkUnresponsive
-
- newAnalysisSettingsBuilder() - Method in class org.elasticsearch.test.ESTokenStreamTestCase
-
- newBlobStore() - Method in class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
-
- newBlobStore() - Method in class org.elasticsearch.repositories.ESBlobStoreTestCase
-
- newBuilder() - Method in class org.elasticsearch.test.rest.FakeRestChannel
-
- newBuilder(XContentType, boolean) - Method in class org.elasticsearch.test.rest.FakeRestChannel
-
- newByteArray(long, boolean) - Method in class org.elasticsearch.common.util.MockBigArrays
-
- newBytesOutput() - Method in class org.elasticsearch.test.rest.FakeRestChannel
-
- newBytesReference(int) - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- newBytesReferenceWithOffsetOfZero(int) - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- newClusterInfoService(Settings, ClusterService, ThreadPool, NodeClient, Consumer<ClusterInfo>) - Method in class org.elasticsearch.node.MockNode
-
- newCommand() - Method in class org.elasticsearch.cli.CommandTestCase
-
Creates a Command to test execution.
- newDirectory() - Method in class org.elasticsearch.test.store.MockFSDirectoryService
-
- newDirectoryService(ShardPath) - Method in class org.elasticsearch.test.store.MockFSIndexStore
-
- newDoubleArray(long, boolean) - Method in class org.elasticsearch.common.util.MockBigArrays
-
- newErrorBuilder() - Method in class org.elasticsearch.test.rest.FakeRestChannel
-
- newFloatArray(long, boolean) - Method in class org.elasticsearch.common.util.MockBigArrays
-
- newFSDirectory(Path, LockFactory) - Method in class org.elasticsearch.test.store.MockFSDirectoryService
-
- 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(Index, Settings, Setting<?>...) - Static method in class org.elasticsearch.test.IndexSettingsModule
-
- newIndexSettings(Index, Settings, Settings, Setting<?>...) - Static method in class org.elasticsearch.test.IndexSettingsModule
-
- newIndexSettings(Index, Settings, IndexScopedSettings) - Static method in class org.elasticsearch.test.IndexSettingsModule
-
- newIndexSettings(IndexMetaData, Setting<?>...) - Static method in class org.elasticsearch.test.IndexSettingsModule
-
- newInstance(Map<String, Object>) - Method in class org.elasticsearch.ingest.TestTemplateService.MockTemplateScript.Factory
-
- newInstance(LeafReaderContext) - Method in class org.elasticsearch.script.MockScriptEngine.MockSearchScript
-
- newIntArray(long, boolean) - Method in class org.elasticsearch.common.util.MockBigArrays
-
- newLongArray(long, boolean) - Method in class org.elasticsearch.common.util.MockBigArrays
-
- newMapperService(NamedXContentRegistry, Path, Settings, String) - Static method in class org.elasticsearch.index.MapperTestUtils
-
- newMapperService(NamedXContentRegistry, Path, Settings, IndicesModule, String) - Static method in class org.elasticsearch.index.MapperTestUtils
-
- newNode(String) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
- newNode(String, String, Map<String, String>) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
- newNode(String, Map<String, String>) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
- newNode(String, Set<DiscoveryNode.Role>) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
- newNode(String, Version) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
- newNodeEnvironment() - Method in class org.elasticsearch.test.ESTestCase
-
- newNodeEnvironment(Settings) - Method in class org.elasticsearch.test.ESTestCase
-
- newObjectArray(long) - Method in class org.elasticsearch.common.util.MockBigArrays
-
- newReadWriteEngine(EngineConfig) - Method in class org.elasticsearch.test.engine.MockEngineFactory
-
- newRequestId() - Method in class org.elasticsearch.test.transport.CapturingTransport
-
- newRequestId() - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- newSearcher(String, IndexSearcher, SearcherManager) - Method in class org.elasticsearch.test.engine.MockEngineSupport
-
- newSearchService(ClusterService, IndicesService, ThreadPool, ScriptService, BigArrays, FetchPhase, ResponseCollectorService) - Method in class org.elasticsearch.node.MockNode
-
- newShard(boolean) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
creates a new initializing shard.
- newShard(ShardRouting, IndexingOperationListener...) - 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.
- newShard(ShardId, boolean, String, IndexMetaData, IndexSearcherWrapper) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
creates a new initializing shard.
- newShard(ShardId, boolean, String, IndexMetaData, Runnable, IndexSearcherWrapper) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
creates a new initializing shard.
- newShard(ShardRouting, IndexMetaData, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
creates a new initializing shard.
- newShard(ShardRouting, IndexMetaData, IndexSearcherWrapper, EngineFactory, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
creates a new initializing shard.
- newShard(ShardRouting, ShardPath, IndexMetaData, IndexSearcherWrapper, EngineFactory, 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(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(String, int, String, String, boolean, ShardRoutingState) - 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(String, int, String, String, boolean, ShardRoutingState, AllocationId) - 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(String, int, String, String, boolean, ShardRoutingState, UnassignedInfo) - 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 empyu shard and starts it.
- newStartedShard(boolean) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
creates a new empty shard and starts it.
- newTestIndicesModule(Map<String, Mapper.TypeParser>, Map<String, MetadataFieldMapper.TypeParser>) - Static method in class org.elasticsearch.test.ESTestCase
-
Creates an IndicesModule for testing with the given mappers and metadata mappers.
- newTestScriptModule() - Static method in class org.elasticsearch.test.ESTestCase
-
- newTransportService(Settings, Transport, ThreadPool, TransportInterceptor, Function<BoundTransportAddress, DiscoveryNode>, ClusterSettings) - Method in class org.elasticsearch.node.MockNode
-
- newWithRestoreSource(ShardRouting, RecoverySource.SnapshotRecoverySource) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
-
- newZenPing(Settings, ThreadPool, TransportService, UnicastHostsProvider) - Method in class org.elasticsearch.test.discovery.TestZenDiscovery
-
- NIO_ACCEPTOR_COUNT - Static variable in class org.elasticsearch.transport.nio.NioTransport
-
- NIO_WORKER_COUNT - Static variable in class org.elasticsearch.transport.nio.NioTransport
-
- NioChannel - Interface in org.elasticsearch.transport.nio.channel
-
- NioClient - Class in org.elasticsearch.transport.nio
-
- NioClient(Logger, OpenChannels, Supplier<SocketSelector>, TimeValue, ChannelFactory) - Constructor for class org.elasticsearch.transport.nio.NioClient
-
- NioServerSocketChannel - Class in org.elasticsearch.transport.nio.channel
-
- NioServerSocketChannel(String, ServerSocketChannel, ChannelFactory, AcceptingSelector) - Constructor for class org.elasticsearch.transport.nio.channel.NioServerSocketChannel
-
- NioShutdown - Class in org.elasticsearch.transport.nio
-
- NioShutdown(Logger) - Constructor for class org.elasticsearch.transport.nio.NioShutdown
-
- NioSocketChannel - Class in org.elasticsearch.transport.nio.channel
-
- NioSocketChannel(String, SocketChannel, SocketSelector) - Constructor for class org.elasticsearch.transport.nio.channel.NioSocketChannel
-
- NioTransport - Class in org.elasticsearch.transport.nio
-
- NioTransport(Settings, ThreadPool, NetworkService, BigArrays, NamedWriteableRegistry, CircuitBreakerService) - Constructor for class org.elasticsearch.transport.nio.NioTransport
-
- noAllocationDeciders() - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
- node() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
Return a reference to the singleton node.
- node - Variable in class org.elasticsearch.test.transport.CapturingTransport.CapturedRequest
-
- nodeA - Variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- nodeB - Variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- nodeConfigPath(int) - Method in class org.elasticsearch.test.discovery.ClusterDiscoveryConfiguration
-
- nodeConfigPath(int) - Method in class org.elasticsearch.test.ESIntegTestCase
-
- nodeConfigPath(int) - Method in class org.elasticsearch.test.NodeConfigurationSource
-
- NodeConfigurationSource - Class in org.elasticsearch.test
-
- NodeConfigurationSource() - Constructor for class org.elasticsearch.test.NodeConfigurationSource
-
- nodeConnected(DiscoveryNode) - Method in class org.elasticsearch.test.transport.CapturingTransport
-
- nodeConnected(DiscoveryNode) - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- NodeMocksPlugin - Class in org.elasticsearch.node
-
- NodeMocksPlugin() - Constructor for class org.elasticsearch.node.NodeMocksPlugin
-
- nodePlugins() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Returns a collection of plugins that should be loaded on each node.
- nodePlugins() - Method in class org.elasticsearch.test.NodeConfigurationSource
-
Returns plugins that should be loaded on the node
- nodePrefix() - Method in class org.elasticsearch.test.InternalTestCluster
-
Returns the common node name prefix for this test cluster.
- nodes() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.DisruptedLinks
-
Set of all nodes that can participate in disruptions
- nodeSettings(int) - Method in class org.elasticsearch.test.discovery.ClusterDiscoveryConfiguration
-
- nodeSettings(int) - Method in class org.elasticsearch.test.discovery.ClusterDiscoveryConfiguration.UnicastZen
-
- nodeSettings(int) - Method in class org.elasticsearch.test.ESIntegTestCase
-
This method is used to obtain settings for the Nth node in the cluster.
- nodeSettings() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
Additional settings to add when creating the node.
- nodeSettings(int) - Method in class org.elasticsearch.test.NodeConfigurationSource
-
- nodesInclude(String) - Method in class org.elasticsearch.test.InternalTestCluster
-
Returns a set of nodes that have at least one shard of the given index.
- nodesSideOne - Variable in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
-
- nodesSideTwo - Variable in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
-
- nonMasterClient() - Method in class org.elasticsearch.test.InternalTestCluster
-
Returns a node client to random node but not the master.
- NoOpClient - Class in org.elasticsearch.test.client
-
Client that always responds with null
to every request.
- NoOpClient(ThreadPool) - Constructor for class org.elasticsearch.test.client.NoOpClient
-
Build with ThreadPool
.
- NoOpClient(String) - Constructor for class org.elasticsearch.test.client.NoOpClient
-
- NoOpDisruptionScheme - Class in org.elasticsearch.test.disruption
-
- NoOpDisruptionScheme() - Constructor for class org.elasticsearch.test.disruption.NoOpDisruptionScheme
-
- NoopGatewayAllocator - Class in org.elasticsearch.test.gateway
-
An allocator used for tests that doesn't do anything
- NoopGatewayAllocator() - Constructor for class org.elasticsearch.test.gateway.NoopGatewayAllocator
-
- normalizeOther(MappedFieldType) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase.Modifier
-
Optional method to implement that allows the field type that will be compared to be modified,
so that it does not have the default value for the property being modified.
- 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.AbstractStreamableTestCase
-
- NUMBER_OF_TEST_RUNS - Static variable in class org.elasticsearch.test.AbstractWireSerializingTestCase
-
- numberOfReplicas() - Method in class org.elasticsearch.test.ESIntegTestCase
-
- numberOfShards() - Method in class org.elasticsearch.test.ESIntegTestCase
-
- numberOfShards() - Method in class org.elasticsearch.test.TestSearchContext
-
- numDataAndMasterNodes() - Method in class org.elasticsearch.test.ExternalTestCluster
-
- numDataAndMasterNodes() - Method in class org.elasticsearch.test.InternalTestCluster
-
- numDataAndMasterNodes() - Method in class org.elasticsearch.test.TestCluster
-
Returns the number of data and master eligible nodes in the cluster.
- numDataNodes() - Method in 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.
- 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
-
- ramBytesUsed() - Method in class org.elasticsearch.transport.nio.NetworkBytesReference
-
- random(Random, String...) - Static method in class org.elasticsearch.test.disruption.NetworkDisruption.Bridge
-
- random(Random, Set<String>) - Static method in class org.elasticsearch.test.disruption.NetworkDisruption.Bridge
-
- random(Random) - Static method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDelay
-
- 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(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.TwoPartitions
-
- random - Variable in class org.elasticsearch.test.disruption.SingleNodeDisruption
-
- random - Variable in class org.elasticsearch.test.TestCluster
-
- RANDOM_IO_EXCEPTION_RATE_ON_OPEN_SETTING - Static variable in class org.elasticsearch.test.store.MockFSDirectoryService
-
- RANDOM_IO_EXCEPTION_RATE_SETTING - Static variable in class org.elasticsearch.test.store.MockFSDirectoryService
-
- RANDOM_NO_DELETE_OPEN_FILE_SETTING - Static variable in class org.elasticsearch.test.store.MockFSDirectoryService
-
- RANDOM_PREVENT_DOUBLE_WRITE_SETTING - Static variable in class org.elasticsearch.test.store.MockFSDirectoryService
-
- randomAllocationDeciders(Settings, ClusterSettings, Random) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
- randomAlphaOfLength(int) - Static method in class org.elasticsearch.test.ESTestCase
-
- randomAlphaOfLengthBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
-
- randomAnalyzer() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
- randomAsciiName() - Static method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
-
- randomBoolean() - Static method in class org.elasticsearch.test.ESTestCase
-
- randomByte() - Static method in class org.elasticsearch.test.ESTestCase
-
- randomBytes(int) - Static method in class org.elasticsearch.repositories.ESBlobStoreTestCase
-
- randomCompatibleVersion(Random, Version) - Static method in class org.elasticsearch.test.VersionUtils
-
Returns a random Version
from all available versions, that is compatible with the given version.
- randomDateTimeZone() - Static method in class org.elasticsearch.test.ESTestCase
-
generate a random DateTimeZone from the ones available in joda library
- RandomDocumentPicks - Class in org.elasticsearch.ingest
-
- randomDouble() - Static method in class org.elasticsearch.test.ESTestCase
-
- randomDoubleBetween(double, double, boolean) - Static method in class org.elasticsearch.test.ESTestCase
-
Returns a double value in the interval [start, end) if lowerInclusive is
set to true, (start, end) otherwise.
- randomExecutionHint() - Method in class org.elasticsearch.search.aggregations.bucket.AbstractTermsTestCase
-
- randomExistingFieldName(Random, IngestDocument) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
-
Returns a randomly selected existing field name out of the fields that are contained
in the document provided as an argument.
- randomFieldName(Random) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
-
Returns a random field name.
- randomFieldOrScript(ValuesSourceAggregationBuilder<?, ?>, String) - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
-
- randomFieldValue(Random) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
-
Generates a random field value, can be a string, a number, a list of an object itself.
- randomFloat() - Static method in class org.elasticsearch.test.ESTestCase
-
- randomFrom(T...) - Static method in class org.elasticsearch.test.ESTestCase
-
Pick a random object from the given array.
- randomFrom(Random, T...) - Static method in class org.elasticsearch.test.ESTestCase
-
Pick a random object from the given array.
- randomFrom(List<T>) - Static method in class org.elasticsearch.test.ESTestCase
-
Pick a random object from the given list.
- randomFrom(Collection<T>) - Static method in class org.elasticsearch.test.ESTestCase
-
Pick a random object from the given collection.
- randomFrom(Random, Collection<T>) - Static method in class org.elasticsearch.test.ESTestCase
-
Pick a random object from the given collection.
- randomFuzziness(String) - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
- randomGeohash(int, int) - Static method in class org.elasticsearch.test.ESTestCase
-
- randomIndexTemplate() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Creates a randomized index template.
- randomIngestDocument(Random) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
-
Generates a random document and random metadata
- randomIngestDocument(Random, Map<String, Object>) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
-
Generates a document that holds random metadata and the document provided as a map argument
- randomInt() - Static method in class org.elasticsearch.test.ESTestCase
-
- randomInt(int) - Static method in class org.elasticsearch.test.ESTestCase
-
A random integer from 0..max (inclusive).
- randomIntBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
-
A random integer from min
to max
(inclusive).
- randomizeContentType() - Method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
-
- RandomizingClient - Class in org.elasticsearch.test.client
-
A Client
that randomizes request parameters.
- RandomizingClient(Client, Random) - Constructor for class org.elasticsearch.test.client.RandomizingClient
-
- randomLeafFieldName(Random) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
-
Returns a random leaf field name.
- randomLong() - Static method in class org.elasticsearch.test.ESTestCase
-
- randomMinimumShouldMatch() - Static method in class org.elasticsearch.test.AbstractQueryTestCase
-
- randomNonNegativeLong() - Static method in class org.elasticsearch.test.ESTestCase
-
- randomNumericDocValueFormat() - Static method in class org.elasticsearch.test.InternalAggregationTestCase
-
- randomNumericField() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
-
- RandomObjects - Class in org.elasticsearch.test
-
- randomPositiveTimeValue() - Static method in class org.elasticsearch.test.ESTestCase
-
- randomRealisticUnicodeOfCodepointLength(int) - Static method in class org.elasticsearch.test.ESTestCase
-
- randomRealisticUnicodeOfCodepointLengthBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
-
- randomRealisticUnicodeOfLength(int) - Static method in class org.elasticsearch.test.ESTestCase
-
- randomRealisticUnicodeOfLengthBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
-
- randomRecoverySource() - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
-
- randomRepoPath() - Method in class org.elasticsearch.test.ESIntegTestCase
-
Returns path to a random directory that can be used to create a temporary file system repo
- randomRepoPath(Settings) - Static method in class org.elasticsearch.test.ESIntegTestCase
-
Returns path to a random directory that can be used to create a temporary file system repo
- 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<RescoreBuilder<?>>, Supplier<List<SearchExtBuilder>>, Supplier<CollapseBuilder>) - Static method in class org.elasticsearch.search.RandomSearchRequestGenerator
-
- randomShardInfo(Random) - Static method in class org.elasticsearch.test.RandomObjects
-
Returns a tuple that contains a randomized ReplicationResponse.ShardInfo
value (left side) and its corresponding
value (right side) after it has been printed out as a ToXContent
and parsed back using a parsing
method like ReplicationResponse.ShardInfo.fromXContent(XContentParser)
.
- randomShardInfo(Random, boolean) - Static method in class org.elasticsearch.test.RandomObjects
-
Returns a tuple that contains a randomized ReplicationResponse.ShardInfo
value (left side) and its corresponding
value (right side) after it has been printed out as a ToXContent
and parsed back using a parsing
method like ReplicationResponse.ShardInfo.fromXContent(XContentParser)
.
- randomShort() - Static method in class org.elasticsearch.test.ESTestCase
-
- randomSource(Random) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
-
- randomSource(Random) - Static method in class org.elasticsearch.test.RandomObjects
-
Returns a random source containing a random number of fields, objects and array, with maximum depth 5.
- randomSource(Random, XContentType) - Static method in class org.elasticsearch.test.RandomObjects
-
Returns a random source in a given XContentType containing a random number of fields, objects and array, with maximum depth 5.
- randomSource(Random, XContentType, int) - Static method in class org.elasticsearch.test.RandomObjects
-
Returns a random source in a given XContentType containing a random number of fields, objects and array, with maximum depth 5.
- randomStoredFieldValues(Random, XContentType) - Static method in class org.elasticsearch.test.RandomObjects
-
Returns a tuple containing random stored field values and their corresponding expected values once printed out
via ToXContent.toXContent(XContentBuilder, ToXContent.Params)
and parsed back via
XContentParser.objectText()
.
- randomString(Random) - Static method in class org.elasticsearch.ingest.RandomDocumentPicks
-
- randomSubsetOf(int, 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)
- randomSubsetOf(int, Collection<T>) - Static method in class org.elasticsearch.test.ESTestCase
-
Returns size random values
- randomTimeValue(int, int, String...) - Static method in class org.elasticsearch.test.ESTestCase
-
- randomTimeValue(int, int) - Static method in class org.elasticsearch.test.ESTestCase
-
- randomTimeValue() - Static method in class org.elasticsearch.test.ESTestCase
-
- randomUnicodeOfCodepointLength(int) - Static method in class org.elasticsearch.test.ESTestCase
-
- randomUnicodeOfCodepointLengthBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
-
- randomUnicodeOfLength(int) - Static method in class org.elasticsearch.test.ESTestCase
-
- randomUnicodeOfLengthBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
-
- randomUnique(Supplier<T>, int) - Static method in class org.elasticsearch.test.ESTestCase
-
Builds a set of unique items.
- randomValueOtherThan(T, Supplier<T>) - Static method in class org.elasticsearch.test.ESTestCase
-
helper to get a random value in a certain range that's different from the input
- randomValueOtherThanMany(Predicate<T>, Supplier<T>) - Static method in class org.elasticsearch.test.ESTestCase
-
helper to get a random value in a certain range that's different from the input
- randomVersion(Random) - Static method in class org.elasticsearch.test.VersionUtils
-
Returns a random Version
from all available versions.
- randomVersionBetween(Random, Version, Version) - Static method in class org.elasticsearch.test.VersionUtils
-
Returns a random Version
between minVersion
and maxVersion
(inclusive).
- rawSelector() - Method in class org.elasticsearch.transport.nio.ESSelector
-
- read(NetworkBytesReference) - Method in class org.elasticsearch.transport.nio.channel.NioSocketChannel
-
- read() - Method in interface org.elasticsearch.transport.nio.channel.ReadContext
-
- read() - Method in class org.elasticsearch.transport.nio.channel.TcpReadContext
-
- readBlobFully(BlobContainer, String, int) - Static method in class org.elasticsearch.repositories.ESBlobStoreTestCase
-
- ReadContext - Interface in org.elasticsearch.transport.nio.channel
-
- readDiffFrom(String, StreamInput) - Static method in class org.elasticsearch.test.TestCustomMetaData
-
- readException(NioSocketChannel, Exception) - Method in class org.elasticsearch.transport.nio.SocketEventHandler
-
This method is called when an attempt to read from a channel throws an exception.
- readFrom(StreamInput) - Method in class org.elasticsearch.test.hamcrest.ElasticsearchAssertions.ExceptionWrapper
-
- readFrom(Function<String, T>, StreamInput) - Static method in class org.elasticsearch.test.TestCustomMetaData
-
- readFrom(StreamInput) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.StringMessageRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.TestRequest
-
- readFrom(StreamInput) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.Version0Request
-
- readFrom(StreamInput) - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.Version1Request
-
- readSecret(String) - Method in class org.elasticsearch.cli.MockTerminal
-
- readText(String) - Method in class org.elasticsearch.cli.MockTerminal
-
- receivedRequest(long, String) - Method in class org.elasticsearch.test.transport.MockTransportService.Tracer
-
- receivedResponse(long, DiscoveryNode, String) - Method in class org.elasticsearch.test.transport.MockTransportService.Tracer
-
- recoverReplica(IndexShard, IndexShard) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
recovers a replica from the given primary
- recoverReplica(IndexShard, IndexShard, BiFunction<IndexShard, DiscoveryNode, RecoveryTarget>, boolean) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
recovers a replica from the given primary
- recoverReplica(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) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
- recoveryListener - Static variable in class org.elasticsearch.index.shard.IndexShardTestCase
-
- RecoverySettingsChunkSizePlugin - Class in org.elasticsearch.node
-
- RecoverySettingsChunkSizePlugin() - Constructor for class org.elasticsearch.node.RecoverySettingsChunkSizePlugin
-
- recoveryShardFromStore(IndexShard) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
- refresh(String...) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Waits for relocations and refreshes all indices in the cluster.
- RegexMatcher - Class in org.elasticsearch.test.hamcrest
-
Matcher that supports regular expression and allows to provide optional flags
- RegexMatcher(String) - Constructor for class org.elasticsearch.test.hamcrest.RegexMatcher
-
- RegexMatcher(String, int) - Constructor for class org.elasticsearch.test.hamcrest.RegexMatcher
-
- register(String, String, TaskAwareRequest) - Method in class org.elasticsearch.test.tasks.MockTaskManager
-
- register() - Method in class org.elasticsearch.transport.nio.channel.AbstractNioChannel
-
This method attempts to registered a channel with the raw nio selector.
- register() - Method in interface org.elasticsearch.transport.nio.channel.NioChannel
-
- registrationException(NioServerSocketChannel, Exception) - Method in class org.elasticsearch.transport.nio.AcceptorEventHandler
-
This method is called when an attempt to register a server channel throws an exception.
- registrationException(NioSocketChannel, Exception) - Method in class org.elasticsearch.transport.nio.SocketEventHandler
-
This method is called when an attempt to register a channel throws an exception.
- reinitPrimary(ShardRouting) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
-
- reinitPrimary(ShardRouting, UnassignedInfo.Reason, RecoverySource) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
-
- reinitShard(IndexShard, IndexingOperationListener...) - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
Takes an existing shard, closes it and 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 and starts a new initialing shard at the same location
- relocate(ShardRouting, String) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
-
- relocate(ShardRouting, String, long) - Static method in class org.elasticsearch.cluster.routing.ShardRoutingHelper
-
- relocate(ShardRouting, String, long) - Static method in class org.elasticsearch.cluster.routing.TestShardRouting
-
- removeAndEnsureHealthy(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.BlockClusterStateProcessing
-
- removeAndEnsureHealthy(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.LongGCDisruption
-
- removeAndEnsureHealthy(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.NetworkDisruption
-
- removeAndEnsureHealthy(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.NoOpDisruptionScheme
-
- removeAndEnsureHealthy(InternalTestCluster) - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
-
- removeAndEnsureHealthy(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.SlowClusterStateProcessing
-
- removeConnectInterested(NioChannel) - Static method in class org.elasticsearch.transport.nio.channel.SelectionKeyUtils
-
- removeContext(long) - Method in class org.elasticsearch.search.MockSearchService
-
- removeDisruption(MockTransportService, MockTransportService) - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkLinkDisruptionType
-
- removeFromCluster(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.NetworkDisruption
-
- removeFromCluster(InternalTestCluster) - Method in class org.elasticsearch.test.disruption.NoOpDisruptionScheme
-
- 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 class org.elasticsearch.test.disruption.NoOpDisruptionScheme
-
- removeFromNode(String, InternalTestCluster) - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
-
- removeFromNode(String, InternalTestCluster) - Method in class org.elasticsearch.test.disruption.SingleNodeDisruption
-
- removeLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.test.transport.CapturingTransport
-
- removeLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- removeListener(MockTaskManagerListener) - Method in class org.elasticsearch.test.tasks.MockTaskManager
-
- removeRegisteredChannel(NioChannel) - Method in class org.elasticsearch.transport.nio.ESSelector
-
- removeTracer(MockTransportService.Tracer) - Method in class org.elasticsearch.test.transport.MockTransportService
-
- removeWriteInterested(NioChannel) - Static method in class org.elasticsearch.transport.nio.channel.SelectionKeyUtils
-
- replacePlaceholders(Map<String, String>) - Method in class org.elasticsearch.test.rest.yaml.restspec.ClientYamlSuiteRestPath
-
- replaceStashedValues(Map<String, Object>) - Method in class org.elasticsearch.test.rest.yaml.Stash
-
Goes recursively against each map entry and replaces any string value starting with "$" with its
corresponding value retrieved from the stash
- ReproduceInfoPrinter - Class in org.elasticsearch.test.junit.listeners
-
A RunListener
that emits a command you can use to re-run a failing test with the failing random seed to
System.err
.
- ReproduceInfoPrinter() - Constructor for class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter
-
- ReproduceInfoPrinter.GradleMessageBuilder - Class in org.elasticsearch.test.junit.listeners
-
- request() - Method in class org.elasticsearch.index.reindex.AbstractAsyncBulkByScrollActionTestCase
-
- request() - Method in class org.elasticsearch.test.rest.FakeRestChannel
-
- request() - Method in class org.elasticsearch.test.TestSearchContext
-
- request - Variable in class org.elasticsearch.test.transport.CapturingTransport.CapturedRequest
-
- requestId - Variable in class org.elasticsearch.test.transport.CapturingTransport.CapturedRequest
-
- requestSent(DiscoveryNode, long, String, TransportRequestOptions) - Method in class org.elasticsearch.test.transport.MockTransportService.Tracer
-
- rescore() - Method in class org.elasticsearch.test.TestSearchContext
-
- reset() - Method in class org.elasticsearch.cli.MockTerminal
-
Wipes the input and output.
- resetCheckIndexStatus() - Method in class org.elasticsearch.test.ESTestCase
-
- resetNodeAfterTest() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
This method returns true
if the node that is used in the background should be reset
after each test.
- resetPortCounter() - Static method in class org.elasticsearch.test.ESTestCase
-
- resetTerminal() - Method in class org.elasticsearch.cli.CommandTestCase
-
- resize(ByteArray, long) - Method in class org.elasticsearch.common.util.MockBigArrays
-
- resize(IntArray, long) - Method in class org.elasticsearch.common.util.MockBigArrays
-
- resize(LongArray, long) - Method in class org.elasticsearch.common.util.MockBigArrays
-
- resize(FloatArray, long) - Method in class org.elasticsearch.common.util.MockBigArrays
-
- resize(DoubleArray, long) - Method in class org.elasticsearch.common.util.MockBigArrays
-
- resize(ObjectArray<T>, long) - Method in class org.elasticsearch.common.util.MockBigArrays
-
- resolveExpectedValue(ClientYamlTestExecutionContext) - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
-
- resolveIndex(String) - Static method in class org.elasticsearch.test.ESIntegTestCase
-
- resolveIndex(String) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
- response(String) - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestExecutionContext
-
Extracts a specific value from the last saved response
- responses() - Method in class org.elasticsearch.test.rest.FakeRestChannel
-
- responseSent(long, String) - Method in class org.elasticsearch.test.transport.MockTransportService.Tracer
-
- responseSent(long, String, Throwable) - Method in class org.elasticsearch.test.transport.MockTransportService.Tracer
-
- REST_TESTS_BLACKLIST - Static variable in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
-
Property that allows to blacklist some of the REST tests based on a comma separated list of globs
e.g.
- REST_TESTS_SUITE - Static variable in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
-
Property that allows to control which REST tests get run.
- restAdminSettings() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Returns the REST client settings used for admin actions like cleaning up after the test has completed.
- RestartCallback() - Constructor for class org.elasticsearch.test.InternalTestCluster.RestartCallback
-
- restartNode(String, InternalTestCluster.RestartCallback) - Method in class org.elasticsearch.test.InternalTestCluster
-
Restarts a node and calls the callback during restart.
- restartRandomDataNode() - Method in class org.elasticsearch.test.InternalTestCluster
-
Restarts a random data node in the cluster
- restartRandomDataNode(InternalTestCluster.RestartCallback) - Method in class org.elasticsearch.test.InternalTestCluster
-
Restarts a random data node in the cluster and calls the callback during restart.
- restartRandomNode() - Method in class org.elasticsearch.test.InternalTestCluster
-
Restarts a random node in the cluster
- restartRandomNode(InternalTestCluster.RestartCallback) - Method in class org.elasticsearch.test.InternalTestCluster
-
Restarts a random node in the cluster and calls the callback during restart.
- restClientSettings() - Method in class org.elasticsearch.test.rest.ESRestTestCase
-
Used to obtain settings for the REST client that is used to send REST requests.
- restoreContentType() - Static method in class org.elasticsearch.test.ESTestCase
-
- restoreFileSystem() - Static method in class org.elasticsearch.test.ESTestCase
-
- resumeThreads(Set<Thread>) - Method in class org.elasticsearch.test.disruption.LongGCDisruption
-
- rewrite(Query) - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
- rewriteAndFetch(QueryBuilder, QueryRewriteContext) - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
- rollingRestart() - Method in class org.elasticsearch.test.InternalTestCluster
-
Restarts all nodes in a rolling restart fashion ie.
- rollingRestart(InternalTestCluster.RestartCallback) - Method in class org.elasticsearch.test.InternalTestCluster
-
Restarts all nodes in a rolling restart fashion ie.
- RoundRobinSelectorSupplier - Class in org.elasticsearch.transport.nio
-
- RoundRobinSelectorSupplier(ArrayList<SocketSelector>) - Constructor for class org.elasticsearch.transport.nio.RoundRobinSelectorSupplier
-
- 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() - Method in class org.elasticsearch.script.MockScriptEngine.MockExecutableScript
-
- runLoop() - Method in class org.elasticsearch.transport.nio.ESSelector
-
Starts this selector.
- safeClass(Object) - Method in class org.elasticsearch.test.rest.yaml.section.Assertion
-
a utility to get the class of an object, protecting for null (i.e., returning null if the input is null)
- scaledRandomIntBetween(int, int) - Static method in class org.elasticsearch.test.ESTestCase
-
Returns a "scaled" random number between min and max (inclusive).
- scheduleForRegistration(NioServerSocketChannel) - Method in class org.elasticsearch.transport.nio.AcceptingSelector
-
Schedules a NioServerSocketChannel to be registered with this selector.
- scheduleForRegistration(NioSocketChannel) - Method in class org.elasticsearch.transport.nio.SocketSelector
-
Schedules a NioSocketChannel to be registered by this selector.
- scriptFields() - Method in class org.elasticsearch.test.TestSearchContext
-
- scrollContext() - Method in class org.elasticsearch.test.TestSearchContext
-
- scrollContext(ScrollContext) - Method in class org.elasticsearch.test.TestSearchContext
-
- search(IndexSearcher, Query, AggregationBuilder, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
- searchAfter(FieldDoc) - Method in class org.elasticsearch.test.TestSearchContext
-
- searchAfter() - Method in class org.elasticsearch.test.TestSearchContext
-
- searchAndReduce(IndexSearcher, Query, AggregationBuilder, MappedFieldType...) - Method in class org.elasticsearch.search.aggregations.AggregatorTestCase
-
Divides the provided IndexSearcher
in sub-searcher, one for each segment,
builds an aggregator for each sub-searcher filtered by the provided Query
and
returns the reduced InternalAggregation
.
- searcher() - Method in class org.elasticsearch.test.TestSearchContext
-
- SearchHitHasIdMatcher(String) - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasIdMatcher
-
- SearchHitHasIndexMatcher(String) - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasIndexMatcher
-
- SearchHitHasScoreMatcher(float) - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasScoreMatcher
-
- SearchHitHasTypeMatcher(String) - Constructor for class org.elasticsearch.test.hamcrest.ElasticsearchMatchers.SearchHitHasTypeMatcher
-
- searchType() - Method in class org.elasticsearch.test.TestSearchContext
-
- seed() - Method in class org.elasticsearch.test.TestCluster
-
- SeenEventExpectation(String, String, Level, String) - Constructor for class org.elasticsearch.test.MockLogAppender.SeenEventExpectation
-
- selectException(IOException) - Method in class org.elasticsearch.transport.nio.EventHandler
-
This method handles an IOException that was thrown during a call to Selector.select(long)
.
- SelectionKeyUtils - Class in org.elasticsearch.transport.nio.channel
-
- sendMessage(MockTcpTransport.MockChannel, BytesReference, ActionListener<MockTcpTransport.MockChannel>) - Method in class org.elasticsearch.transport.MockTcpTransport
-
- sendMessage(BytesReference, ActionListener<NioChannel>) - Method in class org.elasticsearch.transport.nio.channel.TcpWriteContext
-
- sendMessage(BytesReference, ActionListener<NioChannel>) - Method in interface org.elasticsearch.transport.nio.channel.WriteContext
-
- sendMessage(NioChannel, BytesReference, ActionListener<NioChannel>) - Method in class org.elasticsearch.transport.nio.NioTransport
-
- sendRequest(Transport.Connection, long, String, TransportRequest, TransportRequestOptions) - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- sendResponse(RestResponse) - Method in class org.elasticsearch.test.rest.FakeRestChannel
-
- serverChannelOpened(NioServerSocketChannel) - Method in class org.elasticsearch.transport.nio.OpenChannels
-
- serverChannelRegistered(NioServerSocketChannel) - Method in class org.elasticsearch.transport.nio.AcceptorEventHandler
-
This method is called when a NioServerSocketChannel is successfully registered.
- serverChannelsCount() - Method in class org.elasticsearch.transport.nio.OpenChannels
-
- serviceA - Variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- serviceB - Variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- ServiceDisruptionScheme - Interface in org.elasticsearch.test.disruption
-
- setAcceptInterested(NioServerSocketChannel) - Static method in class org.elasticsearch.transport.nio.channel.SelectionKeyUtils
-
- setApiCallSection(ApiCallSection) - Method in class org.elasticsearch.test.rest.yaml.section.DoSection
-
- setCatch(String) - Method in class org.elasticsearch.test.rest.yaml.section.DoSection
-
- setClusterReadOnly(boolean) - Static method in class org.elasticsearch.test.ESIntegTestCase
-
Sets or unsets the cluster read_only mode
- setConnectAndReadInterested(NioChannel) - Static method in class org.elasticsearch.transport.nio.channel.SelectionKeyUtils
-
- setContentType() - Static method in class org.elasticsearch.test.ESTestCase
-
- setContexts(ReadContext, WriteContext) - Method in class org.elasticsearch.transport.nio.channel.NioSocketChannel
-
- setDisruptionScheme(ServiceDisruptionScheme) - Method in class org.elasticsearch.test.ESIntegTestCase
-
- setDisruptionScheme(ServiceDisruptionScheme) - Method in class org.elasticsearch.test.InternalTestCluster
-
- setDummyNullValue(Object) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
-
Sets the null value used by the modifier for null value testing.
- setExpectedWarningHeaders(List<String>) - Method in class org.elasticsearch.test.rest.yaml.section.DoSection
-
Set the warning headers that we expect from this response.
- setFile(String, byte[]) - Method in class org.elasticsearch.common.settings.MockSecureSettings
-
- setFileSystem() - Static method in class org.elasticsearch.test.ESTestCase
-
- setListener(Consumer<NioChannel>) - Method in class org.elasticsearch.transport.nio.channel.CloseFuture
-
- setMaxFieldSize(int) - Method in class org.elasticsearch.test.BackgroundIndexer
-
the minimum size in code points of a payload field in the indexed documents
- setMinFieldSize(int) - Method in class org.elasticsearch.test.BackgroundIndexer
-
the minimum size in code points of a payload field in the indexed documents
- setMinimumMasterNodes(int) - Method in class org.elasticsearch.test.ESIntegTestCase
-
Sets the cluster's minimum master node and make sure the response is acknowledge.
- setN1Usage(String, DiskUsage) - Method in class org.elasticsearch.cluster.MockInternalClusterInfoService
-
- setN2Usage(String, DiskUsage) - Method in class org.elasticsearch.cluster.MockInternalClusterInfoService
-
- setN3Usage(String, DiskUsage) - Method in class org.elasticsearch.cluster.MockInternalClusterInfoService
-
- setNanoTimeOverride(long) - Method in class org.elasticsearch.cluster.ESAllocationTestCase.MockAllocationService
-
- setNewDelegate(IndexEventListener) - Method in class org.elasticsearch.test.MockIndexEventListener.TestEventListener
-
- setNextVar(String, Object) - Method in class org.elasticsearch.script.MockScriptEngine.MockExecutableScript
-
- setPermissions(Set<PosixFilePermission>) - Method in class org.elasticsearch.test.PosixPermissionsResetter
-
- setRandomIndexSettings(Random, Settings.Builder) - Method in class org.elasticsearch.test.ESIntegTestCase
-
- setSearcher(Engine.Searcher) - Method in class org.elasticsearch.test.TestSearchContext
-
- SetSection - Class in org.elasticsearch.test.rest.yaml.section
-
Represents a set section:
- set: {_scroll_id: scroll_id}
- SetSection(XContentLocation) - Constructor for class org.elasticsearch.test.rest.yaml.section.SetSection
-
- setSetupSection(SetupSection) - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
-
- setSize(int) - Method in class org.elasticsearch.test.TestSearchContext
-
- setSkipSection(SkipSection) - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSection
-
- setSkipSection(SkipSection) - Method in class org.elasticsearch.test.rest.yaml.section.SetupSection
-
- setSkipSection(SkipSection) - Method in class org.elasticsearch.test.rest.yaml.section.TeardownSection
-
- setState(ClusterApplierService, ClusterState) - Static method in class org.elasticsearch.test.ClusterServiceUtils
-
- setState(MasterService, ClusterState) - Static method in class org.elasticsearch.test.ClusterServiceUtils
-
- setState(ClusterService, ClusterState.Builder) - 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
- setString(String, String) - Method in class org.elasticsearch.common.settings.MockSecureSettings
-
- setTask(SearchTask) - Method in class org.elasticsearch.test.TestSearchContext
-
- setTeardownSection(TeardownSection) - Method in class org.elasticsearch.test.rest.yaml.section.ClientYamlTestSuite
-
- settings - Variable in class org.elasticsearch.test.discovery.TestZenDiscovery.TestPlugin
-
- settings(Version) - Static method in class org.elasticsearch.test.ESTestCase
-
Return consistent index settings for the provided index version.
- setup() - Static method in class org.elasticsearch.common.io.PathUtilsForTesting
-
Sets a new default filesystem for testing
- setUp() - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
- setUp() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
-
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.transport.AbstractSimpleTransportTestCase
-
- setUpClass() - Static method in class org.elasticsearch.test.ESSingleNodeTestCase
-
- setUpdateFrequency(TimeValue) - Method in class org.elasticsearch.cluster.MockInternalClusterInfoService
-
- setupForTest() - Method in class org.elasticsearch.index.reindex.AbstractAsyncBulkByScrollActionTestCase
-
- SetupSection - Class in org.elasticsearch.test.rest.yaml.section
-
Represents a setup section.
- SetupSection() - 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
-
- setupTestCluster() - Method in class org.elasticsearch.test.ESIntegTestCase
-
- setWriteInterested(NioChannel) - Static method in class org.elasticsearch.transport.nio.channel.SelectionKeyUtils
-
- 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
-
- shardTarget() - Method in class org.elasticsearch.test.TestSearchContext
-
- shuffleMap(LinkedHashMap<String, Object>, Set<String>) - Static method in class org.elasticsearch.test.ESTestCase
-
- shuffleProtectedFields() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
- 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...) - Method in class org.elasticsearch.test.ESTestCase
-
Randomly shuffles the fields inside objects parsed using the XContentParser
passed in.
- similarityService() - Method in class org.elasticsearch.test.TestSearchContext
-
- SingleNodeDisruption - Class in org.elasticsearch.test.disruption
-
- SingleNodeDisruption(String, Random) - Constructor for class org.elasticsearch.test.disruption.SingleNodeDisruption
-
- SingleNodeDisruption(Random) - Constructor for class org.elasticsearch.test.disruption.SingleNodeDisruption
-
- size() - Method in class org.elasticsearch.test.ExternalTestCluster
-
- size() - Method in class org.elasticsearch.test.InternalTestCluster
-
- size() - Method in class org.elasticsearch.test.TestCluster
-
Returns the number of nodes in the cluster.
- size() - Method in class org.elasticsearch.test.TestSearchContext
-
- size(int) - Method in class org.elasticsearch.test.TestSearchContext
-
- skip(Version) - Method in class org.elasticsearch.test.rest.yaml.section.SkipSection
-
- SkipSection - Class in org.elasticsearch.test.rest.yaml.section
-
Represents a skip section that tells whether a specific test section or suite needs to be skipped
based on:
- the elasticsearch version the tests are running against
- a specific test feature required that might not be implemented yet by the runner
- SkipSection(String, List<String>, String) - Constructor for class org.elasticsearch.test.rest.yaml.section.SkipSection
-
- slice(int, int) - Method in class org.elasticsearch.transport.nio.NetworkBytesReference
-
- SlowClusterStateProcessing - Class in org.elasticsearch.test.disruption
-
- SlowClusterStateProcessing(Random) - Constructor for class org.elasticsearch.test.disruption.SlowClusterStateProcessing
-
- 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, long, long, long, long) - Constructor for class org.elasticsearch.test.disruption.SlowClusterStateProcessing
-
- smartClient() - Method in class org.elasticsearch.test.InternalTestCluster
-
Returns a "smart" node client to a random node in the cluster
- smartNameFieldType(String) - Method in class org.elasticsearch.test.TestSearchContext
-
- SocketEventHandler - Class in org.elasticsearch.transport.nio
-
Event handler designed to handle events from non-server sockets
- SocketEventHandler(Logger, BiConsumer<NioSocketChannel, Throwable>) - Constructor for class org.elasticsearch.transport.nio.SocketEventHandler
-
- SocketSelector - Class in org.elasticsearch.transport.nio
-
- SocketSelector(SocketEventHandler) - Constructor for class org.elasticsearch.transport.nio.SocketSelector
-
- SocketSelector(SocketEventHandler, Selector) - Constructor for class org.elasticsearch.transport.nio.SocketSelector
-
- sort(SortAndFormats) - Method in class org.elasticsearch.test.TestSearchContext
-
- sort() - Method in class org.elasticsearch.test.TestSearchContext
-
- source() - Method in class org.elasticsearch.test.TestSearchContext
-
- sourceRequested() - Method in class org.elasticsearch.test.TestSearchContext
-
- spinForAtLeastNMilliseconds(long) - Static method in class org.elasticsearch.test.ESTestCase
-
- spinForAtLeastOneMillisecond() - Static method in class org.elasticsearch.test.ESTestCase
-
- start() - Method in class org.elasticsearch.test.BackgroundIndexer
-
Start indexing with no limit to the number of documents
- start(int) - Method in class org.elasticsearch.test.BackgroundIndexer
-
Start indexing
- start() - Method in class org.elasticsearch.test.discovery.MockZenPing
-
- start() - Method in class org.elasticsearch.test.transport.CapturingTransport
-
- start() - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- startCoordinatingOnlyNode(Settings) - Method in class org.elasticsearch.test.InternalTestCluster
-
- startDataOnlyNode() - Method in class org.elasticsearch.test.InternalTestCluster
-
- startDataOnlyNode(Settings) - Method in class org.elasticsearch.test.InternalTestCluster
-
- startDataOnlyNodes(int) - Method in class org.elasticsearch.test.InternalTestCluster
-
- startDataOnlyNodes(int, Settings) - Method in class org.elasticsearch.test.InternalTestCluster
-
- startDisrupting() - Method in class org.elasticsearch.test.disruption.BlockClusterStateProcessing
-
- startDisrupting() - Method in class org.elasticsearch.test.disruption.IntermittentLongGCDisruption
-
- startDisrupting() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
-
- startDisrupting() - Method in class org.elasticsearch.test.disruption.NetworkDisruption
-
- startDisrupting() - Method in class org.elasticsearch.test.disruption.NoOpDisruptionScheme
-
- startDisrupting() - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
-
- startDisrupting() - Method in class org.elasticsearch.test.disruption.SlowClusterStateProcessing
-
- startMasterOnlyNode() - Method in class org.elasticsearch.test.InternalTestCluster
-
- startMasterOnlyNode(Settings) - Method in class org.elasticsearch.test.InternalTestCluster
-
- startMasterOnlyNodes(int) - Method in class org.elasticsearch.test.InternalTestCluster
-
- startMasterOnlyNodes(int, Settings) - Method in class org.elasticsearch.test.InternalTestCluster
-
- startNode(long) - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
- startNode() - Method in class org.elasticsearch.test.InternalTestCluster
-
Starts a node with default settings and returns it's name.
- startNode(Settings.Builder) - Method in class org.elasticsearch.test.InternalTestCluster
-
Starts a node with the given settings builder and returns it's name.
- startNode(Settings) - Method in class org.elasticsearch.test.InternalTestCluster
-
Starts a node with the given settings and returns it's 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
- startRandomInitializingShard(ClusterState, AllocationService) - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
- stash() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestExecutionContext
-
- Stash - Class in org.elasticsearch.test.rest.yaml
-
Allows to cache the last obtained test response and or part of it within variables
that can be used as input values in following requests and assertions.
- Stash() - Constructor for class org.elasticsearch.test.rest.yaml.Stash
-
- stashValue(String, Object) - Method in class org.elasticsearch.test.rest.yaml.Stash
-
Allows to saved a specific field in the stash as key-value pair
- stop() - Method in class org.elasticsearch.test.BackgroundIndexer
-
Stop all background threads *
- stop() - Method in class org.elasticsearch.test.transport.CapturingTransport
-
- stop() - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- 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.IntermittentLongGCDisruption
-
- stopDisrupting() - Method in class org.elasticsearch.test.disruption.LongGCDisruption
-
- stopDisrupting() - Method in class org.elasticsearch.test.disruption.NetworkDisruption
-
- stopDisrupting() - Method in class org.elasticsearch.test.disruption.NoOpDisruptionScheme
-
- stopDisrupting() - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
-
- stopDisrupting() - Method in class org.elasticsearch.test.disruption.SlowClusterStateProcessing
-
- stopInternal() - Method in class org.elasticsearch.transport.MockTcpTransport
-
- stopInternal() - Method in class org.elasticsearch.transport.nio.NioTransport
-
- stopRandomDataNode() - Method in class org.elasticsearch.test.InternalTestCluster
-
Stops a random data node in the cluster.
- stopRandomNode(Predicate<Settings>) - Method in class org.elasticsearch.test.InternalTestCluster
-
Stops a random node in the cluster that applies to the given filter or non if the non of the nodes applies to the
filter.
- stopRandomNonMasterNode() - Method in class org.elasticsearch.test.InternalTestCluster
-
Stops any of the current nodes but not the master node.
- storedFieldsContext() - Method in class org.elasticsearch.test.TestSearchContext
-
- storedFieldsContext(StoredFieldsContext) - Method in class org.elasticsearch.test.TestSearchContext
-
- storedFieldsRequested() - Method in class org.elasticsearch.test.TestSearchContext
-
- StreamsUtils - Class in org.elasticsearch.test
-
- StreamsUtils() - Constructor for class org.elasticsearch.test.StreamsUtils
-
- strictOnly - Variable in class org.elasticsearch.index.mapper.FieldTypeTestCase.Modifier
-
true if this modifier only makes types incompatible in strict mode, false otherwise
- STRING_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
-
- STRING_FIELD_NAME - Static variable in class org.elasticsearch.test.AbstractQueryTestCase
-
- STRING_FIELD_NAME_2 - Static variable in class org.elasticsearch.test.AbstractQueryTestCase
-
- StringMessageRequest() - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.StringMessageRequest
-
- StringMessageRequest(String) - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.StringMessageRequest
-
- 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_CLUSTER_NODE_PREFIX - Static variable in class org.elasticsearch.test.ESIntegTestCase
-
node names of the corresponding clusters will start with these prefixes
- supportsBoostAndQueryName() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Few queries allow you to set the boost and queryName on the java api, although the corresponding parser
doesn't parse them as they are not supported.
- 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".
- SYSPROP_THIRDPARTY - Static variable in class org.elasticsearch.test.ESIntegTestCase
-
Property that controls whether ThirdParty Integration tests are run (not the default).
- task - Variable in class org.elasticsearch.index.reindex.AbstractAsyncBulkByScrollActionTestCase
-
- TcpFrameDecoder - Class in org.elasticsearch.transport.nio.channel
-
- TcpFrameDecoder() - Constructor for class org.elasticsearch.transport.nio.channel.TcpFrameDecoder
-
- TcpReadContext - Class in org.elasticsearch.transport.nio.channel
-
- TcpReadContext(NioSocketChannel, TcpReadHandler) - Constructor for class org.elasticsearch.transport.nio.channel.TcpReadContext
-
- TcpReadContext(NioSocketChannel, TcpReadHandler, TcpFrameDecoder) - Constructor for class org.elasticsearch.transport.nio.channel.TcpReadContext
-
- TcpReadHandler - Class in org.elasticsearch.transport.nio
-
- TcpReadHandler(NioTransport) - Constructor for class org.elasticsearch.transport.nio.TcpReadHandler
-
- TcpWriteContext - Class in org.elasticsearch.transport.nio.channel
-
- TcpWriteContext(NioSocketChannel) - Constructor for class org.elasticsearch.transport.nio.channel.TcpWriteContext
-
- teardown() - Static method in class org.elasticsearch.common.io.PathUtilsForTesting
-
Resets filesystem back to the real system default
- tearDown() - Method in class org.elasticsearch.index.reindex.AbstractAsyncBulkByScrollActionTestCase
-
- tearDown() - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
- tearDown() - Method in class org.elasticsearch.test.ESSingleNodeTestCase
-
- tearDown() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- tearDownClass() - Static method in class org.elasticsearch.test.ESSingleNodeTestCase
-
- TeardownSection - Class in org.elasticsearch.test.rest.yaml.section
-
- TeardownSection() - Constructor for class org.elasticsearch.test.rest.yaml.section.TeardownSection
-
- 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
-
- test() - Method in class org.elasticsearch.test.rest.yaml.ESClientYamlSuiteTestCase
-
- TEST_CLUSTER_NODE_PREFIX - Static variable in class org.elasticsearch.test.ESIntegTestCase
-
- testAdapterSendReceiveCallbacks() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- TestAllocateDecision(Decision) - Constructor for class org.elasticsearch.cluster.ESAllocationTestCase.TestAllocateDecision
-
- TestAnalysis(IndexAnalyzers, Map<String, TokenFilterFactory>, Map<String, TokenizerFactory>, Map<String, CharFilterFactory>) - Constructor for class org.elasticsearch.test.ESTestCase.TestAnalysis
-
- testArrayOffset() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testBasicEquals() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testBlockingIncomingRequests() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testCharFilters() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
-
- testCheckCompatibility() - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
-
- testCheckTypeName() - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
-
- testClone() - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
-
- TestCluster - Class in org.elasticsearch.test
-
Base test cluster that exposes the basis to run tests against any elasticsearch cluster, whose layout
(e.g.
- TestCluster(long) - Constructor for class org.elasticsearch.test.TestCluster
-
- testClusterClosed() - Method in class org.elasticsearch.test.disruption.NetworkDisruption
-
- testClusterClosed() - Method in class org.elasticsearch.test.disruption.NoOpDisruptionScheme
-
- testClusterClosed() - Method in interface org.elasticsearch.test.disruption.ServiceDisruptionScheme
-
- testClusterClosed() - Method in class org.elasticsearch.test.disruption.SingleNodeDisruption
-
- testCompareTo() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testConcurrentDisconnectOnNonPublishedConnection() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testConcurrentSendRespondAndDisconnect() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testContainerCreationAndDeletion() - Method in class org.elasticsearch.repositories.ESBlobStoreTestCase
-
- testCopyBytesRefSharesBytes() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- TestCustomMetaData - Class in org.elasticsearch.test
-
- TestCustomMetaData(String) - Constructor for class org.elasticsearch.test.TestCustomMetaData
-
- testDeleteBlob() - Method in class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
-
- testDiffableSerialization() - Method in class org.elasticsearch.test.AbstractDiffableSerializationTestCase
-
- testDiffableSerialization() - Method in class org.elasticsearch.test.AbstractDiffableWireSerializationTestCase
-
- testDiffableSerialization(Supplier<T>, Function<T, T>, NamedWriteableRegistry, Writeable.Reader<T>, Writeable.Reader<Diff<T>>) - Static method in class org.elasticsearch.test.DiffableTestUtils
-
Tests making random changes to an object, calculating diffs for these changes, sending this
diffs over the wire and appling these diffs on the other side.
- testDisconnectListener() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testEmptyToBytesRefIterator() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testEquals() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testEquals() - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
-
- testEqualsAndHashcode() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
-
- testEqualsAndHashcode() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
- testEqualsAndHashcode() - Method in class org.elasticsearch.test.AbstractStreamableTestCase
-
Tests that the equals and hashcode methods are consistent and copied
versions of the instance have are equal.
- testEqualsAndHashcode() - Method in class org.elasticsearch.test.AbstractWireSerializingTestCase
-
Tests that the equals and hashcode methods are consistent and copied
versions of the instance have are equal.
- testErrorMessage() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- TestEventListener() - Constructor for class org.elasticsearch.test.MockIndexEventListener.TestEventListener
-
- testFailure(Failure) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter
-
- testFinished(Description) - Method in class org.elasticsearch.test.junit.listeners.LoggingListener
-
- testFinished(Description) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter
-
- testFreeze() - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
-
- testFromXContent() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
-
Generic test that creates new AggregatorFactory from the test
AggregatorFactory and checks both for equality and asserts equality on
the two queries.
- testFromXContent() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Generic test that creates new query from the test query and checks both for equality
and asserts equality on the two queries.
- testFromXContent() - Method in class org.elasticsearch.test.AbstractSerializingTestCase
-
Generic test that creates new instance from the test instance and checks
both for equality and asserts equality on the two instances.
- testFromXContent() - Method in class org.elasticsearch.test.AbstractStreamableXContentTestCase
-
Generic test that creates new instance from the test instance and checks
both for equality and asserts equality on the two queries.
- testFromXContent() - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
- testFromXContentWithRandomFields() - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
- TestGatewayAllocator - Class in org.elasticsearch.test.gateway
-
A gateway allocator implementation that keeps an in memory list of started shard allocation
that are used as replies to the, normally async, fetch data requests.
- TestGatewayAllocator() - Constructor for class org.elasticsearch.test.gateway.TestGatewayAllocator
-
- testGet() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testHandlerIsInvokedOnConnectionClose() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testHandshakeUpdatesVersion() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testHandshakeWithIncompatVersion() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testHashCode() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testHelloWorld() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testHelloWorldCompressed() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testHostOnMessages() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testIndicesDeletedFromRepository() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
-
- testInputStreamSkip() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testIterator() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testIteratorRandom() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testLength() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testLocalNodeConnection() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- TestLogging - Annotation Type in org.elasticsearch.test.junit.annotations
-
Annotation used to set a custom log level for a specific test method.
- testMockFailToSendNoConnectRule() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testMockUnresponsiveRule() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testMoveAndList() - Method in class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
-
- testMultipleSnapshotAndRollback() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
-
- testMultiTermAware() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
-
- testMultiValuedField() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testMultiValuedFieldWithValueScript() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testMultiValuedFieldWithValueScriptWithParams() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testMustRewrite() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
This test ensures that queries that need to be rewritten have dedicated tests.
- testNotifyOnShutdown() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testOrderByEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testOtherDocCount(String...) - Method in class org.elasticsearch.search.aggregations.bucket.AbstractTermsTestCase
-
- TestPlugin() - Constructor for class org.elasticsearch.cluster.MockInternalClusterInfoService.TestPlugin
-
- TestPlugin() - Constructor for class org.elasticsearch.search.MockSearchService.TestPlugin
-
- TestPlugin(Settings) - Constructor for class org.elasticsearch.test.discovery.TestZenDiscovery.TestPlugin
-
- TestPlugin() - Constructor for class org.elasticsearch.test.MockIndexEventListener.TestPlugin
-
- TestPlugin() - Constructor for class org.elasticsearch.test.store.MockFSIndexStore.TestPlugin
-
- TestPlugin() - Constructor for class org.elasticsearch.test.transport.MockTransportService.TestPlugin
-
- TestPlugin(Settings) - Constructor for class org.elasticsearch.transport.AssertingTransportInterceptor.TestPlugin
-
- testPreBuiltMultiTermAware() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
-
- TestProcessor - Class in org.elasticsearch.ingest
-
Processor used for testing, keeps track of how many times it is invoked and
accepts a Consumer
of IngestDocument
to be called when executed.
- TestProcessor(Consumer<IngestDocument>) - Constructor for class org.elasticsearch.ingest.TestProcessor
-
- TestProcessor(String, String, Consumer<IngestDocument>) - Constructor for class org.elasticsearch.ingest.TestProcessor
-
- TestProcessor.Factory - Class in org.elasticsearch.ingest
-
- testProfileSettings() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testProfilesIncludesDefault() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testQueryWrappedInArray() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Test that wraps the randomly generated query into an array as follows: { "query_name" : [{}]}
This causes unexpected situations in parser code that may not be handled properly.
- testRandomReads() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testReduceRandom() - Method in class org.elasticsearch.test.InternalAggregationTestCase
-
- testRegisterHandlerTwice() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- TestRequest() - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.TestRequest
-
- TestRequest(String) - Constructor for class org.elasticsearch.transport.AbstractSimpleTransportTestCase.TestRequest
-
- testResponseHeadersArePreserved() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testRunFinished(Result) - Method in class org.elasticsearch.test.junit.listeners.LoggingListener
-
- testRunStarted(Description) - Method in class org.elasticsearch.test.junit.listeners.LoggingListener
-
- TESTS_CLIENT_RATIO - Static variable in class org.elasticsearch.test.ESIntegTestCase
-
Key used to set the transport client ratio via the commandline -D"tests.client.ratio"
- TESTS_CLUSTER - Static variable in class org.elasticsearch.test.ESIntegTestCase
-
Key used to eventually switch to using an external cluster and provide its transport addresses
- TESTS_ENABLE_MOCK_MODULES - Static variable in class org.elasticsearch.test.ESIntegTestCase
-
A boolean value to enable or disable mock modules.
- testScriptMultiValued() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testScriptMultiValuedWithParams() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testScriptSingleValued() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testScriptSingleValuedWithParams() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- TestSearchContext - Class in org.elasticsearch.test
-
- TestSearchContext(ThreadPool, BigArrays, IndexService) - Constructor for class org.elasticsearch.test.TestSearchContext
-
- TestSearchContext(QueryShardContext) - Constructor for class org.elasticsearch.test.TestSearchContext
-
- TestSearchContext(QueryShardContext, IndexShard) - Constructor for class org.elasticsearch.test.TestSearchContext
-
- TestSeedPlugin() - Constructor for class org.elasticsearch.test.ESIntegTestCase.TestSeedPlugin
-
- testSendRandomRequests() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testSerialization() - Method in class org.elasticsearch.search.aggregations.BaseAggregationTestCase
-
Test serialization and deserialization of the test AggregatorFactory.
- testSerialization() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Test serialization and deserialization of the test query.
- testSerialization() - Method in class org.elasticsearch.test.AbstractStreamableTestCase
-
Test serialization and deserialization of the test instance.
- testSerialization() - Method in class org.elasticsearch.test.AbstractWireSerializingTestCase
-
Test serialization and deserialization of the test instance.
- TestShardRouting - Class in org.elasticsearch.cluster.routing
-
A helper that allows to create shard routing instances within tests, while not requiring to expose
different simplified constructors on the ShardRouting itself.
- TestShardRouting() - Constructor for class org.elasticsearch.cluster.routing.TestShardRouting
-
- testSingleValuedField() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testSingleValuedFieldGetProperty() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testSingleValuedFieldPartiallyUnmapped() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testSingleValuedFieldWithValueScript() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testSingleValuedFieldWithValueScriptWithParams() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testSlice() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testSliceArrayOffset() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testSliceCopyBytesRef() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testSliceEquals() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testSliceIterator() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testSliceStreamInput() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testSliceToBytesRef() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testSliceWriteToOutputStream() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testSnapshotAndRestore() - Method in class org.elasticsearch.repositories.blobstore.ESBlobStoreRepositoryIntegTestCase
-
- testStarted(Description) - Method in class org.elasticsearch.test.junit.listeners.LoggingListener
-
- testStarted(Description) - Method in class org.elasticsearch.test.junit.listeners.ReproduceInfoPrinter
-
- testStreamInput() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testStreamInputBulkReadWithOffset() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testStreamInputMarkAndReset() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testTcpHandshake() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testTcpHandshakeConnectionReset() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testTcpHandshakeTimeout() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- TestTemplateService - Class in org.elasticsearch.ingest
-
- TestTemplateService.MockTemplateScript - Class in org.elasticsearch.ingest
-
- TestTemplateService.MockTemplateScript.Factory - Class in org.elasticsearch.ingest
-
- testThreadContext() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- TestThreadPool - Class in org.elasticsearch.threadpool
-
- TestThreadPool(String) - Constructor for class org.elasticsearch.threadpool.TestThreadPool
-
- TestThreadPool(String, Settings) - Constructor for class org.elasticsearch.threadpool.TestThreadPool
-
- testTimeoutPerConnection() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testTimeoutSendExceptionWithDelayedResponse() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testTimeoutSendExceptionWithNeverSendingBackResponse() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testToBytes() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testToBytesRef() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testToBytesRefMaterializedPages() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testToBytesRefSharedPage() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testTokenFilters() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
-
- testTokenizers() - Method in class org.elasticsearch.indices.analysis.AnalysisFactoryTestCase
-
- testToQuery() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Test creates the Query
from the QueryBuilder
under test and delegates the
assertions being made on the result to the implementing subclass.
- testToUtf8() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- testTracerLog() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testTransportProfilesWithPortAndHost() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testTransportStats() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testTransportStatsWithException() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testUnknownField() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Test that unknown field trigger ParsingException.
- testUnknownObjectException() - Method in class org.elasticsearch.test.AbstractQueryTestCase
-
Test that adding an additional object within each object of the otherwise correct query always triggers some kind of
parse exception.
- testUnmapped() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractNumericTestCase
-
- testVerifyOverwriteFails() - Method in class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
-
- testVersionFrom0to0() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testVersionFrom0to1() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testVersionFrom1to0() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testVersionFrom1to1() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testVoidMessageCompressed() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- testWriteRead() - Method in class org.elasticsearch.repositories.ESBlobStoreContainerTestCase
-
- testWriteToOutputStream() - Method in class org.elasticsearch.common.bytes.AbstractBytesReferenceTestCase
-
- TestZenDiscovery - Class in org.elasticsearch.test.discovery
-
A alternative zen discovery which allows using mocks for things like pings, as well as
giving access to internals.
- TestZenDiscovery.TestPlugin - Class in org.elasticsearch.test.discovery
-
A plugin which installs mock discovery and configures it to be used.
- threadPool - Variable in class org.elasticsearch.index.reindex.AbstractAsyncBulkByScrollActionTestCase
-
- threadPool - Variable in class org.elasticsearch.index.shard.IndexShardTestCase
-
- threadPool - Variable in class org.elasticsearch.transport.AbstractSimpleTransportTestCase
-
- threadPoolSettings() - Method in class org.elasticsearch.index.shard.IndexShardTestCase
-
- throttleAllocationDeciders() - Static method in class org.elasticsearch.cluster.ESAllocationTestCase
-
- ThrowingFields(Fields, ThrowingLeafReaderWrapper.Thrower) - Constructor for class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.ThrowingFields
-
- ThrowingLeafReaderWrapper - Class in org.elasticsearch.test.engine
-
An FilterLeafReader that allows to throw exceptions if certain methods
are called on is.
- ThrowingLeafReaderWrapper(LeafReader, ThrowingLeafReaderWrapper.Thrower) - Constructor for class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper
-
- ThrowingLeafReaderWrapper.Flags - Enum in org.elasticsearch.test.engine
-
- ThrowingLeafReaderWrapper.Thrower - Interface in org.elasticsearch.test.engine
-
A callback interface that allows to throw certain exceptions for
methods called on the IndexReader that is wrapped by
ThrowingLeafReaderWrapper
- ThrowingLeafReaderWrapper.ThrowingFields - Class in org.elasticsearch.test.engine
-
Wraps a Fields but with additional asserts
- ThrowingLeafReaderWrapper.ThrowingTerms - Class in org.elasticsearch.test.engine
-
Wraps a Terms but with additional asserts
- ThrowingTerms(Terms, ThrowingLeafReaderWrapper.Thrower) - Constructor for class org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.ThrowingTerms
-
- timeEstimateCounter() - Method in class org.elasticsearch.test.TestSearchContext
-
- timeout() - Method in class org.elasticsearch.test.TestSearchContext
-
- timeout(TimeValue) - Method in class org.elasticsearch.test.TestSearchContext
-
- timeout() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.StringMessageRequest
-
- tmpPaths() - Method in class org.elasticsearch.test.ESTestCase
-
Returns a random number of temporary paths.
- toBytesRef() - Method in class org.elasticsearch.transport.nio.NetworkBytesReference
-
- tokenFilter - Variable in class org.elasticsearch.test.ESTestCase.TestAnalysis
-
- tokenizer - Variable in class org.elasticsearch.test.ESTestCase.TestAnalysis
-
- toShuffledXContent(ToXContent, XContentType, ToXContent.Params, boolean, String...) - Method in class org.elasticsearch.test.ESTestCase
-
Returns the bytes that represent the XContent output of the provided ToXContent
object, using the provided
XContentType
.
- toString(MappedFieldType) - Method in class org.elasticsearch.index.mapper.FieldTypeTestCase
-
- toString() - Method in class org.elasticsearch.test.client.RandomizingClient
-
- toString() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.Bridge
-
- toString() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDelay
-
- toString() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkDisconnect
-
- toString() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.NetworkUnresponsive
-
- toString() - Method in class org.elasticsearch.test.disruption.NetworkDisruption
-
- toString() - Method in class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
-
- toString() - Method in class org.elasticsearch.test.NotEqualMessageBuilder
-
The failure message.
- toString() - Method in class org.elasticsearch.test.rest.yaml.ClientYamlTestCandidate
-
- toString() - Method in class org.elasticsearch.test.TestCustomMetaData
-
- toString() - Method in class org.elasticsearch.transport.AbstractSimpleTransportTestCase.TestRequest
-
- toString() - Method in class org.elasticsearch.transport.MockTcpTransport.MockChannel
-
- totalIndexedDocs() - Method in class org.elasticsearch.test.BackgroundIndexer
-
- totalNumShards - Variable in class org.elasticsearch.test.ESIntegTestCase.NumShards
-
- toXContent(T, XContentType) - Method in class org.elasticsearch.test.AbstractSerializingTestCase
-
Renders the provided instance in XContent
- toXContent(T, XContentType) - Static method in class org.elasticsearch.test.AbstractStreamableXContentTestCase
-
Renders the provided instance in XContent
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.test.rest.yaml.Stash
-
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.test.TestCustomMetaData
-
- toXContentBuilder(XContent) - Method in class org.elasticsearch.test.rest.yaml.ObjectPath
-
Create a new
XContentBuilder
from the xContent object underlying this
ObjectPath
.
- Tracer() - Constructor for class org.elasticsearch.test.transport.MockTransportService.Tracer
-
- trackScores(boolean) - Method in class org.elasticsearch.test.TestSearchContext
-
- trackScores() - Method in class org.elasticsearch.test.TestSearchContext
-
- trackTotalHits(boolean) - Method in class org.elasticsearch.test.TestSearchContext
-
- trackTotalHits() - Method in class org.elasticsearch.test.TestSearchContext
-
- TRANSLOG_RETENTION_CHECK_INTERVAL_SETTING - Static variable in class org.elasticsearch.test.InternalSettingsPlugin
-
- transport - Variable in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- TRANSPORT_ACCEPTOR_THREAD_NAME_PREFIX - Static variable in class org.elasticsearch.transport.nio.NioTransport
-
- TRANSPORT_BASE_PORT - Variable in class org.elasticsearch.test.InternalTestCluster
-
- TRANSPORT_CLIENT_PREFIX - Static variable in class org.elasticsearch.test.InternalTestCluster
-
- TRANSPORT_WORKER_THREAD_NAME_PREFIX - Static variable in class org.elasticsearch.transport.nio.NioTransport
-
- 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
-
- transportClientSettings() - Method in class org.elasticsearch.test.discovery.ClusterDiscoveryConfiguration
-
- 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
-
- transportServiceAdapter(TransportServiceAdapter) - Method in class org.elasticsearch.test.transport.CapturingTransport
-
- transportServiceAdapter(TransportServiceAdapter) - Method in class org.elasticsearch.test.transport.MockTransportService.DelegateTransport
-
- TRUSTSTORE_PASSWORD - Static variable in class org.elasticsearch.test.rest.ESRestTestCase
-
- TRUSTSTORE_PATH - Static variable in class org.elasticsearch.test.rest.ESRestTestCase
-
- TwoPartitions(String, String) - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
-
- TwoPartitions(Set<String>, Set<String>) - Constructor for class org.elasticsearch.test.disruption.NetworkDisruption.TwoPartitions
-
- typeName() - Method in class org.elasticsearch.index.mapper.MockFieldMapper.FakeFieldType
-