All Classes
| Class | Description |
|---|---|
| AbstractAsyncBulkByScrollActionTestCase<Request extends org.elasticsearch.index.reindex.AbstractBulkByScrollRequest<Request>,Response extends org.elasticsearch.index.reindex.BulkByScrollResponse> | |
| AbstractBlobContainerRetriesTestCase | |
| AbstractBlobContainerRetriesTestCase.ZeroInputStream |
A resettable InputStream that only serves zeros.
|
| AbstractBootstrapCheckTestCase | |
| AbstractBroadcastResponseTestCase<T extends org.elasticsearch.action.support.broadcast.BroadcastResponse> | |
| AbstractBuilderTestCase | |
| AbstractBytesReferenceTestCase | |
| AbstractCoordinatorTestCase | |
| AbstractDiffableSerializationTestCase<T extends org.elasticsearch.cluster.Diffable<T> & org.elasticsearch.common.xcontent.ToXContent> |
An abstract test case to ensure correct behavior of Diffable.
|
| AbstractDiffableWireSerializationTestCase<T extends org.elasticsearch.cluster.Diffable<T>> |
An abstract test case to ensure correct behavior of Diffable.
|
| AbstractFullClusterRestartTestCase | |
| AbstractHttpFixture |
Base class for test fixtures that requires a
HttpServer to work. |
| AbstractHttpFixture.Request |
Represents an HTTP Request.
|
| AbstractHttpFixture.RequestHandler | |
| AbstractHttpFixture.Response |
Represents an HTTP Response.
|
| AbstractMultiClustersTestCase | |
| AbstractNamedWriteableTestCase<T extends org.elasticsearch.common.io.stream.NamedWriteable> |
Standard test case for testing the wire serialization of subclasses of NamedWriteable.
|
| AbstractNumericFieldMapperTestCase | |
| AbstractNumericTestCase | |
| AbstractQueryTestCase<QB extends org.elasticsearch.index.query.AbstractQueryBuilder<QB>> | |
| AbstractSchemaValidationTestCase<T extends org.elasticsearch.common.xcontent.ToXContent> |
Test case for validating
ToXContent objects against a json schema. |
| AbstractSerializingTestCase<T extends org.elasticsearch.common.xcontent.ToXContent & org.elasticsearch.common.io.stream.Writeable> | |
| AbstractSimpleTransportTestCase | |
| AbstractSimpleTransportTestCase.StringMessageRequest | |
| AbstractSimpleTransportTestCase.TestRequest | |
| AbstractSimpleTransportTestCase.Version0Request | |
| AbstractSimpleTransportTestCase.Version1Request | |
| AbstractSnapshotIntegTestCase | |
| AbstractTermsTestCase | |
| AbstractThirdPartyRepositoryTestCase | |
| AbstractWireSerializingTestCase<T extends org.elasticsearch.common.io.stream.Writeable> |
Standard test case for testing the wire serialization of subclasses of Writeable.
|
| AbstractWireTestCase<T> |
Standard test case for testing wire serialization.
|
| AbstractXContentTestCase<T extends org.elasticsearch.common.xcontent.ToXContent> | |
| AbstractXContentTestCase.XContentTester<T> |
Tests converting to and from xcontent.
|
| ActionTestUtils | |
| AggregatorTestCase |
Base class for testing
Aggregator implementations. |
| AggregatorTestCase.InternalAggCardinality | |
| AnalysisFactoryTestCase |
Alerts us if new analysis components are added to Lucene, so we don't miss them.
|
| AnalysisFactoryTestCase.MovedToAnalysisCommon |
Marker class for components that have moved to the analysis-common modules.
|
| AnalysisTestsHelper | |
| ApiCallSection |
Represents a test fragment that contains the information needed to call an api
|
| Assertion |
Base class for executable sections that hold assertions
|
| AsyncRecoveryTarget |
Wraps a
RecoveryTarget to make all remote calls to be executed asynchronously using the provided executor. |
| AzureFixtureHelper | |
| BackgroundIndexer | |
| BaseAggregationTestCase<AB extends org.elasticsearch.search.aggregations.AbstractAggregationBuilder<AB>> | |
| BasePipelineAggregationTestCase<AF extends org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder<AF>> | |
| BlobStoreTestUtil | |
| BlobStoreWrapper | |
| BlockClusterStateProcessing | |
| BlockMasterServiceOnMaster | |
| BootstrapForTesting |
Initializes natives and installs test security manager
(init'd early by base classes to ensure it happens regardless of which
test case happens to be first, test ordering, etc).
|
| BusyMasterServiceDisruption | |
| CapturingTransport |
A transport class that doesn't send anything but rather captures all requests for inspection from tests
|
| CapturingTransport.CapturedRequest | |
| ClasspathUtils | |
| ClientYamlDocsTestClient |
Used to execute REST requests according to the docs snippets that need to be tests.
|
| ClientYamlSuiteRestApi |
Specification of an Elasticsearch endpoint used by the YAML specs to generate REST requests.
|
| ClientYamlSuiteRestApi.Body | |
| ClientYamlSuiteRestApi.Path | |
| ClientYamlSuiteRestApi.Stability | |
| ClientYamlSuiteRestApi.Visibility | |
| ClientYamlSuiteRestApiParser |
Parser for a
ClientYamlSuiteRestApi. |
| ClientYamlSuiteRestSpec |
Holds the specification used to turn
do actions in the YAML suite into REST api calls. |
| ClientYamlTestCandidate |
Wraps
ClientYamlTestSections ready to be run. |
| ClientYamlTestClient |
Used by
ESClientYamlSuiteTestCase to execute REST requests according to the tests written in yaml suite files. |
| ClientYamlTestExecutionContext |
Execution context passed across the REST tests.
|
| ClientYamlTestResponse |
Response obtained from a REST call, eagerly reads the response body into a string for later optional parsing.
|
| ClientYamlTestResponseException |
Exception obtained from a REST call in case the response code indicated an error.
|
| ClientYamlTestSection |
Represents a test section, which is composed of a skip section and multiple executable sections.
|
| ClientYamlTestSuite |
Holds a REST test suite loaded from a specific yaml file.
|
| CloseToAssertion |
Represents a close_to assert section:
- close_to: { get.fields._routing: { value: 5.1, error: 0.00001 } }
|
| ClusterInfoServiceUtils | |
| ClusterServiceUtils | |
| ClusterStateCreationUtils |
Helper methods for generating cluster states
|
| CollectionAssertions |
Assertions for easier handling of our custom collections,
for example ImmutableOpenMap
|
| CollectionMatchers |
Matchers for easier handling of our custom collections,
for example ImmutableOpenMap
|
| CollectionMatchers.ImmutableOpenMapHasAllKeysMatcher | |
| CollectionMatchers.ImmutableOpenMapHasKeyMatcher | |
| CommandTestCase |
A base test case for cli tools.
|
| ContainsAssertion | |
| CoordinationStateTestCluster | |
| CorruptionUtils | |
| DataStreamTestHelper | |
| DeterministicTaskQueue | |
| DiffableTestUtils |
Utilities that simplify testing of diffable classes
|
| DiskUsageIntegTestCase |
An integration test case that allows mocking the disk usage per node.
|
| DiskUsageIntegTestCase.TestFileStore | |
| DisruptableMockTransport | |
| DisruptableMockTransport.ConnectionStatus |
Response type from
DisruptableMockTransport.getConnectionStatus(DiscoveryNode) indicating whether, and how, messages should
be disrupted on this transport. |
| DocIdSeqNoAndSource |
A tuple of document id, sequence number, primary term, source and version of a document
|
| DoSection |
Represents a do section:
- do:
catch: missing
headers:
Authorization: Basic user:pass
Content-Type: application/json
warnings|warnings_regex:
- Stuff is deprecated, yo
- Don't use deprecated stuff
- Please, stop.
|
| DummyShardLock | |
| ElasticsearchAssertions | |
| ElasticsearchMatchers | |
| ElasticsearchMatchers.HasPropertyLambdaMatcher<T,V> | |
| ElasticsearchMatchers.SearchHitHasIdMatcher | |
| ElasticsearchMatchers.SearchHitHasIndexMatcher | |
| ElasticsearchMatchers.SearchHitHasScoreMatcher | |
| ElasticsearchMatchers.SearchHitHasTypeMatcher | |
| EmptySystemIndices |
A test class which contains a singleton instance of the
SystemIndices class that has been created with no
non-standard system indices defined except for those defined within the class itself. |
| EngineTestCase | |
| EngineTestCase.IndexWriterFactory | |
| EngineTestCase.MatchingDirectoryReader | |
| EngineTestCase.PrimaryTermSupplier | |
| EqualsHashCodeTestUtils |
Utility class that encapsulates standard checks and assertions around testing the equals() and hashCode()
methods of objects that implement them.
|
| EqualsHashCodeTestUtils.CopyFunction<T> |
A function that makes a copy of its input argument
|
| EqualsHashCodeTestUtils.MutateFunction<T> |
A function that creates a copy of its input argument that is different from its
input in exactly one aspect (e.g.
|
| ESAllocationTestCase | |
| ESAllocationTestCase.DelayedShardsMockGatewayAllocator |
Mocks behavior in ReplicaShardAllocator to remove delayed shards from list of unassigned shards so they don't get reassigned yet.
|
| ESAllocationTestCase.MockAllocationService |
A lock
AllocationService allowing tests to override time |
| ESAllocationTestCase.TestAllocateDecision | |
| EsBaseDirectoryTestCase |
Extends Lucene's BaseDirectoryTestCase with ES test behavior.
|
| ESBlobStoreRepositoryIntegTestCase |
Integration tests for
BlobStoreRepository implementations. |
| ESClientYamlSuiteTestCase |
Runs a suite of yaml tests shared with all the official Elasticsearch
clients against against an elasticsearch cluster.
|
| ESFsBasedRepositoryIntegTestCase | |
| ESIndexInputTestCase |
Test harness for verifying
IndexInput implementations. |
| ESIndexLevelReplicationTestCase | |
| ESIntegTestCase |
ESIntegTestCase is an abstract base class to run integration
tests against a JVM private Elasticsearch Cluster. |
| ESIntegTestCase.AssertActionNamePlugin | |
| ESIntegTestCase.ClusterScope |
Defines a cluster scope for a
ESIntegTestCase subclass. |
| ESIntegTestCase.NumShards | |
| ESIntegTestCase.Scope |
The scope of a test cluster used together with
ESIntegTestCase.ClusterScope annotations on ESIntegTestCase subclasses. |
| ESIntegTestCase.SuiteScopeTestCase |
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 | |
| ESIntegTestCase.ThirdParty |
Annotation for third-party integration tests.
|
| ESMockAPIBasedRepositoryIntegTestCase |
Integration tests for
BlobStoreRepository implementations rely on mock APIs that emulate cloud-based services. |
| ESMockAPIBasedRepositoryIntegTestCase.BlobStoreHttpHandler |
A
HttpHandler that allows to list stored blobs |
| ESMockAPIBasedRepositoryIntegTestCase.DelegatingHttpHandler | |
| ESMockAPIBasedRepositoryIntegTestCase.ErroneousHttpHandler |
HTTP handler that injects random service errors
Note: it is not a good idea to allow this handler to simulate too many errors as it would
slow down the test suite.
|
| ESMockAPIBasedRepositoryIntegTestCase.HttpStatsCollectorHandler |
HTTP handler that allows collect request stats per request type.
|
| ESRestTestCase |
Superclass for tests that interact with an external test cluster using Elasticsearch's
RestClient. |
| ESRestTestCase.VersionSensitiveWarningsHandler |
Helper class to check warnings in REST responses with sensitivity to versions
used in the target cluster.
|
| ESSingleNodeTestCase |
A test that keep a singleton node started for all tests that can be used to get
references to Guice injectors in unit tests.
|
| ESTestCase |
Base testcase for randomized unit testing with Elasticsearch
|
| ESTestCase.GeohashGenerator | |
| ESTestCase.TestAnalysis |
This cute helper class just holds all analysis building blocks that are used
to build IndexAnalyzers.
|
| ESTokenStreamTestCase | |
| ExecutableSection |
Represents a test fragment that can be executed (e.g.
|
| ExternalTestCluster |
External cluster to run the tests against.
|
| FakeRestChannel | |
| FakeRestRequest | |
| FakeRestRequest.Builder | |
| FakeTcpChannel | |
| FakeThreadPoolMasterService | |
| FakeTransport |
A transport that does nothing.
|
| Features |
Allows to register additional features supported by the tests runner.
|
| FieldMaskingReader | |
| FieldTypeTestCase |
Base test case for subclasses of MappedFieldType
|
| GeometryTestUtils | |
| GreaterThanAssertion |
Represents a gt assert section:
|
| GreaterThanEqualToAssertion |
Represents a gte assert section:
- gte: { fields._ttl: 0 }
|
| IndexSettingsModule | |
| IndexShardTestCase |
A base class for unit tests that need to create and shutdown
IndexShard instances easily,
containing utilities for shard creation and recoveries. |
| IngestDocumentMatcher | |
| IngestTestPlugin |
Adds an ingest processor to be used in tests.
|
| IntermittentLongGCDisruption |
Simulates irregular long gc intervals.
|
| InternalAggregationTestCase<T extends org.elasticsearch.search.aggregations.InternalAggregation> |
Implementors of this test case should be aware that the aggregation under test needs to be registered
in the test's namedWriteableRegistry.
|
| InternalMultiBucketAggregationTestCase<T extends org.elasticsearch.search.aggregations.InternalAggregation & org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation> | |
| InternalSettingsPlugin | |
| InternalSingleBucketAggregationTestCase<T extends org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation> | |
| InternalTestCluster |
InternalTestCluster manages a set of JVM private nodes and allows convenient access to them.
|
| InternalTestCluster.RestartCallback |
An abstract class that is called during
InternalTestCluster.rollingRestart(InternalTestCluster.RestartCallback)
and / or InternalTestCluster.fullRestart(InternalTestCluster.RestartCallback) to execute actions at certain
stages of the restart. |
| IsFalseAssertion |
Represents an is_false assert section:
- is_false: get.fields.bar
|
| IsTrueAssertion |
Represents an is_true assert section:
- is_true: get.fields.bar
|
| JsonLogLine |
Represents a single log line in a json format.
|
| JsonLogsIntegTestCase |
Tests that extend this class verify that all json layout fields appear in the first few log lines after startup
Fields available upon process startup:
type, timestamp, level, component,
message, node.name, cluster.name. |
| JsonLogsStream |
Returns a stream of json log lines.
|
| LeakTracker |
Leak tracking mechanism that allows for ensuring that a resource has been properly released before a given object is garbage collected.
|
| LeakTracker.Leak<T> | |
| LengthAssertion |
Represents a length assert section:
|
| LessThanAssertion |
Represents a lt assert section:
- lt: { fields._ttl: 20000}
|
| LessThanOrEqualToAssertion |
Represents a lte assert section:
- lte: { fields._ttl: 0 }
|
| LinearizabilityChecker |
Basic implementation of the Wing and Gong Graph Search Algorithm, following the descriptions in
Gavin Lowe: Testing for linearizability
Concurrency and Computation: Practice and Experience 29, 4 (2017).
|
| LinearizabilityChecker.Event | |
| LinearizabilityChecker.EventType | |
| LinearizabilityChecker.History |
Sequence of invocations and responses, recording the run of a concurrent system.
|
| LinearizabilityChecker.KeyedSpec |
Sequential specification of a datatype that allows for keyed access,
providing compositional checking (see
LinearizabilityChecker.SequentialSpec.partition(List)). |
| LinearizabilityChecker.SequentialSpec |
Sequential specification of a datatype.
|
| LoggingListener |
A
RunListener that allows changing the log level for a specific test method. |
| LongGCDisruption |
Suspends all threads on the specified node in order to simulate a long gc.
|
| MapperScriptTestCase<FactoryType> | |
| MapperServiceTestCase |
Test case that lets you easilly build
MapperService based on some
mapping. |
| MapperTestCase |
Base class for testing
Mappers. |
| MapperTestUtils | |
| MatchAssertion |
Represents a match assert section:
- match: { get.fields._routing: "5" }
|
| MetadataMapperTestCase | |
| MockBigArrays | |
| MockBigArrays.LimitedBreaker | |
| MockDeterministicScript |
A mocked script used for testing purposes.
|
| MockEngineFactory | |
| MockEngineFactoryPlugin |
A plugin to use
MockEngineFactory. |
| MockEngineSupport |
Support class to build MockEngines like
MockInternalEngine
since they need to subclass the actual engine |
| MockEngineSupport.DirectoryReaderWrapper | |
| MockEngineSupport.MockContext | |
| MockFieldFilterPlugin | |
| MockFieldMapper | |
| MockFieldMapper.Builder | |
| MockFieldMapper.FakeFieldType | |
| MockFSDirectoryFactory | |
| MockFSDirectoryFactory.ElasticsearchMockDirectoryWrapper | |
| MockFSIndexStore | |
| MockFSIndexStore.TestPlugin | |
| MockGatewayMetaState |
GatewayMetaState constructor accepts a lot of arguments. |
| MockHttpTransport |
A dummy http transport used by tests when not wanting to actually bind to a real address.
|
| MockHttpTransport.TestPlugin |
Marker plugin used by
MockNode to enable MockHttpTransport. |
| MockIndexEventListener |
This is a testing plugin that registers a generic
MockIndexEventListener.TestEventListener as a node level service
as well as a listener on every index. |
| MockIndexEventListener.TestEventListener | |
| MockIndexEventListener.TestPlugin | |
| MockInternalClusterInfoService | |
| MockInternalClusterInfoService.TestPlugin |
This is a marker plugin used to trigger MockNode to use this mock info service.
|
| MockKeywordPlugin |
Some tests rely on the keyword tokenizer, but this tokenizer isn't part of lucene-core and therefor not available
in some modules.
|
| MockLogAppender |
Test appender that can be used to verify that certain events were logged correctly
|
| MockLogAppender.AbstractEventExpectation | |
| MockLogAppender.ExceptionSeenEventExpectation | |
| MockLogAppender.LoggingExpectation | |
| MockLogAppender.PatternSeenEventExpectation | |
| MockLogAppender.SeenEventExpectation | |
| MockLogAppender.UnseenEventExpectation | |
| MockNioTransport | |
| MockNioTransportPlugin | |
| MockNode |
A node for testing which allows:
Overriding Version.CURRENT
Adding test plugins that exist on the classpath
|
| MockPageCacheRecycler | |
| MockRepository | |
| MockRepository.Plugin | |
| MockScriptEngine |
A mocked script engine that can be used for testing purpose.
|
| MockScriptEngine.ContextCompiler |
A non-typed compiler for a single custom context
|
| MockScriptEngine.MockFilterScript | |
| MockScriptEngine.MockMetricAggCombineScript | |
| MockScriptEngine.MockMetricAggCombineScriptFactory | |
| MockScriptEngine.MockMetricAggInitScript | |
| MockScriptEngine.MockMetricAggInitScriptFactory | |
| MockScriptEngine.MockMetricAggMapScript | |
| MockScriptEngine.MockMetricAggMapScriptFactory | |
| MockScriptEngine.MockMetricAggReduceScript | |
| MockScriptEngine.MockMetricAggReduceScriptFactory | |
| MockScriptPlugin |
A script plugin that uses
MockScriptEngine as the script engine for tests. |
| MockScriptService | |
| MockScriptService.TestPlugin |
Marker plugin used by
MockNode to enable MockScriptService. |
| MockSearchService | |
| MockSearchService.TestPlugin |
Marker plugin used by
MockNode to enable MockSearchService. |
| MockSecureSettings |
A mock implementation of secure settings for tests to use.
|
| MockSinglePrioritizingExecutor |
Mock single threaded
PrioritizedEsThreadPoolExecutor based on DeterministicTaskQueue,
simulating the behaviour of an executor returned by EsExecutors.newSinglePrioritizing(java.lang.String, java.util.concurrent.ThreadFactory, org.elasticsearch.common.util.concurrent.ThreadContext, java.util.concurrent.ScheduledExecutorService). |
| MockTaskManager |
A mock task manager that allows adding listeners for events
|
| MockTaskManagerListener |
Listener for task registration/unregistration
|
| MockTerminal |
A terminal for tests which captures all output, and
can be plugged with fake input.
|
| MockTransport |
A basic transport implementation that allows to intercept requests that have been sent
|
| MockTransportClient | Deprecated. |
| MockTransportService |
A mock delegate service that allows to simulate different network topology failures.
|
| MockTransportService.TestPlugin | |
| ModuleTestCase |
Base testcase for testing
Module implementations. |
| MyFilterTokenFilterFactory | |
| NamedFormatter |
A formatter that allows named placeholders e.g.
|
| Network |
Annotation used to set if internet network connectivity is required to run the test.
|
| NetworkDisruption |
Network disruptions are modeled using two components:
1) the
NetworkDisruption.DisruptedLinks represents the links in the network that are to be disrupted
2) the NetworkDisruption.NetworkLinkDisruptionType represents the failure mode that is to be applied to the links |
| NetworkDisruption.Bridge |
Creates two partitions with symmetric failures and a bridge node that can connect to both of the partitions
|
| NetworkDisruption.DisruptedLinks |
Represents a set of nodes with connections between nodes that are to be disrupted
|
| NetworkDisruption.IsolateAllNodes | |
| NetworkDisruption.NetworkDelay |
Simulates slow or congested network.
|
| NetworkDisruption.NetworkLinkDisruptionType |
Abstract class representing various types of network disruptions.
|
| NetworkDisruption.TwoPartitions |
Creates two partitions with symmetric failures
|
| NodeConfigurationSource | |
| NodeMocksPlugin | |
| NodeRoles |
Utility methods for creating
Settings instances defining a set of DiscoveryNodeRole. |
| NoOpClient |
Client that always responds with
null to every request. |
| NoOpNodeClient |
Client that always response with
null to every request. |
| NotEqualMessageBuilder |
Builds a message describing how two sets of values are unequal.
|
| NullDispatcher | |
| ObjectPath |
Holds an object and allows to extract specific values from it given their path
|
| OptionalMatchers | |
| PathUtilsForTesting |
Exposes some package private stuff in PathUtils for framework purposes only!
|
| PluginTestUtil |
Utility methods for testing plugins
|
| PosixPermissionsResetter |
Stores the posix attributes for a path and resets them on close.
|
| RandomAliasActionsGenerator | |
| RandomCreateIndexGenerator | |
| RandomDocumentPicks | |
| RandomizingClient |
A
Client that randomizes request parameters. |
| RandomObjects | |
| RandomSearchRequestGenerator |
Builds random search requests.
|
| RecoverySettingsChunkSizePlugin |
Marker plugin that will trigger
MockNode making RecoverySettingsChunkSizePlugin.CHUNK_SIZE_SETTING dynamic. |
| RegexMatcher |
Matcher that supports regular expression and allows to provide optional flags
|
| ReproduceInfoPrinter |
A
RunListener that emits a command you can use to re-run a failing test with the failing random seed to
System.err. |
| ReproduceInfoPrinter.GradleMessageBuilder | |
| RestActionTestCase |
A common base class for Rest*ActionTests.
|
| RestActionTestCase.VerifyingClient |
A mocked
NodeClient which can be easily reconfigured to verify arbitrary verification
functions, and can be reset to allow reconfiguration partway through a test without having to construct a new object. |
| RestClientBuilderTestCase |
A test case with access to internals of a RestClient.
|
| RestoreOnlyRepository |
A dummy repository for testing which just needs restore overridden
|
| RetentionLeaseUtils | |
| ScoreAccessor |
A float encapsulation that dynamically accesses the score of a document.
|
| SearcherHelper | |
| ServiceDisruptionScheme | |
| SetSection |
Represents a set section:
- set: {_scroll_id: scroll_id}
|
| SetupSection |
Represents a setup section.
|
| ShardRoutingHelper |
A helper class that allows access to package private APIs for testing.
|
| SingleNodeDisruption | |
| SkipSection |
Represents a skip section that tells whether a specific test section or suite needs to be skipped
based on:
- the elasticsearch version the tests are running against
- a specific test feature required that might not be implemented yet by the runner
- an operating system (full name, including specific Linux distributions) that might show a certain behavior
|
| SlowClusterStateProcessing | |
| Stash |
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.
|
| StreamsUtils | |
| StubbableConnectionManager | |
| StubbableConnectionManager.GetConnectionBehavior | |
| StubbableConnectionManager.NodeConnectedBehavior | |
| StubbableTransport | |
| StubbableTransport.OpenConnectionBehavior | |
| StubbableTransport.RequestHandlingBehavior<Request extends org.elasticsearch.transport.TransportRequest> | |
| StubbableTransport.SendRequestBehavior | |
| TeardownSection | |
| TestCircuitBreaker | |
| TestCluster |
Base test cluster that exposes the basis to run tests against any elasticsearch cluster, whose layout
(e.g.
|
| TestCustomMetadata | |
| TestEnvironment |
Provides a convenience method for tests to construct an Environment when the config path does not matter.
|
| TestEventHandler | |
| TestGatewayAllocator |
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.
|
| TestGeoShapeFieldMapperPlugin | Deprecated. |
| TestIndexNameExpressionResolver |
A utility class that simplifies the creation of
IndexNameExpressionResolver instances in tests to avoid repetition of
creating the constructor arguments for a default instance. |
| TestIssueLogging |
Annotation used to set a custom log level when investigating test failures.
|
| TestLogging |
Annotation used to set a custom log level for controlling logging behavior in tests.
|
| TestProcessor |
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.Factory | |
| TestProfiles | |
| TestRequest | |
| TestResponse | |
| TestSearchContext | |
| TestShardRouting |
A helper that allows to create shard routing instances within tests, while not requiring to expose
different simplified constructors on the ShardRouting itself.
|
| TestTemplateService | |
| TestTemplateService.MockTemplateScript | |
| TestTemplateService.MockTemplateScript.Factory | |
| TestThreadInfoPatternConverter |
Converts
%test_thread_info in log4j patterns into information
based on the loggin thread's name. |
| TestThreadPool | |
| TestTransportChannel | |
| TestTransportChannels | |
| ThrowingLeafReaderWrapper |
An FilterLeafReader that allows to throw exceptions if certain methods
are called on is.
|
| ThrowingLeafReaderWrapper.Flags |
Flags passed to
ThrowingLeafReaderWrapper.Thrower.maybeThrow(org.elasticsearch.test.engine.ThrowingLeafReaderWrapper.Flags)
when the corresponding method is called. |
| ThrowingLeafReaderWrapper.Thrower |
A callback interface that allows to throw certain exceptions for
methods called on the IndexReader that is wrapped by
ThrowingLeafReaderWrapper |
| ThrowingLeafReaderWrapper.ThrowingFields |
Wraps a Fields but with additional asserts
|
| ThrowingLeafReaderWrapper.ThrowingTerms |
Wraps a Terms but with additional asserts
|
| TransformAndSetSection |
Represents a transform_and_set section:
|
| TranslogDeletionPolicies | |
| TranslogHandler | |
| TransportRecoveryActionHelper |
Helper methods for
TransportRecoveryAction. |
| TransportWriteActionTestHelper | |
| TupleMatchers | |
| VersionRange | |
| VersionUtils |
Utilities for selecting versions in tests
|
| XContentTestUtils | |
| XContentTestUtils.JsonMapView |