All Classes

Class Description
AbstractAggregationBuilder<AB extends AbstractAggregationBuilder<AB>>
Base implementation of a AggregationBuilder.
AbstractAllocateAllocationCommand
Abstract base class for allocating an unassigned shard to a node
AbstractAllocateAllocationCommand.Builder<T extends AbstractAllocateAllocationCommand>
Works around ObjectParser not supporting constructor arguments.
AbstractAllocationDecision
An abstract class for representing various types of allocation decisions.
AbstractAsyncTask
A base class for tasks that need to repeat.
AbstractAtomicGeoPointFieldData  
AbstractAtomicOrdinalsFieldData  
AbstractBinaryDocValues
Base implementation that throws an IOException for the DocIdSetIterator APIs.
AbstractBindingBuilder<T>
Bind a value or constant.
AbstractBlobContainer
A base abstract blob container that implements higher level container methods.
AbstractBulkByScrollRequest<Self extends AbstractBulkByScrollRequest<Self>>  
AbstractBulkByScrollRequestBuilder<Request extends AbstractBulkByScrollRequest<Request>,​Self extends AbstractBulkByScrollRequestBuilder<Request,​Self>>  
AbstractBulkIndexByScrollRequest<Self extends AbstractBulkIndexByScrollRequest<Self>>  
AbstractBulkIndexByScrollRequestBuilder<Request extends AbstractBulkIndexByScrollRequest<Request>,​Self extends AbstractBulkIndexByScrollRequestBuilder<Request,​Self>>  
AbstractBytesReference  
AbstractCatAction  
AbstractCharFilterFactory  
AbstractClient  
AbstractDiffable<T extends Diffable<T>>
Abstract diffable object with simple diffs implementation that sends the entire object if object has changed or nothing is object remained the same.
AbstractGeometryFieldMapper<Parsed,​Processed>
AbstractGeometryFieldMapper.AbstractGeometryFieldType<Parsed,​Processed>  
AbstractGeometryFieldMapper.Builder<T extends AbstractGeometryFieldMapper.Builder,​Y extends AbstractGeometryFieldMapper>  
AbstractGeometryFieldMapper.Defaults  
AbstractGeometryFieldMapper.Indexer<Parsed,​Processed>
Interface representing an preprocessor in geo-shape indexing pipeline
AbstractGeometryFieldMapper.Names  
AbstractGeometryFieldMapper.Parser<Parsed>
interface representing parser in geo shape indexing pipeline
AbstractGeometryFieldMapper.QueryProcessor
interface representing a query builder that generates a query from the given shape
AbstractGeometryFieldMapper.TypeParser  
AbstractGeometryQueryBuilder<QB extends AbstractGeometryQueryBuilder<QB>>
Base QueryBuilder that builds a Geometry Query
AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
local class that encapsulates xcontent parsed shape parameters
AbstractHighlighterBuilder<HB extends AbstractHighlighterBuilder<?>>
This abstract class holds parameters shared by HighlightBuilder and HighlightBuilder.Field and provides the common setters, equality, hashCode calculation and common serialization
AbstractHttpServerTransport  
AbstractIndexAnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer>  
AbstractIndexComponent  
AbstractIndexFieldData<FD extends AtomicFieldData>  
AbstractIndexFieldData.PerValueEstimator
A PerValueEstimator is a sub-class that can be used to estimate the memory overhead for loading the data.
AbstractIndexOrdinalsFieldData  
AbstractIndexShardComponent  
AbstractInternalProfileTree<PB extends AbstractProfileBreakdown<?>,​E>  
AbstractLatLonPointDVIndexFieldData  
AbstractLatLonPointDVIndexFieldData.Builder  
AbstractLatLonPointDVIndexFieldData.LatLonPointDVIndexFieldData  
AbstractLifecycleComponent  
AbstractLifecycleRunnable
AbstractLifecycleRunnable is a service-lifecycle aware AbstractRunnable.
AbstractMatcher<T>
Implements and() and or().
AbstractModule
A support class for Modules which reduces repetition and results in a more readable configuration.
AbstractNamedDiffable<T extends NamedDiffable<T>>
Abstract diffable object with simple diffs implementation that sends the entire object if object has changed or nothing is object remained the same.
AbstractNumericDocValues
Base implementation that throws an IOException for the DocIdSetIterator APIs.
AbstractPipelineAggregationBuilder<PAB extends AbstractPipelineAggregationBuilder<PAB>>
Base implementation of a PipelineAggregationBuilder.
AbstractProcessor
An Abstract Processor that holds a processorTag field to be used by other processors.
AbstractProfileBreakdown<T extends java.lang.Enum<T>>
A record of timings for the various operations that may happen during query execution.
AbstractProfiler<PB extends AbstractProfileBreakdown<?>,​E>  
AbstractQueryBuilder<QB extends AbstractQueryBuilder<QB>>
Base class for all classes producing lucene queries.
AbstractRangeAggregatorFactory<R extends RangeAggregator.Range>  
AbstractRangeBuilder<AB extends AbstractRangeBuilder<AB,​R>,​R extends RangeAggregator.Range>  
AbstractRareTermsAggregator<T extends ValuesSource,​U extends IncludeExclude.Filter,​V>  
AbstractRecyclerC<T>  
AbstractResourceWatcher<Listener>
Abstract resource watcher framework, which handles adding and removing listeners and calling resource observer.
AbstractRestChannel  
AbstractRunnable
An extension to runnable.
AbstractScopedSettings
A basic setting service that can be used for per-index and per-cluster settings.
AbstractScopedSettings.SettingUpdater<T>
Transactional interface to update settings.
AbstractSortedDocValues
Base implementation that throws an IOException for the DocIdSetIterator APIs.
AbstractSortedNumericDocValues
Base implementation that throws an IOException for the DocIdSetIterator APIs.
AbstractSortedSetDocValues
Base implementation that throws an IOException for the DocIdSetIterator APIs.
AbstractSortingNumericDocValues
Base implementation that throws an IOException for the DocIdSetIterator APIs.
AbstractTokenFilterFactory  
AbstractTokenizerFactory  
AckClusterStatePublishResponseHandler
Allows to wait for all nodes to reply to the publish of a new cluster state and notifies the ClusterStatePublisher.AckListener so that the cluster state update can be acknowledged
AckedClusterStateTaskListener  
AckedClusterStateUpdateTask<Response>
An extension interface to ClusterStateUpdateTask that allows to be notified when all the nodes have acknowledged a cluster state update request
AckedRequest
Identifies a cluster state update request with acknowledgement support
AcknowledgedRequest<Request extends MasterNodeRequest<Request>>
Abstract class that allows to mark action requests that support acknowledgements.
AcknowledgedRequestBuilder<Request extends AcknowledgedRequest<Request>,​Response extends AcknowledgedResponse,​RequestBuilder extends AcknowledgedRequestBuilder<Request,​Response,​RequestBuilder>>
Base request builder for master node operations that support acknowledgements
AcknowledgedResponse
A response that indicates that a request has been acknowledged
ActionFilter
A filter allowing to filter transport actions
ActionFilter.Simple
A simple base class for injectable action filters that spares the implementation from handling the filter chain.
ActionFilterChain<Request extends ActionRequest,​Response extends ActionResponse>
A filter chain allowing to continue and process the transport action request
ActionFilters
Holds the action filters injected through plugins, properly sorted by ActionFilter.order()
ActionFuture<T>
An extension to Future allowing for simplified "get" operations.
ActionListener<Response>
A listener for action responses or failures.
ActionListenerResponseHandler<Response extends TransportResponse>
A simple base class for action response listeners, defaulting to using the SAME executor (as its very common on response handlers).
ActionModule
Builds and binds the generic action map, all TransportActions, and ActionFilters.
ActionNotFoundTransportException
An exception indicating that a transport action was not found.
ActionPlugin
An additional extension point for Plugins that extends Elasticsearch's scripting functionality.
ActionPlugin.ActionHandler<Request extends ActionRequest,​Response extends ActionResponse>  
ActionRequest  
ActionRequestBuilder<Request extends ActionRequest,​Response extends ActionResponse>  
ActionRequestValidationException  
ActionResponse
Base class for responses to action requests.
ActionRunnable<Response>
Base class for Runnables that need to call ActionListener.onFailure(Exception) in case an uncaught exception or error is thrown while the actual action is run.
ActionTransportException
An action invocation failure.
ActionType<Response extends ActionResponse>
A generic action.
ActiveShardCount
A class whose instances represent a value for counting the number of active shard copies for a given shard in an index.
ActiveShardsObserver
This class provides primitives for waiting for a configured number of shards to become active before sending a response on an ActionListener.
AdapterActionFuture<T,​L>  
AdaptiveSelectionStats
Class representing statistics about adaptive replica selection.
AddVotingConfigExclusionsAction  
AddVotingConfigExclusionsRequest
A request to add voting config exclusions for certain master-eligible nodes, and wait for these nodes to be removed from the voting configuration.
AddVotingConfigExclusionsResponse
A response to AddVotingConfigExclusionsRequest indicating that voting config exclusions have been added for the requested nodes and these nodes have been removed from the voting configuration.
AdjacencyMatrix
A multi bucket aggregation where the buckets are defined by a set of filters (a bucket is produced per filter plus a bucket for each non-empty filter intersection so A, B and A&B).
AdjacencyMatrix.Bucket
A bucket associated with a specific filter or pair (identified by its key)
AdjacencyMatrixAggregationBuilder  
AdjacencyMatrixAggregator
Aggregation for adjacency matrices.
AdjacencyMatrixAggregator.KeyedFilter  
AdjacencyMatrixAggregatorFactory  
AdminClient
Administrative actions/operations against the cluster or the indices.
AggregatedDfs  
Aggregation
An aggregation.
Aggregation.CommonFields
Common xcontent fields that are shared among addAggregation
AggregationBuilder
A factory that knows how to create an Aggregator of a specific type.
AggregationBuilder.CommonFields
Common xcontent fields shared among aggregator builders
AggregationBuilders
Utility class to create aggregations.
AggregationExecutionException
Thrown when failing to execute an aggregation
AggregationInitializationException
Thrown when failing to execute an aggregation
AggregationInspectionHelper
Provides a set of static helpers to determine if a particular type of InternalAggregation "has a value" or not.
AggregationPath
A path that can be used to sort/order buckets (in some multi-bucket aggregations, e.g.
AggregationPath.PathElement  
AggregationPhase
Aggregation phase of a search request, used to collect aggregations
AggregationProfileBreakdown  
AggregationProfiler  
AggregationProfileShardResult
A container class to hold the profile results for a single shard in the request.
Aggregations
Represents a set of Aggregations
AggregationScript  
AggregationScript.Factory
A factory to construct stateful AggregationScript factories for a specific index.
AggregationScript.LeafFactory
A factory to construct AggregationScript instances.
AggregationTimingType  
Aggregator
An Aggregator.
Aggregator.Parser
Parses the aggregation request and creates the appropriate aggregator factory for it.
Aggregator.SubAggCollectionMode
Aggregation mode for sub aggregations.
AggregatorBase
Base implementation for concrete aggregators.
AggregatorFactories  
AggregatorFactories.Builder  
AggregatorFactory  
AggregatorFactory.MultiBucketAggregatorWrapper  
Alias
Represents an alias, to be associated with an index
AliasAction
Individual operation to perform on the cluster state as part of an IndicesAliasesRequest.
AliasAction.Add
Operation to add an alias to an index.
AliasAction.NewAliasValidator
Validate a new alias.
AliasAction.Remove
Operation to remove an alias from an index.
AliasAction.RemoveIndex
Operation to remove an index.
AliasesExistAction  
AliasesExistRequestBuilder  
AliasesExistResponse  
AliasesNotFoundException  
AliasesRequest
Needs to be implemented by all ActionRequest subclasses that relate to one or more indices and one or more aliases.
AliasFilter
Represents a QueryBuilder and a list of alias names that filters the builder is composed of.
AliasFilterParsingException  
AliasMetaData  
AliasMetaData.Builder  
AliasOrIndex
Encapsulates the IndexMetaData instances of a concrete index or indices an alias is pointing to.
AliasOrIndex.Alias
Represents an alias and groups all IndexMetaData instances sharing the same alias name together.
AliasOrIndex.Index
Represents an concrete index and encapsulates its IndexMetaData
AliasValidator
Validator for an alias, to be used before adding an alias to the index metadata and make sure the alias is valid
AllCircuitBreakerStats
Stats class encapsulating all of the different circuit breaker stats
AllFieldMapper
Noop mapper that ensures that mappings created in 6x that explicitly disable the _all field can be restored in this version.
AllFieldMapper.Builder  
AllFieldMapper.Defaults  
AllFieldMapper.TypeParser  
AllocatedPersistentTask
Represents a executor node operation that corresponds to a persistent task
AllocatedPersistentTask.State  
AllocateEmptyPrimaryAllocationCommand
Allocates an unassigned empty primary shard to a specific node.
AllocateEmptyPrimaryAllocationCommand.Builder  
AllocateReplicaAllocationCommand
Allocates an unassigned replica shard to a specific node.
AllocateReplicaAllocationCommand.Builder  
AllocateStalePrimaryAllocationCommand
Allocates an unassigned stale primary shard to a specific node.
AllocateStalePrimaryAllocationCommand.Builder  
AllocateUnassignedDecision
Represents the allocation decision by an allocator for an unassigned shard.
AllocationCommand
A command to move shards in some way.
AllocationCommands
A simple AllocationCommand composite managing several AllocationCommand implementations
AllocationDecider
AllocationDecider is an abstract base class that allows to make dynamic cluster- or index-wide shard allocation decisions on a per-node basis.
AllocationDeciders
A composite AllocationDecider combining the "decision" of multiple AllocationDecider implementations into a single allocation decision.
AllocationDecision
An enum which represents the various decision types that can be taken by the allocators and deciders for allocating a shard to a node.
AllocationId
Uniquely identifies an allocation.
AllocationService
This service manages the node allocation of a cluster.
AllocationService.CommandsResult
this class is used to describe results of applying a set of AllocationCommand
Analysis  
AnalysisMode
Enum representing the mode in which token filters and analyzers are allowed to operate.
AnalysisModule
AnalysisModule.AnalysisProvider<T>
The basic factory interface for analysis components.
AnalysisPlugin
An additional extension point for Plugins that extends Elasticsearch's analysis functionality.
AnalysisRegistry
An internal registry for tokenizer, token filter, char filter and analyzer.
AnalyzeAction  
AnalyzeAction.AnalyzeToken  
AnalyzeAction.AnalyzeTokenList  
AnalyzeAction.CharFilteredText  
AnalyzeAction.DetailAnalyzeResponse  
AnalyzeAction.Request
A request to analyze a text associated with a specific index.
AnalyzeAction.Response  
AnalyzerComponents
A class that groups analysis components necessary to produce a custom analyzer.
AnalyzerComponentsProvider
Analyzers that provide access to their token filters should implement this
AnalyzeRequestBuilder  
AnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer>  
AnalyzerScope  
AnnotatedBindingBuilder<T>
See the EDSL examples at Binder.
AnnotatedConstantBindingBuilder
See the EDSL examples at Binder.
AnnotatedElementBuilder
See the EDSL examples at Binder.
Annotations
Annotation utilities.
ApplyCommitRequest
A master node sends this request to its peers to inform them that it could commit the cluster state with the given term and version.
ArrayUtils  
ArrayValueMapperParser
A marker interface indicating that this mapper can handle array value, and the array itself should be passed to it.
Assertions
Provides a static final field that can be used to check if assertions are enabled.
AssignmentDecision
AssignmentDecision represents the decision made during the process of assigning a persistent task to a node of the cluster.
AssignmentDecision.Type  
Assisted
Annotates an injected parameter or field whose value comes from an argument to a factory method.
AssistedInject Deprecated.
FactoryProvider now works better with the standard @Inject annotation.
AsyncBiFunction<T,​U,​C>
A BiFunction-like interface designed to be used with asynchronous executions.
AsyncIOProcessor<Item>
This async IO processor allows to batch IO operations and have a single writer processing the write operations.
AsyncShardFetch<T extends BaseNodeResponse>
Allows to asynchronously fetch shard related data from other nodes for allocation, without blocking the cluster update thread.
AsyncShardFetch.FetchResult<T extends BaseNodeResponse>
The result of a fetch operation.
AsyncShardFetch.Lister<NodesResponse extends BaseNodesResponse<NodeResponse>,​NodeResponse extends BaseNodeResponse>
An action that lists the relevant shard data that needs to be fetched.
AtomicArray<E>
A list backed by an AtomicReferenceArray with potential null values, easily allowing to get the concrete values as a list using AtomicArray.asList().
AtomicFieldData
The thread safe LeafReader level cache of the data.
AtomicGeoPointFieldData
AtomicFieldData specialization for geo points.
AtomicHistogramFieldData
AtomicFieldData specialization for histogram data.
AtomicNumericFieldData
Specialization of AtomicFieldData for numeric data.
AtomicOrdinalsFieldData
Specialization of AtomicFieldData for data that is indexed with ordinals.
AutoCreateIndex
Encapsulates the logic of whether a new index should be automatically created when a write operation is about to happen in a non existing index.
AutoDateHistogramAggregationBuilder  
AutoDateHistogramAggregationBuilder.RoundingInfo  
AutoDateHistogramAggregatorFactory  
AutoExpandReplicas
This class acts as a functional wrapper around the index.auto_expand_replicas setting.
AutoQueueAdjustingExecutorBuilder
A builder for executors that automatically adjust the queue length as needed, depending on Little's Law.
Avg
An aggregation that computes the average of the values in the current bucket.
AvgAggregationBuilder  
AvgBucketPipelineAggregationBuilder  
AvgBucketPipelineAggregator  
AwarenessAllocationDecider
This AllocationDecider controls shard allocation based on awareness key-value pairs defined in the node configuration.
BackoffPolicy
Provides a backoff policy for bulk requests.
BalancedShardsAllocator
The BalancedShardsAllocator re-balances the nodes allocations within an cluster based on a BalancedShardsAllocator.WeightFunction.
BalancedShardsAllocator.Balancer
BalancedShardsAllocator.WeightFunction
This class is the primary weight function used to create balanced over nodes and shards in the cluster.
BaseAggregationBuilder
Interface shared by AggregationBuilder and PipelineAggregationBuilder so they can conveniently share the same namespace for XContentParser.namedObject(Class, String, Object).
BaseAliasesRequestBuilder<Response extends ActionResponse,​Builder extends BaseAliasesRequestBuilder<Response,​Builder>>  
BaseFuture<V>  
BaseGatewayShardAllocator
An abstract class that implements basic functionality for allocating shards to nodes based on shard copies that already exist in the cluster.
BaseNodeRequest  
BaseNodeResponse
A base class for node level operations.
BaseNodesRequest<Request extends BaseNodesRequest<Request>>  
BaseNodesResponse<TNodeResponse extends BaseNodeResponse>  
BasePrimaryAllocationCommand
Abstract base class for allocating an unassigned primary shard to a node
BasePrimaryAllocationCommand.Builder<T extends BasePrimaryAllocationCommand>  
BaseRestHandler
Base handler for REST requests.
BaseRestHandler.RestChannelConsumer
REST requests are handled by preparing a channel consumer that represents the execution of the request against a channel.
BaseTasksRequest<Request extends BaseTasksRequest<Request>>
A base class for task requests
BaseTasksResponse
Base class for responses of task-related operations
BaseTermQueryBuilder<QB extends BaseTermQueryBuilder<QB>>  
BaseTranslogReader
A base class for all classes that allows reading ops from translog files
BasicReplicationRequest
A replication request that has no more information than ReplicationRequest.
BatchedRerouteService
A BatchedRerouteService is a RerouteService that batches together reroute requests to avoid unnecessary extra reroutes.
BestBucketsDeferringCollector
A specialization of DeferringBucketCollector that collects all matches and then is able to replay a given subset of buckets which represent the survivors from a pruning process performed by the aggregator that owns this collector.
BestDocsDeferringCollector
A specialization of DeferringBucketCollector that collects all matches and then replays only the top scoring documents to child aggregations.
BigArray
Base abstraction of an array.
BigArrays
Utility class to work with arrays.
BinaryDocValuesRangeQuery  
BinaryDocValuesRangeQuery.QueryType  
BinaryDVAtomicFieldData
AtomicFieldData impl on top of Lucene's binary doc values.
BinaryDVIndexFieldData  
BinaryFieldMapper  
BinaryFieldMapper.Builder  
BinaryFieldMapper.CustomBinaryDocValuesField  
BinaryFieldMapper.Defaults  
BinaryFieldMapper.TypeParser  
BinaryRange
A range field for binary encoded ranges
BinaryRangeAggregator
A range aggregator for values that are stored in SORTED_SET doc values.
BinaryRangeAggregator.Range  
BinaryRangeAggregatorFactory  
Binder
Collects configuration information (primarily bindings) which will be used to create an Injector.
BindHttpException  
Binding<T>
A mapping from a key (type and optional annotation) to the strategy for getting instances of the type.
BindingAnnotation
Annotates annotations which are used for binding.
BindingBuilder<T>
Bind a non-constant key.
BindingImpl<T>  
BindingScopingVisitor<V>
Visits each of the strategies used to scope an injection.
BindingTargetVisitor<T,​V>
Visits each of the strategies used to find an instance to satisfy an injection.
BindTransportException  
BitArray
A bit array that is implemented using a growing LongArray created from BigArrays.
BitsetFilterCache
This is a cache for BitDocIdSet based filters and is unbounded by size or time.
BitsetFilterCache.Listener
A listener interface that is executed for each onCache / onRemoval event
BitsetFilterCache.Value  
BlendedTermQuery
BlendedTermQuery can be used to unify term statistics across one or more fields in the index.
BlobContainer
An interface for managing a repository of blob entries, where each blob entry is just a named group of bytes.
BlobMetaData
An interface for providing basic metadata about a blob.
BlobPath
The list of paths where a blob can reside.
BlobStore
An interface for storing blobs.
BlobStoreException  
BlobStoreIndexShardSnapshot
Shard snapshot metadata
BlobStoreIndexShardSnapshot.FileInfo
Information about snapshotted file
BlobStoreIndexShardSnapshots
Contains information about all snapshots for the given shard in repository
BlobStoreRepository
BlobStore - based implementation of Snapshot Repository
BlockingClusterStatePublishResponseHandler
Handles responses obtained when publishing a new cluster state from master to all non master nodes.
BooleanFieldMapper
A field mapper for boolean fields.
BooleanFieldMapper.BooleanFieldType  
BooleanFieldMapper.Builder  
BooleanFieldMapper.Defaults  
BooleanFieldMapper.TypeParser  
BooleanFieldMapper.Values  
BoolQueryBuilder
A Query that matches documents matching boolean combinations of other queries.
BoostingQueryBuilder
The BoostingQuery class can be used to effectively demote results that match a given query.
BootstrapCheck
Encapsulates a bootstrap check.
BootstrapCheck.BootstrapCheckResult
Encapsulate the result of a bootstrap check.
BootstrapContext
Context that is passed to every bootstrap check to make decisions on.
BootstrapInfo
Exposes system startup information
BootstrapSettings  
BoundedBreakIteratorScanner
A custom break iterator that is used to find break-delimited passages bounded by a provided maximum length in the UnifiedHighlighter context.
BoundTransportAddress
A bounded transport address is a tuple of TransportAddress, one array that represents the addresses the transport is bound to, and the other is the published one that represents the address clients should communicate on.
BreakerSettings
Settings for a CircuitBreaker
BroadcastOperationRequestBuilder<Request extends BroadcastRequest<Request>,​Response extends BroadcastResponse,​RequestBuilder extends BroadcastOperationRequestBuilder<Request,​Response,​RequestBuilder>>  
BroadcastRequest<Request extends BroadcastRequest<Request>>  
BroadcastResponse
Base class for all broadcast operation based responses.
BroadcastShardOperationFailedException
An exception indicating that a failure occurred performing an operation on the shard.
BroadcastShardRequest  
BroadcastShardResponse  
BucketAggregationScript
A script used in bucket aggregations that returns a double value.
BucketAggregationScript.Factory  
BucketAggregationSelectorScript
A script used in bucket aggregations that returns a boolean value.
BucketAggregationSelectorScript.Factory  
BucketCollector
A Collector that can collect data in separate buckets.
BucketHelpers
A set of static helpers to simplify working with aggregation buckets, in particular providing utilities that help pipeline aggregations.
BucketHelpers.GapPolicy
A gap policy determines how "holes" in a set of buckets should be handled.
BucketMetricsParser
A parser for parsing requests for a BucketMetricsPipelineAggregator
BucketMetricsPipelineAggregationBuilder<AF extends BucketMetricsPipelineAggregationBuilder<AF>>  
BucketMetricsPipelineAggregator
A class of sibling pipeline aggregations which calculate metrics across the buckets of a sibling aggregation
BucketMetricValue  
BucketOrder
BucketPriorityQueue<B extends Terms.Bucket>  
BucketsAggregator  
BucketScriptPipelineAggregationBuilder  
BucketScriptPipelineAggregator  
BucketSelectorPipelineAggregationBuilder  
BucketSelectorPipelineAggregator  
BucketSignificancePriorityQueue<B extends SignificantTerms.Bucket>  
BucketSortPipelineAggregationBuilder
Builds a pipeline aggregation that allows sorting the buckets of its parent aggregation.
BucketSortPipelineAggregator  
BucketUtils
Helper functions for common Bucketing functions
BufferedChecksumStreamInput
Similar to Lucene's BufferedChecksumIndexInput, however this wraps a StreamInput so anything read will update the checksum
BufferedChecksumStreamOutput
Similar to Lucene's BufferedChecksumIndexOutput, however this wraps a StreamOutput so anything written will update the checksum
Build
Information about a build of Elasticsearch.
Build.Flavor  
Build.Type  
BulkAction  
BulkByScrollResponse
Response used for actions that index many documents using a scroll request.
BulkByScrollTask
Task storing information about a currently running BulkByScroll request.
BulkByScrollTask.Status
Status of the reindex, update by query, or delete by query.
BulkByScrollTask.StatusBuilder
This class acts as a builder for BulkByScrollTask.Status.
BulkByScrollTask.StatusOrException
The status of a slice of the request.
BulkItemRequest  
BulkItemResponse
Represents a single item response for an action executed as part of the bulk API.
BulkItemResponse.Failure
Represents a failure.
BulkProcessor
A bulk processor is a thread safe bulk processing class, allowing to easily set when to "flush" a new bulk request (either based on number of actions, based on the size, or time), and to easily control the number of concurrent bulk requests allowed to be executed in parallel.
BulkProcessor.Builder
A builder used to create a build an instance of a bulk processor.
BulkProcessor.Listener
A listener for the execution.
BulkRequest
A bulk request holds an ordered IndexRequests, DeleteRequests and UpdateRequests and allows to executes it in a single batch.
BulkRequestBuilder
A bulk request holds an ordered IndexRequests and DeleteRequests and allows to executes it in a single batch.
BulkRequestHandler
Implements the low-level details of bulk request handling
BulkRequestParser
Helper to parse bulk requests.
BulkResponse
A response of a bulk execution.
BulkShardRequest  
BulkShardResponse  
ByteArray
Abstraction of an array of byte values.
ByteArrayIndexInput
Wraps array of bytes into IndexInput
ByteBufferReference
This is a BytesReference backed by a ByteBuffer.
ByteBufferStreamInput  
BytesArray  
BytesBinaryDVIndexFieldData  
BytesBinaryDVIndexFieldData.Builder  
ByteSizeUnit
A SizeUnit represents size at a given unit of granularity and provides utility methods to convert across units.
ByteSizeValue  
BytesReference
A reference to bytes.
BytesRefFieldComparatorSource
Comparator source for string/binary values.
BytesRefHash
Specialized hash table implementation similar to Lucene's BytesRefHash that maps BytesRef values to ids.
BytesRefs  
BytesRestResponse  
BytesStream  
BytesStreamOutput
A @link StreamOutput that uses BigArrays to acquire pages of bytes, which avoids frequent reallocation & copying of the internal data.
BytesTransportRequest
A specialized, bytes only request, that can potentially be optimized on the network layer, specifically for the same large buffer send to several nodes.
ByteUtils
Utility methods to do byte-level encoding.
Cache<K,​V>
A simple concurrent cache.
Cache.CacheStats  
CacheBuilder<K,​V>  
CachedSupplier<T>
A Supplier that caches its return value.
CacheLoader<K,​V>  
CancelAllocationCommand
A command that cancels relocation, or recovery of a given shard on a node.
CancellableTask
A task that can be canceled
CancellableThreads
A utility class for multi threaded operation that needs to be cancellable via interrupts.
CancellableThreads.ExecutionCancelledException  
CancellableThreads.Interruptible  
CancellableThreads.IOInterruptible  
CancellableThreads.OnCancel  
CancelTasksAction
ActionType for cancelling running tasks
CancelTasksRequest
A request to cancel tasks
CancelTasksRequestBuilder
Builder for the request to cancel tasks running on the specified nodes
CancelTasksResponse
Returns the list of tasks that were cancelled
CandidateGenerator  
Cardinality
An aggregation that computes approximate numbers of unique terms.
CardinalityAggregationBuilder  
CategoryContextMapping
A ContextMapping that uses a simple string as a criteria The suggestions are boosted and/or filtered by their associated category (string) value.
CategoryContextMapping.Builder
CategoryQueryContext
Defines the query context for CategoryContextMapping
CategoryQueryContext.Builder  
CellIdSource
Wrapper class to help convert MultiGeoPointValues to numeric long values for bucketing.
CellIdSource.GeoPointLongEncoder
The encoder to use to convert a geopoint's (lon, lat, precision) into a long-encoded bucket key for aggregating.
ChannelActionListener<Response extends TransportResponse,​Request extends TransportRequest>  
ChannelFactory
only for testing until we have a disk-full FileSystem
Channels  
CharFilterFactory  
CheckedBiConsumer<T,​U,​E extends java.lang.Exception>
A BiConsumer-like interface which allows throwing checked exceptions.
CheckedBiFunction<T,​U,​R,​E extends java.lang.Exception>
A BiFunction-like interface which allows throwing checked exceptions.
CheckedConsumer<T,​E extends java.lang.Exception>
A Consumer-like interface which allows throwing checked exceptions.
CheckedSupplier<R,​E extends java.lang.Exception>
A Supplier-like interface which allows throwing checked exceptions.
ChecksumBlobStoreFormat<T extends ToXContent>
Snapshot metadata file format used in v2.0 and above
ChildMemoryCircuitBreaker
Breaker that will check a parent's when incrementing
ChiSquare  
ChiSquare.ChiSquareBuilder  
Cidrs  
CircleBuilder  
CircuitBreaker
Interface for an object that can be incremented, breaking after some configured limit has been reached.
CircuitBreaker.Durability  
CircuitBreaker.Type  
CircuitBreakerService
Interface for Circuit Breaker services, which provide breakers to classes that load field data.
CircuitBreakerStats
Class encapsulating stats about the circuit breaker
CircuitBreakingException
Exception thrown when the circuit breaker trips
Classes  
ClassPermission
Checked by scripting engines to allow loading a java class.
CleanupRepositoryAction  
CleanupRepositoryRequest  
CleanupRepositoryRequestBuilder  
CleanupRepositoryResponse  
ClearIndicesCacheAction  
ClearIndicesCacheRequest  
ClearIndicesCacheRequestBuilder  
ClearIndicesCacheResponse
The response of a clear cache action.
ClearScrollAction  
ClearScrollRequest  
ClearScrollRequestBuilder  
ClearScrollResponse  
ClearVotingConfigExclusionsAction  
ClearVotingConfigExclusionsRequest
A request to clear the voting config exclusions from the cluster state, optionally waiting for these nodes to be removed from the cluster first.
ClearVotingConfigExclusionsResponse
A response to ClearVotingConfigExclusionsRequest indicating that voting config exclusions have been cleared from the cluster state.
Client
A client provides a one stop interface for performing actions/operations against the cluster.
ClientScrollableHitSource
A scrollable source of hits from a Client instance.
CloseableChannel  
CloseableConnection
Abstract Transport.Connection that provides common close logic.
CloseIndexAction  
CloseIndexClusterStateUpdateRequest
Cluster state update request that allows to close one or more indices
CloseIndexRequest
A request to close an index.
CloseIndexRequestBuilder
Builder for close index request
CloseIndexResponse  
CloseIndexResponse.IndexResult  
CloseIndexResponse.ShardResult  
CloseIndexResponse.ShardResult.Failure  
ClusterAdminClient
Administrative actions/operations against indices.
ClusterAllocationExplainAction
ActionType for explaining shard allocation for a shard in the cluster
ClusterAllocationExplainRequest
A request to explain the allocation of a shard in the cluster
ClusterAllocationExplainRequestBuilder
Builder for requests to explain the allocation of a shard in the cluster
ClusterAllocationExplainResponse
Explanation response for a shard in the cluster
ClusterAllocationExplanation
A ClusterAllocationExplanation is an explanation of why a shard is unassigned, or if it is not unassigned, then which nodes it could possibly be relocated to.
ClusterApplier  
ClusterApplier.ClusterApplyListener
Listener for results of cluster state application
ClusterApplierService  
ClusterBlock  
ClusterBlockException  
ClusterBlockLevel  
ClusterBlocks
Represents current cluster level blocks to block dirty operations done against the cluster.
ClusterBlocks.Builder  
ClusterBootstrapService  
ClusterChangedEvent
An event received by the local node, signaling that the cluster state has changed.
ClusterFormationFailureHelper  
ClusterGetSettingsRequest
This request is specific to the REST client.
ClusterGetSettingsResponse
This response is specific to the REST client.
ClusterHealthAction  
ClusterHealthRequest  
ClusterHealthRequest.Level  
ClusterHealthRequestBuilder  
ClusterHealthResponse  
ClusterHealthStatus  
ClusterIndexHealth  
ClusterInfo
ClusterInfo is an object representing a map of nodes to DiskUsage and a map of shard ids to shard sizes, see InternalClusterInfoService.shardIdentifierFromRouting(String) for the key used in the shardSizes map
ClusterInfoRequest<Request extends ClusterInfoRequest<Request>>  
ClusterInfoRequestBuilder<Request extends ClusterInfoRequest<Request>,​Response extends ActionResponse,​Builder extends ClusterInfoRequestBuilder<Request,​Response,​Builder>>  
ClusterInfoService
Interface for a class used to gather information about a cluster periodically.
ClusterModule
Configures classes and services that affect the entire cluster.
ClusterName  
ClusterNameExpressionResolver
Resolves cluster names from an expression.
ClusterPlugin
An extension point for Plugin implementations to customer behavior of cluster management.
ClusterRebalanceAllocationDecider
This AllocationDecider controls re-balancing operations based on the cluster wide active shard state.
ClusterRebalanceAllocationDecider.ClusterRebalanceType
An enum representation for the configured re-balance type.
ClusterRerouteAction  
ClusterRerouteRequest
Request to submit cluster reroute allocation commands
ClusterRerouteRequestBuilder
Builder for a cluster reroute request
ClusterRerouteResponse
Response returned after a cluster reroute request
ClusterSearchShardsAction  
ClusterSearchShardsGroup  
ClusterSearchShardsRequest  
ClusterSearchShardsRequestBuilder  
ClusterSearchShardsResponse  
ClusterService  
ClusterSettings
Encapsulates all valid cluster level settings.
ClusterShardHealth  
ClusterState
Represents the current state of the cluster.
ClusterState.Builder  
ClusterState.Custom  
ClusterState.FeatureAware
An interface that implementors use when a class requires a client to maybe have a feature.
ClusterState.Metric  
ClusterStateAction  
ClusterStateApplier
A component that is in charge of applying an incoming cluster state to the node internal data structures.
ClusterStateHealth  
ClusterStateListener
A listener to be notified when a cluster state changes.
ClusterStateObserver
A utility class which simplifies interacting with the cluster state in cases where one tries to take action based on the current state but may want to wait for a new state and retry upon failure.
ClusterStateObserver.Listener  
ClusterStatePublisher  
ClusterStatePublisher.AckListener  
ClusterStateRequest  
ClusterStateRequestBuilder  
ClusterStateResponse
The response for getting the cluster state.
ClusterStateTaskConfig
Cluster state update task configuration for timeout and priority
ClusterStateTaskConfig.Basic  
ClusterStateTaskExecutor<T>  
ClusterStateTaskExecutor.ClusterTasksResult<T>
Represents the result of a batched execution of cluster state update tasks
ClusterStateTaskExecutor.ClusterTasksResult.Builder<T>  
ClusterStateTaskExecutor.TaskResult  
ClusterStateTaskListener  
ClusterStateUpdateRequest<T extends ClusterStateUpdateRequest<T>>
Base class to be used when needing to update the cluster state Contains the basic fields that are always needed
ClusterStateUpdateResponse
Base response returned after a cluster state update
ClusterStateUpdaters  
ClusterStateUpdateTask
A task that can update the cluster state.
ClusterStatsAction  
ClusterStatsIndices  
ClusterStatsIndices.ShardStats  
ClusterStatsNodeResponse  
ClusterStatsNodes  
ClusterStatsNodes.Counts  
ClusterStatsNodes.JvmStats  
ClusterStatsNodes.JvmVersion  
ClusterStatsNodes.OsStats  
ClusterStatsNodes.ProcessStats  
ClusterStatsRequest
A request to get cluster level stats.
ClusterStatsRequestBuilder  
ClusterStatsResponse  
ClusterUpdateSettingsAction  
ClusterUpdateSettingsRequest
Request for an update cluster settings action
ClusterUpdateSettingsRequestBuilder
Builder for a cluster update settings request
ClusterUpdateSettingsResponse
A response for a cluster update settings action.
CodecService
Since Lucene 4.0 low level index segments are read and written through a codec layer that allows to use use-case specific file formats & data-structures per field.
CollapseBuilder
A builder that enables field collapsing on search request.
CollapseContext
Context used for field collapsing
CollapseTopFieldDocs
Represents hits returned by CollapsingTopDocsCollector.getTopDocs().
CollapsingTopDocsCollector<T>
A collector that groups documents based on field values and returns CollapseTopFieldDocs output.
CollectionUtils
Collections-related utility methods.
CollectorResult
Public interface and serialization container for profiled timings of the Collectors used in the search.
CombinedBitSet
A BitSet implementation that combines two instances of BitSet and Bits to provide a single merged view.
CombinedDeletionPolicy
An IndexDeletionPolicy that coordinates between Lucene's commits and the retention of translog generation files, making sure that all translog files that are needed to recover from the Lucene commit are not deleted.
CombinedRateLimiter
A rate limiter designed for multiple concurrent users.
CombineFunction  
CommandLoggingConfigurator
Holder class for method to configure logging without Elasticsearch configuration files for use in CLI tools that will not read such files.
CommitStats
a class the returns dynamic information with respect to the last commit point of this shard
CommonStats  
CommonStatsFlags  
CommonStatsFlags.Flag  
CommonTermsQueryBuilder Deprecated.
Since max_optimization optimization landed in 7.0, normal MatchQuery will achieve the same result without any configuration.
Comparators
Comparator-related utility methods.
CompensatedSum
Used to calculate sums using the Kahan summation algorithm.
CompletionFieldMapper
Mapper for completion field.
CompletionFieldMapper.Builder
CompletionFieldMapper.CompletionFieldType  
CompletionFieldMapper.Defaults  
CompletionFieldMapper.Fields  
CompletionFieldMapper.TypeParser  
CompletionPersistentTaskAction
ActionType that is used by executor node to indicate that the persistent action finished or failed on the node and needs to be removed from the cluster state in case of successful completion or restarted on some other node in case of failure.
CompletionPersistentTaskAction.Request  
CompletionPersistentTaskAction.RequestBuilder  
CompletionPersistentTaskAction.TransportAction  
CompletionStats  
CompletionSuggester  
CompletionSuggestion
Suggestion response for CompletionSuggester results Response format for each entry: { "text" : STRING "score" : FLOAT "contexts" : CONTEXTS } CONTEXTS : { "CONTEXT_NAME" : ARRAY, ..
CompletionSuggestion.Entry  
CompletionSuggestion.Entry.Option  
CompletionSuggestionBuilder
Defines a suggest command based on a prefix, typically to provide "auto-complete" functionality for users as they type search terms.
CompletionSuggestionContext  
CompositeAggregation  
CompositeAggregation.Bucket  
CompositeAggregationBuilder  
CompositeBytesReference
A composite BytesReference that allows joining multiple bytes references into one without copying.
CompositeIndicesRequest
Marker interface that needs to be implemented by all ActionRequest subclasses that are composed of multiple sub-requests which relate to one or more indices.
CompositeValuesSourceBuilder<AB extends CompositeValuesSourceBuilder<AB>>
CompositeValuesSourceParserHelper  
CompoundProcessor
A Processor that executes a list of other "processors".
CompressedXContent
Similar class to the String class except that it internally stores data using a compressed representation in order to require less permanent memory.
Compressor  
CompressorFactory  
ConcurrentCollections  
ConcurrentDequeRecycler<T>
A Recycler implementation based on a concurrent Deque.
ConcurrentHashMapLong<T>  
ConcurrentMapLong<T>  
ConcurrentRebalanceAllocationDecider
Similar to the ClusterRebalanceAllocationDecider this AllocationDecider controls the number of currently in-progress re-balance (relocation) operations and restricts node allocations if the configured threshold is reached.
ConcurrentSnapshotExecutionException
Thrown when a user tries to multiple conflicting snapshot/restore operations at the same time.
Condition<T>
Base class for rollover request conditions
Condition.Result
Holder for evaluated condition result
Condition.Stats
Holder for index stats used to evaluate conditions
ConditionalProcessor  
ConfigurationException
Thrown when a programming error such as a misplaced annotation, illegal binding, or unsupported scope is found.
ConfigurationUtils  
ConnectionManager
This class manages node connections.
ConnectionManager.ConnectionValidator  
ConnectionProfile
A connection profile describes how many connection are established to specific node for each of the available request types.
ConnectionProfile.Builder
A builder to build a new ConnectionProfile
ConnectTransportException  
ConsistentSettingsService
Used to publish secure setting hashes in the cluster state and to validate those hashes against the local values of those same settings.
ConsoleCtrlHandler  
ConstantBindingBuilder
Binds to a constant value.
ConstantBindingBuilderImpl<T>
Bind a constant.
ConstantIndexFieldData  
ConstantIndexFieldData.Builder  
ConstantScoreQueryBuilder
A query that wraps a filter and simply returns a constant score equal to the query boost for every document in the filter.
ConstructionContext<T>
Context of a dependency construction.
ConstructorBinding<T>
A binding to the constructor of a concrete clss.
ContentPath  
ContextBuilder<E extends ContextMapping<?>>
Builder for ContextMapping
ContextIndexSearcher
Context-aware extension of IndexSearcher.
ContextMapping<T extends ToXContent>
A ContextMapping defines criteria that can be used to filter and/or boost suggestions at query time for CompletionFieldMapper.
ContextMapping.InternalQueryContext  
ContextMapping.Type  
ContextMappings
ContextMappings indexes context-enabled suggestion fields and creates context queries for defined ContextMappings for a CompletionFieldMapper
ContextPreservingActionListener<R>
Restores the given ThreadContext.StoredContext once the listener is invoked
ConvertedConstantBinding<T>
A binding created from converting a bound instance to a new type.
CoordinateNode
Node used to represent a tree of coordinates.
CoordinatesBuilder
A builder for a list of coordinates.
CoordinationMetaData  
CoordinationMetaData.Builder  
CoordinationMetaData.VotingConfigExclusion  
CoordinationMetaData.VotingConfiguration
A collection of persistent node ids, denoting the voting configuration for cluster state changes.
CoordinationState
The core class of the cluster state coordination algorithm, directly implementing the formal model
CoordinationState.PersistedState
Pluggable persistence layer for CoordinationState.
CoordinationState.VoteCollection
A collection of votes, used to calculate quorums.
CoordinationStateRejectedException
This exception is thrown when rejecting state transitions on the CoordinationState object, for example when receiving a publish request with the wrong term or version.
Coordinator  
Coordinator.Mode  
CopyOnWriteHashMap<K,​V>
An immutable map whose writes result in a new copy of the map to be created.
CoreValuesSourceType
CoreValuesSourceType holds the ValuesSourceType implementations for the core aggregations package.
Correction  
CorruptStateException
This exception is thrown when Elasticsearch detects an inconsistency in one of it's persistent states.
CorsHandler
This file is forked from the https://netty.io project.
CorsHandler.Config  
CountDown
A simple thread safe count-down class that in contrast to a CountDownLatch never blocks.
CountedBitSet
A CountedBitSet wraps a FixedBitSet but automatically releases the internal bitset when all bits are set to reduce memory usage.
CounterMetric  
CreateIndexAction  
CreateIndexClusterStateUpdateRequest
Cluster state update request that allows to create an index
CreateIndexClusterStateUpdateResponse
A cluster state update response with specific fields for index creation.
CreateIndexRequest
A request to create an index.
CreateIndexRequestBuilder
Builder for a create index request
CreateIndexResponse
A response for a create index action.
CreateSnapshotAction
Create snapshot action
CreateSnapshotRequest
Create snapshot request
CreateSnapshotRequestBuilder
Create snapshot request builder
CreateSnapshotResponse
Create snapshot response
CreationException
Thrown when errors occur while creating a Injector.
CuckooFilter
An approximate set membership datastructure CuckooFilters are similar to Bloom Filters in usage; values are inserted, and the Cuckoo can be asked if it has seen a particular value before.
CumulativeSumPipelineAggregationBuilder  
CumulativeSumPipelineAggregator  
CustomAnalyzer  
CustomAnalyzerProvider
A custom analyzer that is built out of a single Tokenizer and a list of TokenFilters.
CustomDocValuesField  
CustomFieldQuery  
CustomFieldsVisitor
A field visitor that allows to load a selection of the stored fields by exact name or by pattern.
CustomNormalizerProvider
A custom normalizer that is built out of a char and token filters.
CustomPassageFormatter
Custom passage formatter that allows us to: 1) extract different snippets (instead of a single big string) together with their scores (Snippet) 2) use the Encoder implementations that are already used with the other highlighters
CustomQueryScorer  
CustomUnifiedHighlighter
Subclass of the UnifiedHighlighter that works for a single field in a single document.
DanglingIndicesState
The dangling indices state is responsible for finding new dangling indices (indices that have their state written on disk, but don't exists in the metadata of the cluster), and importing them into the cluster.
DataOutputStreamOutput  
DateFieldMapper
A FieldMapper for dates.
DateFieldMapper.Builder  
DateFieldMapper.DateFieldType  
DateFieldMapper.Defaults  
DateFieldMapper.Resolution  
DateFieldMapper.TypeParser  
DateFormatter  
DateFormatters  
DateHistogramAggregationBuilder
A builder for histograms on date fields.
DateHistogramAggregatorFactory  
DateHistogramInterval
The interval the date histogram is based on.
DateHistogramValuesSourceBuilder
A CompositeValuesSourceBuilder that builds a RoundingValuesSource from a Script or a field name using the provided interval.
DateIntervalConsumer<T>
A shared interface for aggregations that parse and use "interval" parameters.
DateIntervalWrapper
A class that handles all the parsing, bwc and deprecations surrounding date histogram intervals.
DateIntervalWrapper.IntervalTypeEnum  
DateMathParser
An abstraction over date math parsing to allow different implementation for joda and java time.
DateRangeAggregationBuilder  
DateRangeAggregatorFactory  
DateTimeUnit  
DateUtils  
DeadlockAnalyzer  
DeadlockAnalyzer.Deadlock  
DecayFunction
Implement this interface to provide a decay function that is executed on a distance.
DecayFunctionBuilder<DFB extends DecayFunctionBuilder<DFB>>  
DecayFunctionBuilder.AbstractDistanceScoreFunction
This is the base class for scoring a single field.
DecayFunctionParser<DFB extends DecayFunctionBuilder<DFB>>
Parser used for all decay functions, one instance each.
Decision
This abstract class defining basic Decision used during shard allocation process.
Decision.Multi
Simple class representing a list of decisions
Decision.Single
Simple class representing a single decision
Decision.Type
This enumeration defines the possible types of decisions
DeDuplicatingTokenFilter
Inspects token streams for duplicate sequences of tokens.
DefaultBindingScopingVisitor<V>
No-op visitor for subclassing.
DefaultBindingTargetVisitor<T,​V>
No-op visitor for subclassing.
DefaultElementVisitor<V>
No-op visitor for subclassing.
DefaultRestChannel
The default rest channel for incoming requests.
DefaultShardOperationFailedException  
DeferableBucketAggregator  
DeferringBucketCollector
A BucketCollector that records collected doc IDs and buckets and allows to replay a subset of the collected buckets.
DeflateCompressor
Compressor implementation based on the DEFLATE compression algorithm.
DelayedAllocationService
The DelayedAllocationService listens to cluster state changes and checks if there are unassigned shards with delayed allocation (unassigned shards that have the delay marker).
DelayRecoveryException
An exception marking that this recovery attempt should be ignored (since probably, we already recovered).
DeleteAction  
DeleteByQueryAction  
DeleteByQueryRequest
Creates a new DeleteByQueryRequest that uses scrolling and bulk requests to delete all documents matching the query.
DeleteByQueryRequestBuilder  
DeleteIndexAction  
DeleteIndexClusterStateUpdateRequest
Cluster state update request that allows to close one or more indices
DeleteIndexRequest
A request to delete an index.
DeleteIndexRequestBuilder  
DeleteIndexTemplateAction  
DeleteIndexTemplateRequest
A request to delete an index template.
DeleteIndexTemplateRequestBuilder  
DeletePipelineAction  
DeletePipelineRequest  
DeletePipelineRequestBuilder  
DeletePipelineTransportAction  
DeleteRepositoryAction
Unregister repository action
DeleteRepositoryRequest
Unregister repository request.
DeleteRepositoryRequestBuilder
Builder for unregister repository request
DeleteRequest
A request to delete a document from an index based on its type and id.
DeleteRequestBuilder
A delete document action request builder.
DeleteResponse
The response of the delete action.
DeleteResponse.Builder
Builder class for DeleteResponse.
DeleteResult
The result of deleting multiple blobs from a BlobStore.
DeleteSnapshotAction
Delete snapshot action
DeleteSnapshotRequest
Delete snapshot request
DeleteSnapshotRequestBuilder
Delete snapshot request builder
DeleteStoredScriptAction  
DeleteStoredScriptRequest  
DeleteStoredScriptRequestBuilder  
Dependency<T>
A variable that can be resolved by an injector.
DeprecatedMessage
A logger message used by DeprecationLogger.
DeprecationLogger
A logger that logs deprecation notices.
DeprecationMap  
DeprecationRestHandler
DeprecationRestHandler provides a proxy for any existing RestHandler so that usage of the handler can be logged using the DeprecationLogger.
DequeRecycler<T>
A Recycler implementation based on a Deque.
Derivative  
DerivativePipelineAggregationBuilder  
DerivativePipelineAggregator  
DestructiveOperations
Helper for dealing with destructive operations and wildcard usage.
DetachClusterCommand  
DfsPhase
Dfs phase of a search request, used to make scoring 100% accurate by collecting additional info from each shard before the query phase.
DfsPhaseExecutionException  
DfsSearchResult  
Diff<T>
Represents difference between states of cluster state parts
Diffable<T>
Cluster state part, changes in which can be serialized
DiffableStringMap
This is a Map<String, String> that implements AbstractDiffable so it can be used for cluster state purposes
DiffableStringMap.DiffableStringMapDiff
Represents differences between two DiffableStringMaps.
DiffableUtils  
DiffableUtils.DiffableValueReader<K,​V extends Diffable<V>>
Implementation of the ValueSerializer that wraps value and diff readers.
DiffableUtils.DiffableValueSerializer<K,​V extends Diffable<V>>
Serializer for Diffable map values.
DiffableUtils.ImmutableOpenMapDiff<K,​T>
Represents differences between two ImmutableOpenMap of (possibly diffable) objects
DiffableUtils.KeySerializer<K>
Provides read and write operations to serialize keys of map
DiffableUtils.MapDiff<K,​T,​M>
Represents differences between two maps of objects and is used as base class for different map implementations.
DiffableUtils.NonDiffableValueSerializer<K,​V>
Serializer for non-diffable map values
DiffableUtils.StringSetValueSerializer<K>
Implementation of ValueSerializer that serializes immutable sets
DiffableUtils.ValueSerializer<K,​V>
Provides read and write operations to serialize map values.
DirectCandidateGenerator  
DirectCandidateGenerator.Candidate  
DirectCandidateGenerator.CandidateSet  
DirectCandidateGenerator.TokenConsumer  
DirectCandidateGeneratorBuilder  
DirectoryService  
DirectSpellcheckerSettings  
DisabledQueryCache  
DisableGraphAttribute
This attribute can be used to indicate that the PositionLengthAttribute should not be taken in account in this TokenStream.
DisableGraphAttributeImpl
Default implementation of DisableGraphAttribute.
Discovery
A pluggable module allowing to implement discovery of other nodes, publishing of the cluster state to all nodes, electing a master of the cluster that raises cluster state change events.
DiscoveryModule
A module for loading classes for node discovery.
DiscoveryNode
A discovery node represents a node that is part of the cluster.
DiscoveryNodeFilters  
DiscoveryNodeFilters.OpType  
DiscoveryNodeRole
Represents a node role.
DiscoveryNodes
This class holds all DiscoveryNode in the cluster and provides convenience methods to access, modify merge / diff discovery nodes.
DiscoveryNodes.Builder  
DiscoveryNodes.Delta  
DiscoveryPlugin
An additional extension point for Plugins that extends Elasticsearch's discovery functionality.
DiscoverySettings
Exposes common discovery settings that may be supported by all the different discovery implementations
DiscoveryStats  
DiscoveryUpgradeService
Deals with rolling upgrades of the cluster coordination layer.
DiskThresholdDecider
The DiskThresholdDecider checks that the node a shard is potentially being allocated to has enough disk space.
DiskThresholdMonitor
Listens for a node to go over the high watermark and kicks off an empty reroute if it does.
DiskThresholdSettings
A container to keep settings for disk thresholds up to date with cluster setting changes.
DiskUsage
Encapsulation class used to represent the amount of disk used on a node.
DisMaxQueryBuilder
A query that generates the union of documents produced by its sub-queries, and that scores each document with the maximum score for that document as produced by any sub-query, plus a tie breaking increment for any additional matching sub-queries.
DistanceFeatureQueryBuilder
A query to boost scores based on their proximity to the given origin for date, date_nanos and geo_point field types
DistanceFeatureQueryBuilder.Origin  
DistanceUnit
The DistanceUnit enumerates several units for measuring distances.
DistanceUnit.Distance
This class implements a value+unit tuple.
DiversifiedAggregationBuilder  
DiversifiedAggregatorFactory  
DiversifiedBytesHashSamplerAggregator
Alternative, faster implementation for converting String keys to longs but with the potential for hash collisions.
DiversifiedMapSamplerAggregator  
DiversifiedNumericSamplerAggregator  
DiversifiedOrdinalsSamplerAggregator  
DocLookup  
DocsStats  
DocumentField
A single field name and values part of SearchHit and GetResult.
DocumentFieldMappers  
DocumentMapper  
DocumentMapper.Builder  
DocumentMapperForType  
DocumentMapperParser  
DocumentMissingException  
DocumentSourceMissingException  
DocValueBits  
DocValueFormat
A formatter for values as returned by the fielddata/doc-values APIs.
DocValueFormat.DateTime  
DocValueFormat.Decimal  
DocValuesIndexFieldData
IndexFieldData impl based on Lucene's doc values.
DocValuesIndexFieldData.Builder  
DocValuesSliceQuery
A SliceQuery that uses the numeric doc values of a field to do the slicing.
DocWriteRequest<T>
Generic interface to group ActionRequest, which perform writes to a single document Action requests implementing this can be part of BulkRequest
DocWriteRequest.OpType
Requested operation type to perform on the document
DocWriteResponse
A base class for the response of a write operation that involves a single doc
DocWriteResponse.Builder
Base class of all DocWriteResponse builders.
DocWriteResponse.Result
An enum that represents the results of CRUD operations, primarily used to communicate the type of operation that occurred.
DoubleArray
Abstraction of an array of double values.
DoubleTerms
Result of the TermsAggregator when the field is some kind of decimal number like a float, double, or distance.
DoubleTermsAggregator  
DoubleValuesComparatorSource
Comparator source for double values.
DropProcessor
Drop processor only returns null for the execution result to indicate that any document executed by it should not be indexed.
DropProcessor.Factory  
DuplicateByteSequenceSpotter
A Trie structure for analysing byte streams for duplicate sequences.
DuplicateSequenceAttribute
Provides statistics useful for detecting duplicate sections of text
DuplicateSequenceAttributeImpl  
DynamicKeyFieldMapper
A field mapper that supports lookup of dynamic sub-keys.
DynamicTemplate  
DynamicTemplate.MatchType  
DynamicTemplate.XContentFieldType
The type of a field as detected while parsing a json document.
EarlyTerminatingCollector
A Collector that early terminates collection after maxCountHits docs have been collected.
ElasticsearchClient  
ElasticsearchCorruptionException
This exception is thrown when Elasticsearch detects an inconsistency in one of it's persistent files.
ElasticsearchDirectoryReader
A FilterDirectoryReader that exposes Elasticsearch internal per shard / index information like the shard ID.
ElasticsearchException
A base class for all elasticsearch exceptions.
ElasticsearchGenerationException
A generic exception indicating failure to generate.
ElasticsearchLeafReader
A FilterLeafReader that exposes Elasticsearch internal per shard / index information like the shard ID.
ElasticsearchMergePolicy
A MergePolicy that upgrades segments and can upgrade merges.
ElasticsearchNodeCommand  
ElasticsearchNodeCommand.UnknownCondition  
ElasticsearchNodeCommand.UnknownMetaDataCustom  
ElasticsearchParseException
Unchecked exception that is translated into a 400 BAD REQUEST error when it bubbles out over HTTP.
ElasticsearchSecurityException
Generic security exception
ElasticsearchStatusException
Exception who's RestStatus is arbitrary rather than derived.
ElasticsearchTimeoutException
The same as TimeoutException simply a runtime one.
ElasticsearchWrapperException
An exception that is meant to be "unwrapped" when sent back to the user as an error because its is cause, if non-null is always more useful to the user than the exception itself.
ElectionSchedulerFactory
It's provably impossible to guarantee that any leader election algorithm ever elects a leader, but they generally work (with probability that approaches 1 over time) as long as elections occur sufficiently infrequently, compared to the time it takes to send a message to another node and receive a response back.
ElectionStrategy
Allows plugging in a custom election strategy, restricting the notion of an election quorum.
ElectMasterService  
ElectMasterService.MasterCandidate
a class to encapsulate all the information about a candidate in a master election that is needed to decided which of the candidates should win
Element
A core component of a module or injector.
Elements
Exposes elements of a module so they can be inspected, validated or rewritten.
ElementVisitor<V>
Visit elements.
EmptyClusterInfoService
ClusterInfoService that provides empty maps for disk usage and shard sizes
EmptyTransportResponseHandler  
EnableAllocationDecider
EnableAllocationDecider.Allocation
Allocation values or rather their string representation to be used used with EnableAllocationDecider.CLUSTER_ROUTING_ALLOCATION_ENABLE_SETTING / EnableAllocationDecider.INDEX_ROUTING_ALLOCATION_ENABLE_SETTING via cluster / index settings.
EnableAllocationDecider.Rebalance
Rebalance values or rather their string representation to be used used with EnableAllocationDecider.CLUSTER_ROUTING_REBALANCE_ENABLE_SETTING / EnableAllocationDecider.INDEX_ROUTING_REBALANCE_ENABLE_SETTING via cluster / index settings.
EnableAssignmentDecider
EnableAssignmentDecider is used to allow/disallow the persistent tasks to be assigned to cluster nodes.
EnableAssignmentDecider.Allocation
Allocation values or rather their string representation to be used used with EnableAssignmentDecider.CLUSTER_TASKS_ALLOCATION_ENABLE_SETTING via cluster settings.
EnabledAttributeMapper  
Engine  
Engine.CommitId  
Engine.Delete  
Engine.DeleteResult  
Engine.EventListener  
Engine.Get  
Engine.GetResult  
Engine.HistorySource
Whether we should read history operations from translog or Lucene index
Engine.Index  
Engine.IndexCommitRef  
Engine.IndexResult  
Engine.IndexThrottle
A throttling class that can be activated, causing the acquireThrottle method to block on a lock when throttling is enabled
Engine.NoOp  
Engine.NoOpLock
A Lock implementation that always allows the lock to be acquired
Engine.NoOpResult  
Engine.Operation  
Engine.Operation.Origin  
Engine.Operation.TYPE
type of operation (index, delete), subclasses use static types
Engine.Result
Base class for index and delete operation results Holds result meta data (e.g.
Engine.Result.Type  
Engine.Searcher  
Engine.SearcherScope  
Engine.SyncedFlushResult  
Engine.TranslogRecoveryRunner  
Engine.Warmer
Called for each new opened engine reader to warm new segments
EngineConfig  
EngineConfig.TombstoneDocSupplier
A supplier supplies tombstone documents which will be used in soft-update methods.
EngineCreationFailureException
An exception indicating that an Engine creation failed.
EngineException  
EngineFactory
Simple Engine Factory
EnginePlugin
A plugin that provides alternative engine implementations.
EnvelopeBuilder  
Environment
The environment of where things exists.
EnvironmentAwareCommand
A cli command which requires an Environment to use current paths and settings.
ErrorHandler
Handles errors in the Injector.
Errors
A collection of error messages.
ErrorsException
Indicates that a result could not be returned while preparing or resolving a binding.
EsAbortPolicy  
EsExecutors  
ESJsonLayout
Formats log events as strings in a json format.
ESJsonLayout.Builder<B extends ESJsonLayout.Builder<B>>  
ESLogMessage
A base class for custom log4j logger messages.
ESMessageFieldConverter
Pattern converter to populate ESMessageField in a pattern.
EsRejectedExecutionException  
EsThreadPoolExecutor
An extension to thread pool executor, allowing (in the future) to add specific additional stats to it.
EsThreadPoolExecutor.ShutdownListener  
ESToParentBlockJoinQuery
A ToParentBlockJoinQuery that allows to retrieve its nested path.
EvictingQueue<T>
An EvictingQueue is a non-blocking queue which is limited to a maximum size; when new elements are added to a full queue, elements are evicted from the head of the queue to accommodate the new elements.
EwmaModel
Calculate a exponentially weighted moving average
EwmaModel.EWMAModelBuilder  
ExceptionsHelper  
ExecutorBuilder<U extends org.elasticsearch.threadpool.ExecutorBuilder.ExecutorSettings>
Base class for executor builders.
ExistsQueryBuilder
Constructs a query that only match on documents that the field has a value in them.
ExplainableScoreScript
To be implemented by ScoreScript which can provided an Explanation of the score This is currently not used inside elasticsearch but it is used, see for example here: https://github.com/elastic/elasticsearch/issues/8561
ExplainAction
Entry point for the explain feature.
ExplainPhase
Explains the scoring calculations for the top hits.
ExplainRequest
Explain request encapsulating the explain query and document identifier to get an explanation for.
ExplainRequestBuilder
A builder for ExplainRequest.
ExplainResponse
Response containing the score explanation.
Explicit<T>
Holds a value that is either: a) set implicitly e.g.
ExponentialDecayFunctionBuilder  
ExponentiallyWeightedMovingAverage
Implements exponentially weighted moving averages (commonly abbreviated EWMA) for a single value.
Exposed
Accompanies a @Provides method annotation in a private module to indicate that the provided binding is exposed.
ExposedBinding<T>
A binding to a key exposed from an enclosed private environment.
ExposedBindingImpl<T>  
ExposureBuilder<T>
For private binder's expose() method.
ExtendedBounds  
ExtendedCommonTermsQuery Deprecated.
Since max_optimization optimization landed in 7.0, normal MatchQuery will achieve the same result without any configuration.
ExtendedStats
Statistics over a set of values (either aggregated over field data or scripts)
ExtendedStats.Bounds  
ExtendedStatsAggregationBuilder  
ExtendedStatsBucket
Extended Statistics over a set of buckets
ExtendedStatsBucketParser  
ExtendedStatsBucketPipelineAggregationBuilder  
ExtendedStatsBucketPipelineAggregator  
ExtensiblePlugin
An extension point for Plugin implementations to be themselves extensible.
FactoryProvider<F>
Provides a factory that combines the caller's arguments with injector-supplied values to construct objects.
FailableCache<K,​V>
Lazily creates (and caches) values for keys.
FailedNodeException  
FailedShard
A class representing a failed shard.
FailedToCommitClusterStateException
Thrown when failing to publish a cluster state.
FastVectorHighlighter  
FaultDetection
A base class for MasterFaultDetection & NodesFaultDetection, making sure both use the same setting.
FetchDocValuesContext
All the required context to pull a field from the doc values.
FetchDocValuesContext.FieldAndFormat
Wrapper around a field name and the format that should be used to display values of this field.
FetchDocValuesPhase
Fetch sub phase which pulls data from doc values.
FetchPhase
Fetch phase of a search request, used to fetch the actual top matching documents to be returned to the client, identified after reducing all of the matches returned by the query phase
FetchPhaseExecutionException  
FetchScorePhase  
FetchSearchResult  
FetchSourceContext
Context used to fetch the _source.
FetchSourcePhase  
FetchSubPhase
Sub phase within the fetch phase used to fetch things *about* the documents like highlighting or matched queries.
FetchSubPhase.HitContext  
FetchVersionPhase  
FieldAliasMapper
A mapper for field aliases.
FieldAliasMapper.Builder  
FieldAliasMapper.Names  
FieldAliasMapper.TypeParser  
FieldCapabilities
Describes the capabilities of a field optionally merged across multiple indices.
FieldCapabilitiesAction  
FieldCapabilitiesIndexRequest  
FieldCapabilitiesIndexResponse
Response for FieldCapabilitiesIndexRequest requests.
FieldCapabilitiesRequest  
FieldCapabilitiesRequestBuilder  
FieldCapabilitiesResponse
Response for FieldCapabilitiesRequest requests.
FieldContext
Used by all field data based aggregators.
FieldData
Utility methods, similar to Lucene's DocValues.
FieldDataStats  
FieldLookup  
FieldMapper  
FieldMapper.Builder<T extends FieldMapper.Builder,​Y extends FieldMapper>  
FieldMapper.CopyTo
Represents a list of fields with optional boost factor where the current field should be copied to
FieldMapper.CopyTo.Builder  
FieldMapper.MultiFields  
FieldMapper.MultiFields.Builder  
FieldMaskingSpanQueryBuilder  
FieldMemoryStats
A reusable class to encode field -&gt; memory size mappings
FieldNameAnalyzer  
FieldNamesFieldMapper
A mapper that indexes the field names of a document under _field_names.
FieldNamesFieldMapper.Defaults  
FieldNamesFieldMapper.FieldNamesFieldType  
FieldNamesFieldMapper.TypeParser  
FieldScript
A script to produce dynamic values for return fields.
FieldScript.Factory  
FieldScript.LeafFactory
A factory to construct FieldScript instances.
FieldsLookup  
FieldSortBuilder
A sort builder to sort based on a document field.
FieldsVisitor
Base StoredFieldVisitor that retrieves all non-redundant metadata.
FieldValueFactorFunction
A function_score function that multiplies the score with the value of a field from the document, optionally multiplying the field by a factor first, and applying a modification (log, ln, sqrt, square, etc) afterwards.
FieldValueFactorFunction.Modifier
The Type class encapsulates the modification types that can be applied to the score/value product.
FieldValueFactorFunctionBuilder
Builder to construct field_value_factor functions for a function score query.
FileBasedSeedHostsProvider
An implementation of SeedHostsProvider that reads hosts/ports from FileBasedSeedHostsProvider.UNICAST_HOSTS_FILE.
FileChangesListener
Callback interface that file changes File Watcher is using to notify listeners about changes.
FilePermissionUtils  
FileRestoreContext
This context will execute a file restore of the lucene files.
FileSystemUtils
Elasticsearch utils to work with Path
FileWatcher
File resources watcher The file watcher checks directory and all its subdirectories for file changes and notifies its listeners accordingly
Filter
A filter aggregation.
FilterableTermsEnum
A frequency TermsEnum that returns frequencies derived from a collection of cached leaf termEnums.
FilterAggregationBuilder  
FilterAggregator
Aggregate all docs that match a filter.
FilterAggregatorFactory  
FilterAllocationDecider
This AllocationDecider control shard allocation by include and exclude filters via dynamic cluster and index routing settings.
FilterClient
A Client that contains another Client which it uses as its basic source, possibly transforming the requests / responses along the way or providing additional functionality.
FilteredCollector  
FilteredSearchContext  
FilterIndexOutput
IndexOutput that delegates all calls to another IndexOutput
FilterRepository  
Filters
A multi bucket aggregation where the buckets are defined by a set of filters (a bucket per filter).
Filters.Bucket
A bucket associated with a specific filter (identified by its key)
FiltersAggregationBuilder  
FiltersAggregator  
FiltersAggregator.KeyedFilter  
FiltersAggregatorFactory  
FilterScript
A script implementation of a query filter.
FilterScript.Factory
A factory to construct stateful FilterScript factories for a specific index.
FilterScript.LeafFactory
A factory to construct FilterScript instances.
FilterStreamInput
Wraps a StreamInput and delegates to it.
FixedExecutorBuilder
A builder for fixed executors.
FloatArray
Abstraction of an array of double values.
FloatValuesComparatorSource
Comparator source for float values.
FlushAction  
FlushFailedEngineException  
FlushRequest
A flush request to flush one or more indices.
FlushRequestBuilder  
FlushResponse
A response to flush action.
FlushStats  
FollowersChecker
The FollowersChecker is responsible for allowing a leader to check that its followers are still connected and healthy.
FollowersChecker.FollowerCheckRequest  
ForceMergeAction  
ForceMergeRequest
A request to force merging the segments of one or more indices.
ForceMergeRequest.Defaults  
ForceMergeRequestBuilder
A request to force merge one or more indices.
ForceMergeResponse
A response for force merge action.
FormatNames  
FragmentBuilderHelper
Simple helper class for FastVectorHighlighter FragmentsBuilder implementations.
FreqTermsEnum
A frequency terms enum that maintains a cache of docFreq, totalTermFreq, or both for repeated term lookup.
FsBlobContainer
A file system based implementation of BlobContainer.
FsBlobStore  
FsDirectoryFactory  
FsInfo  
FsInfo.DeviceStats  
FsInfo.IoStats  
FsInfo.Path  
FsProbe  
FsRepository
Shared file system implementation of the BlobStoreRepository
FsService  
FunctionScoreQuery
A query that allows for a pluggable boost function / filter.
FunctionScoreQuery.FilterScoreFunction  
FunctionScoreQuery.ScoreMode  
FunctionScoreQueryBuilder
A query that uses a filters with a script associated with them to compute the score.
FunctionScoreQueryBuilder.FilterFunctionBuilder
Function to be associated with an optional filter, meaning it will be executed only for the documents that match the given filter.
FutureTransportResponseHandler<T extends TransportResponse>
A response handler to be used when all interaction will be done through the TransportFuture.
FutureUtils  
Fuzziness
A unit class that encapsulates all in-exact search parsing and conversion from similarities to edit distances etc.
FuzzyOptions
Fuzzy options for completion suggester
FuzzyOptions.Builder
Options for fuzzy queries
FuzzyQueryBuilder
A Query that does fuzzy matching for a specific value.
Gateway  
Gateway.GatewayStateRecoveredListener  
GatewayAllocator  
GatewayException  
GatewayMetaState
Loads (and maybe upgrades) cluster metadata at startup, and persistently stores cluster metadata for future restarts.
GatewayModule  
GatewayService  
GaussDecayFunctionBuilder  
GcNames  
GeneralScriptException Deprecated.
Use ScriptException for exceptions from the scripting engine, otherwise use a more appropriate exception (e.g.
GeoBoundingBox
A class representing a Geo-Bounding-Box for use by Geo queries and aggregations that deal with extents/rectangles representing rectangular areas of interest.
GeoBoundingBoxQueryBuilder
Creates a Lucene query that will filter for all documents that lie within the specified bounding box.
GeoBounds
An aggregation that computes a bounding box in which all documents of the current bucket are.
GeoBoundsAggregationBuilder  
GeoCentroid
Interface for GeoCentroidAggregator
GeoCentroidAggregationBuilder  
GeoContextMapping
A ContextMapping that uses a geo location/area as a criteria.
GeoContextMapping.Builder  
GeoDistance
Geo distance calculation.
GeoDistanceAggregationBuilder  
GeoDistanceAggregationBuilder.Range  
GeoDistanceQueryBuilder
Filter results of a query to include only those within a specific distance to some geo point.
GeoDistanceRangeAggregatorFactory  
GeoDistanceSortBuilder
A geo distance based sorting on a geo point like field.
GeoExecType
Specifies how a geo query should be run.
GeoGrid
A geo-grid aggregation.
GeoGrid.Bucket
A bucket that is associated with a geo-grid cell.
GeoGridAggregationBuilder  
GeoGridAggregationBuilder.PrecisionParser  
GeoGridAggregator<T extends InternalGeoGrid>
Aggregates data expressed as longs (for efficiency's sake) but formats results as aggregation-specific strings.
GeoHashGridAggregationBuilder  
GeoHashGridAggregator
Aggregates data expressed as GeoHash longs (for efficiency's sake) but formats results as Geohash strings.
GeoHashGridAggregatorFactory  
GeoJson
Utility class for converting libs/geo shapes to and from GeoJson
GeometryCollectionBuilder  
GeometryFormat
Geometry serializer/deserializer
GeometryIO
Utility class for binary serializtion/deserialization of libs/geo classes
GeometryParser
An utility class with a geometry parser methods supporting different shape representation formats
GeoPoint  
GeoPointFieldMapper
Field Mapper for geo_point types.
GeoPointFieldMapper.Builder  
GeoPointFieldMapper.Defaults  
GeoPointFieldMapper.GeoPointFieldType  
GeoPointFieldMapper.Names  
GeoPointFieldMapper.TypeParser  
GeoPointValues
Per-document geo-point values.
GeoPolygonQueryBuilder  
GeoQueryContext
Defines the query context for GeoContextMapping
GeoQueryContext.Builder  
GeoShapeFieldMapper
FieldMapper for indexing LatLonShapes.
GeoShapeFieldMapper.Builder  
GeoShapeFieldMapper.GeoShapeFieldType  
GeoShapeIndexer
Utility class that converts geometries into Lucene-compatible form
GeoShapeQueryBuilder
Derived AbstractGeometryQueryBuilder that builds a lat, lon GeoShape Query
GeoShapeType
Enumeration that lists all GeoShapeTypes that can be parsed and indexed
GeoTileGridAggregationBuilder  
GeoTileGridAggregator
Aggregates data expressed as geotile longs (for efficiency's sake) but formats results as geotile strings.
GeoTileGridAggregatorFactory  
GeoTileGridValuesSourceBuilder  
GeoTileUtils
Implements geotile key hashing, same as used by many map tile implementations.
GeoUtils  
GeoUtils.EffectivePoint
Represents the point of the geohash cell that should be used as the value of geohash
GeoValidationMethod
This enum is used to determine how to deal with invalid geo coordinates in geo related queries: On STRICT validation invalid coordinates cause an exception to be thrown.
GeoWKTParser
Parses shape geometry represented in WKT format complies with OGC® document: 12-063r5 and ISO/IEC 13249-3:2016 standard located at http://docs.opengeospatial.org/is/12-063r5/12-063r5.html
GetAction  
GetAliasesAction  
GetAliasesRequest  
GetAliasesRequestBuilder  
GetAliasesResponse  
GetFieldMappingsAction  
GetFieldMappingsIndexRequest  
GetFieldMappingsRequest
Request the mappings of specific fields Note: there is a new class with the same name for the Java HLRC that uses a typeless format.
GetFieldMappingsRequestBuilder
A helper class to build GetFieldMappingsRequest objects
GetFieldMappingsResponse
Response object for GetFieldMappingsRequest API Note: there is a new class with the same name for the Java HLRC that uses a typeless format.
GetFieldMappingsResponse.FieldMappingMetaData  
GetIndexAction  
GetIndexRequest
A request to retrieve information about an index.
GetIndexRequest.Feature  
GetIndexRequestBuilder  
GetIndexResponse
A response for a get index action.
GetIndexTemplatesAction  
GetIndexTemplatesRequest
Request that allows to retrieve index templates
GetIndexTemplatesRequestBuilder  
GetIndexTemplatesResponse  
GetMappingsAction  
GetMappingsRequest  
GetMappingsRequestBuilder  
GetMappingsResponse  
GetPipelineAction  
GetPipelineRequest  
GetPipelineRequestBuilder  
GetPipelineResponse  
GetPipelineTransportAction  
GetRepositoriesAction
Get repositories action
GetRepositoriesRequest
Get repository request
GetRepositoriesRequestBuilder
Get repository request builder
GetRepositoriesResponse
Get repositories response
GetRequest
A request to get a document (its source) from an index based on its id.
GetRequestBuilder
A get document action request builder.
GetResponse
The response of a get action.
GetResult  
GetScriptContextAction  
GetScriptContextRequest  
GetScriptContextResponse  
GetScriptLanguageAction  
GetScriptLanguageRequest  
GetScriptLanguageResponse  
GetSettingsAction  
GetSettingsRequest  
GetSettingsRequestBuilder  
GetSettingsResponse  
GetSnapshotsAction
Get snapshots action
GetSnapshotsRequest
Get snapshot request
GetSnapshotsRequestBuilder
Get snapshots request builder
GetSnapshotsResponse
Get snapshots response
GetStats  
GetStoredScriptAction  
GetStoredScriptRequest  
GetStoredScriptRequestBuilder  
GetStoredScriptResponse  
GetTaskAction
ActionType for retrieving a list of currently running tasks
GetTaskRequest
A request to get node tasks
GetTaskRequestBuilder
Builder for the request to retrieve the list of tasks running on the specified nodes
GetTaskResponse
Returns the list of tasks currently running on the nodes
Global
A global aggregation.
GlobalAggregationBuilder  
GlobalAggregator  
GlobalAggregatorFactory  
GlobalCheckpointListeners
Represents a collection of global checkpoint listeners.
GlobalCheckpointListeners.GlobalCheckpointListener
A global checkpoint listener consisting of a callback that is notified when the global checkpoint is updated or the shard is closed.
GlobalCheckpointSyncAction
Background global checkpoint sync action initiated when a shard goes inactive.
GlobalCheckpointSyncAction.Request  
GlobalOrdinalsBuilder
Utility class to build global ordinals.
GlobalOrdinalsIndexFieldData
Concrete implementation of IndexOrdinalsFieldData for global ordinals.
GlobalOrdinalsSignificantTermsAggregator
An global ordinal based implementation of significant terms, based on SignificantStringTermsAggregator.
GlobalOrdinalsStringTermsAggregator
An aggregator of string values that relies on global ordinals in order to build buckets.
GlobalOrdinalsStringTermsAggregator.GlobalOrdLookupFunction  
GND  
GND.GNDBuilder  
GroupedActionListener<T>
An action listener that delegates its results to another listener once it has received N results (either successes or failures).
GroupShardsIterator<ShardIt extends ShardIterator>
This class implements a compilation of ShardIterators.
Guice
The entry point to the Guice framework.
HandledTransportAction<Request extends ActionRequest,​Response extends ActionResponse>
A TransportAction that self registers a handler into the transport service
HandshakingTransportAddressConnector  
HasAggregations  
HasDependencies
Implemented by bindings, providers and instances that expose their dependencies explicitly.
HierarchyCircuitBreakerService
CircuitBreakerService that attempts to redistribute space between breakers if tripped
HighlightBuilder
A builder for search highlighting.
HighlightBuilder.BoundaryScannerType  
HighlightBuilder.Field  
HighlightBuilder.Order  
Highlighter
Highlights a search result.
HighlighterContext  
HighlightField
A field highlighted with its highlighted fragments.
HighlightPhase  
HighlightUtils  
HighlightUtils.Encoders  
Histogram
A histogram aggregation.
Histogram.Bucket
A bucket in the histogram where documents fall in
HistogramAggregationBuilder
A builder for histograms on numeric fields.
HistogramAggregatorFactory
Constructs the per-shard aggregator instance for histogram aggregation.
HistogramFactory
Implemented by histogram aggregations and used by pipeline aggregations to insert buckets.
HistogramValue
Per-document histogram value.
HistogramValues
Per-segment histogram values.
HistogramValuesSourceBuilder
A CompositeValuesSourceBuilder that builds a HistogramValuesSource from another numeric values source using the provided interval.
HoltLinearModel
Calculate a doubly exponential weighted moving average
HoltLinearModel.HoltLinearModelBuilder  
HoltWintersModel
Calculate a triple exponential weighted moving average
HoltWintersModel.HoltWintersModelBuilder  
HoltWintersModel.SeasonalityType  
HotThreads  
HppcMaps  
HppcMaps.Object  
HppcMaps.Object.Integer  
HttpChannel  
HttpChannelTaskHandler
This class executes a request and associates the corresponding Task with the HttpChannel that it was originated from, so that the tasks associated with a certain channel get cancelled when the underlying connection gets closed.
HttpException  
HttpHandlingSettings  
HttpInfo  
HttpPipelinedMessage  
HttpPipelinedRequest<R>  
HttpPipeliningAggregator<Response extends HttpPipelinedMessage,​Listener>  
HttpReadTimeoutException  
HttpRequest
A basic http request abstraction.
HttpRequest.HttpVersion  
HttpResponse
A basic http response abstraction.
HttpServerChannel  
HttpServerTransport  
HttpServerTransport.Dispatcher
Dispatches HTTP requests.
HttpStats  
HttpTransportSettings  
HunspellService
Serves as a node level registry for hunspell dictionaries.
HunspellTokenFilterFactory  
HyperLogLogPlusPlus
Hyperloglog++ counter, implemented based on pseudo code from http://static.googleusercontent.com/media/research.google.com/fr//pubs/archive/40671.pdf and its appendix https://docs.google.com/document/d/1gyjfMHy43U9OWBXxfaeG-3MjGzejW1dlpyMwEYAAWEI/view?fullscreen This implementation is different from the original implementation in that it uses a hash table instead of a sorted list for linear counting.
IdFieldMapper
A mapper for the _id field.
IdFieldMapper.Defaults  
IdFieldMapper.TypeParser  
IdOnlyFieldVisitor  
IdsQueryBuilder
A query that will return only documents matching specific ids (and a type).
IfConfig
Simple class to log ifconfig-style output at DEBUG logging.
IgnoredFieldMapper
A field mapper that records fields that have been ignored because they were malformed.
IgnoredFieldMapper.Builder  
IgnoredFieldMapper.Defaults  
IgnoredFieldMapper.IgnoredFieldType  
IgnoredFieldMapper.TypeParser  
IllegalIndexShardStateException  
IllegalShardRoutingStateException
This exception defines illegal states of shard routing
ImmutableOpenIntMap<VType>
An immutable map implementation based on open hash map.
ImmutableOpenIntMap.Builder<VType>  
ImmutableOpenMap<KType,​VType>
An immutable map implementation based on open hash map.
ImmutableOpenMap.Builder<KType,​VType>  
ImplementedBy
A pointer to the default implementation of a type.
InboundHandler  
InboundMessage  
InboundMessage.Request  
InboundMessage.Response  
IncludeExclude
Defines the include/exclude regular expression filtering for string terms aggregation.
IncludeExclude.Filter  
IncludeExclude.LongFilter  
IncludeExclude.OrdinalsFilter  
IncludeExclude.SetBackedLongFilter  
IncludeExclude.StringFilter  
IncompatibleClusterStateVersionException
Thrown by Diff.apply(T) method
IncrementalClusterStateWriter
Tracks the metadata written to disk, allowing updated metadata to be written incrementally (i.e.
Index
A value class representing the basic required properties of an Elasticsearch index.
IndexAction  
IndexAnalyzers
IndexAnalyzers contains a name to analyzer mapping for a specific index.
IndexCache  
IndexClosedException
Exception indicating that one or more requested indices are closed.
IndexComponent  
IndexCreationException  
IndexEventListener
An index event listener is the primary extension point for plugins and build-in services to react / listen to per-index and per-shard events.
IndexFieldData<FD extends AtomicFieldData>
Thread-safe utility class that allows to get per-segment values via the IndexFieldData.load(LeafReaderContext) method.
IndexFieldData.Builder  
IndexFieldData.Global<FD extends AtomicFieldData>  
IndexFieldData.XFieldComparatorSource  
IndexFieldData.XFieldComparatorSource.Nested
Simple wrapper class around a filter that matches parent documents and a filter that matches child documents.
IndexFieldDataCache
A simple field data cache abstraction on the *index* level.
IndexFieldDataCache.Listener  
IndexFieldDataCache.None  
IndexFieldDataService  
IndexFieldMapper  
IndexFieldMapper.Builder  
IndexFieldMapper.Defaults  
IndexFieldMapper.TypeParser  
IndexGeoPointFieldData
Specialization of IndexFieldData for geo points.
IndexGraveyard
A collection of tombstones for explicitly marking indices as deleted in the cluster state.
IndexGraveyard.Builder
A class to build an IndexGraveyard.
IndexGraveyard.IndexGraveyardDiff
A class representing a diff of two IndexGraveyard objects.
IndexGraveyard.Tombstone
An individual tombstone entry for representing a deleted index.
IndexHistogramFieldData
Specialization of IndexFieldData for histograms.
IndexId
Represents a single snapshotted index in the repository.
IndexingMemoryController  
IndexingOperationListener
An indexing listener for indexing, delete, events.
IndexingOperationListener.CompositeListener
A Composite listener that multiplexes calls to each of the listeners methods.
IndexingSlowLog  
IndexingStats  
IndexingStats.Stats  
IndexMetaData  
IndexMetaData.Builder  
IndexMetaData.State  
IndexMetaDataUpdater
Observer that tracks changes made to RoutingNodes in order to update the primary terms and in-sync allocation ids in IndexMetaData once the allocation round has completed.
IndexModule
IndexModule represents the central extension point for index level custom implementations like: Similarity - New Similarity implementations can be registered through IndexModule.addSimilarity(String, TriFunction) while existing Providers can be referenced through Settings under the IndexModule.SIMILARITY_SETTINGS_PREFIX prefix along with the "type" value.
IndexModule.Type  
IndexNameExpressionResolver  
IndexNameExpressionResolver.Context  
IndexNameExpressionResolver.DateMathExpressionResolver  
IndexNotFoundException  
IndexNumericFieldData  
IndexNumericFieldData.NumericType  
IndexOrdinalsFieldData
Specialization of IndexFieldData for data that is indexed with ordinals.
IndexOutputOutputStream
OutputStream that writes into underlying IndexOutput
IndexPrimaryShardNotAllocatedException
Thrown when some action cannot be performed because the primary shard of some shard group in an index has not been allocated post api action.
IndexQueryCache
The index-level query cache.
IndexRequest
Index request to index a typed JSON document into a specific index and make it searchable.
IndexRequestBuilder
An index document action request builder.
IndexResponse
A response of an index operation,
IndexResponse.Builder
Builder class for IndexResponse.
IndexRoutingTable
The IndexRoutingTable represents routing information for a single index.
IndexRoutingTable.Builder  
IndexScopedSettings
Encapsulates all valid index level settings.
IndexSegments  
IndexService  
IndexService.IndexCreationContext  
IndexService.ShardStoreDeleter  
IndexSettings
This class encapsulates all index level settings and handles settings updates.
IndexShard  
IndexShard.ShardFailure
Simple struct encapsulating a shard failure
IndexShardClosedException  
IndexShardComponent  
IndexShardNotRecoveringException  
IndexShardNotStartedException  
IndexShardRecoveringException  
IndexShardRecoveryException  
IndexShardRelocatedException  
IndexShardRestoreException
Generic shard restore exception
IndexShardRestoreFailedException
Thrown when restore of a shard fails
IndexShardRoutingTable
IndexShardRoutingTable encapsulates all instances of a single shard.
IndexShardRoutingTable.Builder  
IndexShardSegments  
IndexShardSnapshotException
Generic shard snapshot exception
IndexShardSnapshotFailedException
Thrown when snapshot process is failed on a shard level
IndexShardSnapshotStatus
Represent shard snapshot status
IndexShardSnapshotStatus.Copy
Returns an immutable state of IndexShardSnapshotStatus at a given point in time.
IndexShardSnapshotStatus.Stage
Snapshot stage
IndexShardStartedException  
IndexShardState  
IndexShardStats  
IndexShardUpgradeStatus  
IndexSortConfig
Holds all the information that is used to build the sort order of an index.
IndexStats  
IndexStats.IndexStatsBuilder  
IndexStorePlugin
A plugin that provides alternative directory implementations.
IndexStorePlugin.DirectoryFactory
An interface that describes how to create a new directory instance per shard.
IndexTemplateMetaData  
IndexTemplateMetaData.Builder  
IndexTemplateMissingException  
IndexUpgradeStatus  
IndexWarmer  
IndexWarmer.Listener  
IndexWarmer.TerminationHandle
A handle on the execution of warm-up action.
IndicesAdminClient
Administrative actions/operations against indices.
IndicesAliasesAction  
IndicesAliasesClusterStateUpdateRequest
Cluster state update request that allows to add or remove aliases
IndicesAliasesRequest
A request to add/remove aliases for one or more indices.
IndicesAliasesRequest.AliasActions
Request to take one or more actions on one or more indexes and alias combinations.
IndicesAliasesRequest.AliasActions.Type  
IndicesAliasesRequestBuilder
Builder for request to modify many aliases at once.
IndicesClusterStateService  
IndicesClusterStateService.AllocatedIndex<T extends IndicesClusterStateService.Shard>  
IndicesClusterStateService.AllocatedIndices<T extends IndicesClusterStateService.Shard,​U extends IndicesClusterStateService.AllocatedIndex<T>>  
IndicesClusterStateService.AllocatedIndices.IndexRemovalReason  
IndicesClusterStateService.Shard  
IndicesClusterStateUpdateRequest<T extends IndicesClusterStateUpdateRequest<T>>
Base cluster state update request that allows to execute update against multiple indices
IndicesExistsAction  
IndicesExistsRequest  
IndicesExistsRequestBuilder  
IndicesExistsResponse  
IndicesFieldDataCache  
IndicesFieldDataCache.FieldDataWeigher  
IndicesFieldDataCache.Key  
IndicesModule
Configures classes and services that are shared by indices on each node.
IndicesOptions
Controls how to deal with unavailable concrete indices (closed or missing), how wildcard expressions are expanded to actual indices (all, closed or open indices) and how to deal with wildcard expressions that resolve to no indices.
IndicesOptions.Option  
IndicesOptions.WildcardStates  
IndicesQueryCache  
IndicesRequest
Needs to be implemented by all ActionRequest subclasses that relate to one or more indices.
IndicesRequest.Replaceable  
IndicesRequestCache
The indices request cache allows to cache a shard level request stage responses, helping with improving similar requests that are potentially expensive (because of aggs for example).
IndicesSegmentResponse  
IndicesSegmentsAction  
IndicesSegmentsRequest  
IndicesSegmentsRequestBuilder  
IndicesService  
IndicesService.ShardDeletionCheckResult
IndicesShardStoreRequestBuilder
Request builder for IndicesShardStoresRequest
IndicesShardStoresAction
ActionType for TransportIndicesShardStoresAction Exposes shard store information for requested indices.
IndicesShardStoresRequest
IndicesShardStoresResponse
Response for IndicesShardStoresAction Consists of IndicesShardStoresResponse.StoreStatuss for requested indices grouped by indices and shard ids and a list of encountered node IndicesShardStoresResponse.Failures
IndicesShardStoresResponse.Failure
Single node failure while retrieving shard store information
IndicesShardStoresResponse.StoreStatus
Shard store information from a node
IndicesShardStoresResponse.StoreStatus.AllocationStatus
The status of the shard store with respect to the cluster
IndicesStatsAction  
IndicesStatsRequest
A request to get indices level stats.
IndicesStatsRequestBuilder
A request to get indices level stats.
IndicesStatsResponse  
IndicesStore  
InetAddresses  
IngestActionForwarder
A utility for forwarding ingest requests to ingest nodes in a round-robin fashion.
IngestConditionalScript
A script used by ConditionalProcessor.
IngestConditionalScript.Factory  
IngestDocument
Represents a single document being captured before indexing and holds the source and metadata (like id, type and index).
IngestDocument.MetaData  
IngestInfo  
IngestMetadata
Holds the ingest pipelines that are available in the cluster
IngestPlugin
An extension point for Plugin implementations to add custom ingest processors
IngestProcessorException
A dedicated wrapper for exceptions encountered executing an ingest processor.
IngestScript
A script used by the Ingest Script Processor.
IngestScript.Factory  
IngestService
Holder class for several ingest related services.
IngestStats  
IngestStats.PipelineStat
Container for pipeline stats.
IngestStats.ProcessorStat
Container for processor stats.
IngestStats.Stats  
Inject
Annotates members of your implementation class (constructors, methods and fields) into which the Injector should inject values.
InjectionListener<I>
Listens for injections into instances of type I.
InjectionPoint
A constructor, field or method that can receive injections.
InjectionRequest<T>
A request to inject the instance fields and methods of an instance.
Injector
Builds the graphs of objects that make up your application.
InMemoryPersistedState  
InnerHitBuilder  
InnerHitContextBuilder
InnerHitsContext
Context used for inner hits retrieval
InnerHitsContext.InnerHitSubContext
A SubSearchContext that associates TopDocs to each SearchHit in the parent search context
InnerHitsPhase  
InputStreamIndexInput  
InputStreamStreamInput  
InstanceBinding<T>
A binding to a single instance.
InstanceBindingImpl<T>  
InstanceShardOperationRequest<Request extends InstanceShardOperationRequest<Request>>  
InstanceShardOperationRequestBuilder<Request extends InstanceShardOperationRequest<Request>,​Response extends ActionResponse,​RequestBuilder extends InstanceShardOperationRequestBuilder<Request,​Response,​RequestBuilder>>  
IntArray
Abstraction of an array of integer values.
InternalAdjacencyMatrix  
InternalAdjacencyMatrix.InternalBucket  
InternalAggregation
An internal implementation of Aggregation.
InternalAggregation.ReduceContext  
InternalAggregationProfileTree  
InternalAggregations
An internal implementation of Aggregations.
InternalAutoDateHistogram
Implementation of Histogram.
InternalAutoDateHistogram.Bucket  
InternalAvg  
InternalBinaryRange
A range aggregation for data that is encoded in doc values using a binary representation.
InternalBinaryRange.Bucket  
InternalBucketMetricValue  
InternalCardinality  
InternalClusterInfoService
InternalClusterInfoService provides the ClusterInfoService interface, routinely updated on a timer.
InternalComposite  
InternalComposite.InternalBucket  
InternalContext
Internal context.
InternalDateHistogram
Implementation of Histogram.
InternalDateHistogram.Bucket  
InternalDateRange  
InternalDateRange.Bucket  
InternalDateRange.Factory  
InternalDerivative  
InternalEngine  
InternalEngine.DeletionStrategy  
InternalEngine.IndexingStrategy  
InternalEngineFactory  
InternalExtendedStats  
InternalExtendedStatsBucket  
InternalFactory<T>
Creates objects which will be injected.
InternalFactory.Instance<T>
ES: An factory that returns a pre created instance.
InternalFilter  
InternalFilters  
InternalFilters.InternalBucket  
InternalGeoBounds  
InternalGeoCentroid
Serialization and merge logic for GeoCentroidAggregator.
InternalGeoDistance  
InternalGeoDistance.Factory  
InternalGeoGrid<B extends InternalGeoGridBucket>
Represents a grid of cells where each cell's location is determined by a specific geo hashing algorithm.
InternalGeoGridBucket<B extends InternalGeoGridBucket>  
InternalGeoHashGrid
Represents a grid of cells where each cell's location is determined by a geohash.
InternalGeoHashGridBucket  
InternalGeoTileGrid
Represents a grid of cells where each cell's location is determined by a geohash.
InternalGeoTileGridBucket  
InternalGlobal
A global scope get (the document set on which we aggregate is all documents in the search context (ie.
InternalHDRPercentileRanks  
InternalHDRPercentileRanks.Iter  
InternalHDRPercentiles  
InternalHDRPercentiles.Iter  
InternalHistogram
Implementation of Histogram.
InternalHistogram.Bucket  
InternalMappedRareTerms<A extends InternalRareTerms<A,​B>,​B extends InternalRareTerms.Bucket<B>>  
InternalMappedSignificantTerms<A extends InternalMappedSignificantTerms<A,​B>,​B extends InternalSignificantTerms.Bucket<B>>  
InternalMappedTerms<A extends InternalTerms<A,​B>,​B extends InternalTerms.Bucket<B>>
Common superclass for results of the terms aggregation on mapped fields.
InternalMax  
InternalMedianAbsoluteDeviation  
InternalMin  
InternalMissing  
InternalMultiBucketAggregation<A extends InternalMultiBucketAggregation,​B extends InternalMultiBucketAggregation.InternalBucket>  
InternalMultiBucketAggregation.InternalBucket  
InternalNested
Result of the NestedAggregator.
InternalNumericMetricsAggregation  
InternalNumericMetricsAggregation.MultiValue  
InternalNumericMetricsAggregation.SingleValue  
InternalOrder
Implementations for MultiBucketsAggregation.Bucket ordering strategies.
InternalOrder.Aggregation
MultiBucketsAggregation.Bucket ordering strategy to sort by a sub-aggregation.
InternalOrder.CompoundOrder
MultiBucketsAggregation.Bucket ordering strategy to sort by multiple criteria.
InternalOrder.Parser
Contains logic for parsing a BucketOrder from a XContentParser.
InternalOrder.Streams
Contains logic for reading/writing BucketOrder from/to streams.
InternalPercentilesBucket  
InternalPercentilesBucket.Iter  
InternalProfileCollector
This class wraps a Lucene Collector and times the execution of: - setScorer() - collect() - doSetNextReader() - needsScores() InternalProfiler facilitates the linking of the Collector graph
InternalRange<B extends InternalRange.Bucket,​R extends InternalRange<B,​R>>  
InternalRange.Bucket  
InternalRange.Factory<B extends InternalRange.Bucket,​R extends InternalRange<B,​R>>  
InternalRareTerms<A extends InternalRareTerms<A,​B>,​B extends InternalRareTerms.Bucket<B>>  
InternalRareTerms.Bucket<B extends InternalRareTerms.Bucket<B>>  
InternalRareTerms.Bucket.Reader<B extends InternalRareTerms.Bucket<B>>
Reads a bucket.
InternalReverseNested
InternalSampler  
InternalScriptedMetric  
InternalScrollSearchRequest  
InternalSearchResponse
SearchResponseSections subclass that can be serialized over the wire.
InternalSettingsPreparer  
InternalSignificantTerms<A extends InternalSignificantTerms<A,​B>,​B extends InternalSignificantTerms.Bucket<B>>
Result of the significant terms aggregation.
InternalSignificantTerms.Bucket<B extends InternalSignificantTerms.Bucket<B>>  
InternalSignificantTerms.Bucket.Reader<B extends InternalSignificantTerms.Bucket<B>>
Reads a bucket.
InternalSimpleValue  
InternalSingleBucketAggregation
A base class for all the single bucket aggregations.
InternalStats  
InternalStatsBucket  
InternalSum  
InternalTDigestPercentileRanks  
InternalTDigestPercentileRanks.Iter  
InternalTDigestPercentiles  
InternalTDigestPercentiles.Iter  
InternalTerms<A extends InternalTerms<A,​B>,​B extends InternalTerms.Bucket<B>>  
InternalTerms.Bucket<B extends InternalTerms.Bucket<B>>  
InternalTerms.Bucket.Reader<B extends InternalTerms.Bucket<B>>
Reads a bucket.
InternalTopHits
Results of the TopHitsAggregator.
InternalValueCount
An internal implementation of ValueCount.
InternalWeightedAvg  
IntervalBuilder
Constructs an IntervalsSource based on analyzed text
IntervalFilterScript
Base class for scripts used as interval filters, see IntervalsSourceProvider.IntervalFilter
IntervalFilterScript.Factory  
IntervalFilterScript.Interval  
IntervalQueryBuilder
Builder for IntervalQuery
IntervalsSourceProvider
Factory class for IntervalsSource Built-in sources include IntervalsSourceProvider.Match, which analyzes a text string and converts it to a proximity source (phrase, ordered or unordered depending on how strict the matching should be); IntervalsSourceProvider.Combine, which allows proximity queries between different sub-sources; and IntervalsSourceProvider.Disjunction.
IntervalsSourceProvider.Combine  
IntervalsSourceProvider.Disjunction  
IntervalsSourceProvider.Fuzzy  
IntervalsSourceProvider.IntervalFilter  
IntervalsSourceProvider.Match  
IntervalsSourceProvider.Prefix  
IntervalsSourceProvider.Wildcard  
InvalidAggregationPathException  
InvalidAliasNameException  
InvalidIndexNameException  
InvalidIndexTemplateException  
InvalidSnapshotNameException
Thrown on the attempt to create a snapshot with invalid name
InvalidTypeNameException  
IpFieldMapper
A FieldMapper for ip addresses.
IpFieldMapper.Builder  
IpFieldMapper.Defaults  
IpFieldMapper.IpFieldType  
IpFieldMapper.IpFieldType.IpScriptDocValues  
IpFieldMapper.TypeParser  
IpRangeAggregationBuilder  
IpRangeAggregationBuilder.Range  
IsoCalendarDataProvider  
Iterables  
Iterators  
JavaDateMathParser
A parser for date/time formatted text with optional date math.
JLHScore  
JLHScore.JLHScoreBuilder  
Joda  
Joda.EpochTimeParser  
Joda.EpochTimePrinter  
JodaCompatibleZonedDateTime
A wrapper around ZonedDateTime that exposes joda methods for backcompat.
JodaDateFormatter  
JodaDateMathParser
A parser for date/time formatted text with optional date math.
JodaDeprecationPatterns  
Join
Triggered by a StartJoinRequest, instances of this class represent join votes, and have a source and target node.
JoinHelper  
JoinHelper.JoinCallback  
JoinRequest  
JoinTaskExecutor  
JoinTaskExecutor.Task  
JsonThrowablePatternConverter
Outputs the Throwable portion of the LoggingEvent as a Json formatted field with array "exception": [ "stacktrace", "lines", "as", "array", "elements" ] Reusing @link org.apache.logging.log4j.core.pattern.ExtendedThrowablePatternConverter which already converts a Throwable from LoggingEvent into a multiline string
JvmGcMonitorService  
JvmInfo  
JvmInfo.Mem  
JvmService  
JvmStats  
JvmStats.BufferPool  
JvmStats.Classes  
JvmStats.GarbageCollector  
JvmStats.GarbageCollectors  
JvmStats.Mem  
JvmStats.MemoryPool  
JvmStats.Threads  
Key<T>
Binding key consisting of an injection type and an optional annotation.
KeyComparable<T extends MultiBucketsAggregation.Bucket & KeyComparable<T>>
Defines behavior for comparing bucket keys to imposes a total ordering of buckets of the same type.
KeyedLock<T>
This class manages locks.
KeyStoreCli
A cli tool for managing secrets in the elasticsearch keystore.
KeyStoreWrapper
A disk based container for sensitive settings in Elasticsearch.
KeywordAnalyzerProvider  
KeywordFieldMapper
A field mapper for keywords.
KeywordFieldMapper.Builder  
KeywordFieldMapper.Defaults  
KeywordFieldMapper.KeywordFieldType  
KeywordFieldMapper.TypeParser  
LagDetector
A publication can succeed and complete before all nodes have applied the published state and acknowledged it; however we need every node eventually either to apply the published state (or a later state) or be removed from the cluster.
Laplace
LatchedActionListener<T>
An action listener that allows passing in a CountDownLatch that will be counted down after onResponse or onFailure is called
LazyInitializable<T,​E extends java.lang.Exception>
Encapsulates a CheckedSupplier which is lazily invoked once on the first call to #getOrCompute().
LeaderBulkByScrollTaskState
Tracks the state of sliced subtasks and provides unified status information for a sliced BulkByScrollRequest.
LeaderChecker
The LeaderChecker is responsible for allowing followers to check that the currently elected leader is still connected and healthy.
LeafBucketCollector
Per-leaf bucket collector.
LeafBucketCollectorBase
A LeafBucketCollector that delegates all calls to the sub leaf aggregator and sets the scorer on its source of values if it implements ScorerAware.
LeafDocLookup  
LeafFieldsLookup  
LeafScoreFunction
Per-leaf ScoreFunction.
LeafSearchLookup
Per-segment version of SearchLookup.
LegacyGeoShapeFieldMapper Deprecated.
LegacyGeoShapeFieldMapper.Builder  
LegacyGeoShapeFieldMapper.DeprecatedParameters Deprecated.
LegacyGeoShapeFieldMapper.DeprecatedParameters.Defaults  
LegacyGeoShapeFieldMapper.DeprecatedParameters.Names  
LegacyGeoShapeFieldMapper.DeprecatedParameters.PrefixTrees  
LegacyGeoShapeFieldMapper.GeoShapeFieldType  
LegacyGeoShapeIndexer  
LegacyGeoShapeQueryProcessor  
Lifecycle
Lifecycle state.
Lifecycle.State  
LifecycleComponent  
LifecycleListener  
LinearDecayFunctionBuilder  
LinearInterpolatingScorer  
LinearInterpolation
Linear interpolation smoothing model.
LinearModel
Calculate a linearly weighted moving average, such that older values are linearly less important.
LinearModel.LinearModelBuilder  
LineStringBuilder  
LinkedBindingBuilder<T>
See the EDSL examples at Binder.
LinkedBindingImpl<T>  
LinkedKeyBinding<T>
A binding to a linked key.
LinkedProviderBindingImpl<T>  
ListenableActionFuture<T>
An ActionFuture that listeners can be added to.
ListenableFuture<V>
A future implementation that allows for the result to be passed to listeners waiting for notification.
ListenerTimeouts  
ListTasksAction
ActionType for retrieving a list of currently running tasks
ListTasksRequest
A request to get node tasks
ListTasksRequestBuilder
Builder for the request to retrieve the list of tasks running on the specified nodes
ListTasksResponse
Returns the list of tasks currently running on the nodes
LivenessRequest
Transport level private response for the transport handler registered under "cluster:monitor/nodes/liveness"
LivenessResponse
Transport level private response for the transport handler registered under "cluster:monitor/nodes/liveness"
LocalAllocateDangledIndices  
LocalAllocateDangledIndices.AllocateDangledRequest  
LocalAllocateDangledIndices.AllocateDangledResponse  
LocalCheckpointTracker
This class generates sequences numbers and keeps track of the so-called "local checkpoint" which is the highest number for which all previous sequence numbers have been processed (inclusive).
LocalClusterUpdateTask
Used to apply state updates on nodes that are not necessarily master
LocaleUtils
Utilities for for dealing with Locale objects
LocalNodeMasterListener
Enables listening to master changes events of the local node (when the local node becomes the master, and when the local node cease being a master).
LogConfigurator  
LoggerInfoStream
An InfoStream (for Lucene's IndexWriter) that redirects messages to "lucene.iw.ifd" and "lucene.iw" Logger.trace.
LoggerMessageFormat
Format string for Elasticsearch log messages.
Loggers
A set of utilities around Logging.
LoggingAwareCommand
A command that is aware of logging.
LoggingAwareMultiCommand
A multi-command that is aware of logging.
LoggingDeprecationHandler
Logs deprecations to the DeprecationLogger.
LoggingTaskListener<Response>
A TaskListener that just logs the response at the info level.
LongArray
Abstraction of an array of long values.
LongHash
Specialized hash table implementation similar to BytesRefHash that maps long values to ids.
LongObjectPagedHashMap<T>
A hash table from native longs to objects.
LongObjectPagedHashMap.Cursor<T>  
LongRareTerms
Result of the RareTerms aggregation when the field is some kind of whole number like a integer, long, or a date.
LongRareTerms.Bucket  
LongRareTermsAggregator
An aggregator that finds "rare" string values (e.g.
LongTerms
Result of the TermsAggregator when the field is some kind of whole number like a integer, long, or a date.
LongTerms.Bucket  
LongTermsAggregator  
LongValuesComparatorSource
Comparator source for long values.
Lucene  
MacAddressProvider  
MainAction  
MainRequest  
MainRequestBuilder  
MainResponse  
Manifest
This class represents the manifest file, which is the entry point for reading meta data from disk.
MapBinder<K,​V>
An API to bind multiple map entries separately, only to later inject them as a complete map.
MapBinder.RealMapBinder<K,​V>
The actual mapbinder plays several roles:
MapBinder.RealMapBinder.MapBinderProviderWithDependencies<K,​V>  
MapBuilder<K,​V>  
MappedFieldType
This defines the core properties and functions to operate on a field.
MappedFieldType.Relation
An enum used to describe the relation between the range of terms in a shard when compared with a query range
Mapper  
Mapper.Builder<T extends Mapper.Builder,​Y extends Mapper>  
Mapper.BuilderContext  
Mapper.TypeParser  
Mapper.TypeParser.ParserContext  
MapperException  
MapperParsingException  
MapperPlugin
An extension point for Plugin implementations to add custom mappers
MapperRegistry
A registry for all field mappers.
MapperService  
MapperService.MergeReason
The reason why a mapping is being merged.
Mapping
Wrapper around everything that defines a mapping, without references to utility classes like MapperService, ...
MappingMetaData
Mapping configuration for a type.
MappingMetaData.Routing  
MappingUpdatedAction
Called by shards in the cluster when their mapping was dynamically updated and it needs to be updated in the cluster state meta data (and broadcast to all members).
MappingUpdatePerformer  
Maps  
MasterFaultDetection
A fault detection that pings the master periodically to see if its alive.
MasterFaultDetection.Listener  
MasterFaultDetection.MasterPingRequest  
MasterFaultDetection.MasterPingResponseResponse  
MasterFaultDetection.ThisIsNotTheMasterYouAreLookingForException
Thrown when a ping reaches the wrong node
MasterNodeChangePredicate  
MasterNodeOperationRequestBuilder<Request extends MasterNodeRequest<Request>,​Response extends ActionResponse,​RequestBuilder extends MasterNodeOperationRequestBuilder<Request,​Response,​RequestBuilder>>
Base request builder for master node operations
MasterNodeReadOperationRequestBuilder<Request extends MasterNodeReadRequest<Request>,​Response extends ActionResponse,​RequestBuilder extends MasterNodeReadOperationRequestBuilder<Request,​Response,​RequestBuilder>>
Base request builder for master node read operations that can be executed on the local node as well
MasterNodeReadRequest<Request extends MasterNodeReadRequest<Request>>
Base request for master based read operations that allows to read the cluster state from the local node if needed
MasterNodeRequest<Request extends MasterNodeRequest<Request>>
A based request for master based operation.
MasterNotDiscoveredException  
MasterService  
MatchAllQueryBuilder
A query that matches on all documents.
MatchBoolPrefixQueryBuilder
The boolean prefix query analyzes the input text and creates a boolean query containing a Term query for each term, except for the last term, which is used to create a prefix query
MatchedQueriesPhase  
Matcher<T>
Returns true or false for a given input.
MatcherAndConverter  
Matchers
Matcher implementations.
MatchNoneQueryBuilder
A query that matches no document.
MatchPhrasePrefixQueryBuilder
Match query is a query that analyzes the text and constructs a phrase prefix query as the result of the analysis.
MatchPhraseQueryBuilder
Match query is a query that analyzes the text and constructs a phrase query as the result of the analysis.
MatchQuery  
MatchQuery.Type  
MatchQuery.ZeroTermsQuery  
MatchQueryBuilder
Match query is a query that analyzes the text and constructs a query as the result of the analysis.
Max
An aggregation that computes the maximum of the values in the current bucket.
MaxAgeCondition
Condition for index maximum age.
MaxAggregationBuilder  
MaxBucketPipelineAggregationBuilder  
MaxBucketPipelineAggregator  
MaxDocsCondition
Condition for maximum index docs.
MaxRetryAllocationDecider
An allocation decider that prevents shards from being allocated on any node if the shards allocation has been retried N times without success.
MaxScoreCollector
A collector that computes the maximum score.
MaxSizeCondition
A size-based condition for an index size.
MeanMetric  
MedianAbsoluteDeviation
An aggregation that approximates the median absolute deviation of a numeric field
MedianAbsoluteDeviationAggregationBuilder  
MedianAbsoluteDeviationAggregator  
MedianAbsoluteDeviationAggregatorFactory  
MembershipAction  
MembershipAction.JoinCallback  
MembershipAction.JoinRequest  
MembershipAction.LeaveRequest  
MembershipAction.MembershipListener  
MembersInjector<T>
Injects dependencies into the fields and methods on instances of type T.
MembersInjectorLookup<T>
A lookup of the members injector for a type.
MemorySizeValue
Utility methods to get memory sizes.
MergableCustomMetaData<T extends MetaData.Custom>
Interface to allow merging MetaData.Custom.
MergePolicyConfig
A shard in elasticsearch is a Lucene index, and a Lucene index is broken down into segments.
MergeSchedulerConfig
The merge scheduler (ConcurrentMergeScheduler) controls the execution of merge operations once they are needed (according to the merge policy).
MergeStats  
MergingBucketsDeferringCollector
A specialization of BestBucketsDeferringCollector that collects all matches and then is able to replay a given subset of buckets.
Message
An error message and the context in which it occurred.
MessageDigests
This MessageDigests class provides convenience methods for obtaining thread local MessageDigest instances for MD5, SHA-1, and SHA-256 message digests.
MetaData  
MetaData.Builder  
MetaData.Custom  
MetaData.XContentContext  
MetaDataCreateIndexService
Service responsible for submitting create index requests
MetaDataDeleteIndexService
Deletes indices.
MetadataFieldMapper
A mapper for a builtin field containing metadata about a document.
MetadataFieldMapper.Builder<T extends MetadataFieldMapper.Builder,​Y extends MetadataFieldMapper>  
MetadataFieldMapper.TypeParser  
MetaDataIndexAliasesService
Service responsible for submitting add and remove aliases requests
MetaDataIndexStateService
Service responsible for submitting open/close index requests
MetaDataIndexTemplateService
Service responsible for submitting index templates updates
MetaDataIndexTemplateService.PutListener  
MetaDataIndexTemplateService.PutRequest  
MetaDataIndexTemplateService.PutResponse  
MetaDataIndexTemplateService.RemoveListener  
MetaDataIndexTemplateService.RemoveRequest  
MetaDataIndexTemplateService.RemoveResponse  
MetaDataIndexUpgradeService
This service is responsible for upgrading legacy index metadata to the current version
MetaDataMappingService
Service responsible for submitting mapping changes
MetaDataStateFormat<T>
MetaDataStateFormat is a base class to write checksummed XContent based files to one or more directories in a standardized directory structure.
MetaDataUpdateSettingsService
Service responsible for submitting update index settings requests
MetaDataUpgrader
Upgrades MetaData on startup on behalf of installed Plugins
MetaStateService
Handles writing and loading Manifest, MetaData and IndexMetaData
Metric  
MetricInspectionHelper
Counterpart to AggregationInspectionHelper, providing helpers for some aggs that have package-private getters.
MetricsAggregator  
Min
An aggregation that computes the minimum of the values in the current bucket.
MinAggregationBuilder  
MinAndMax<T extends java.lang.Comparable<? super T>>
A class that encapsulates a minimum and a maximum Comparable.
MinBucketPipelineAggregationBuilder  
MinBucketPipelineAggregator  
MinDocQuery
A Query that only matches documents that are greater than or equal to a configured doc ID.
MinimumScoreCollector  
Missing
A missing aggregation.
MissingAggregationBuilder  
MissingAggregator  
MissingAggregatorFactory  
MissingHistoryOperationsException
Exception indicating that not all requested operations from LuceneChangesSnapshot are available.
MissingValues
Utility class that allows to return views of ValuesSources that replace the missing value with a configured value.
Module
A module contributes configuration information, typically interface bindings, which will be used to create an Injector.
Modules
Static utility methods for creating and working with instances of Module.
Modules.OverriddenModuleBuilder
See the EDSL example at override().
ModulesBuilder  
MonitorService  
MoreLikeThisQuery  
MoreLikeThisQueryBuilder
A more like this query that finds documents that are "like" the provided set of document(s).
MoreLikeThisQueryBuilder.Item
A single item to be used for a MoreLikeThisQueryBuilder.
MoreTypes
Static methods for working with types that we aren't publishing in the public Types API.
MoreTypes.GenericArrayTypeImpl  
MoreTypes.MemberImpl
We cannot serialize the built-in Java member classes, which prevents us from using Members in our exception types.
MoreTypes.ParameterizedTypeImpl  
MoreTypes.WildcardTypeImpl
The WildcardType interface supports multiple upper bounds and multiple lower bounds.
MovAvgModel  
MovAvgModel.AbstractModelParser
Abstract class which also provides some concrete parsing functionality.
MovAvgModelBuilder
Represents the common interface that all moving average models share.
MovAvgPipelineAggregationBuilder  
MovAvgPipelineAggregator  
MoveAllocationCommand
A command that moves a shard from a specific node to another node.
Note: The shard needs to be in the state ShardRoutingState.STARTED in order to be moved.
MoveDecision
Represents a decision to move a started shard, either because it is no longer allowed to remain on its current node or because moving it to another node will form a better cluster balance.
MovFnPipelineAggregationBuilder  
MovFnPipelineAggregator
This pipeline aggregation gives the user the ability to script functions that "move" across a window of data, instead of single data points.
MovingFunctions
Provides a collection of static utility methods that can be referenced from MovingFunction script contexts
MovingFunctionScript
This class provides a custom script context for the Moving Function pipeline aggregation, so that we can expose a number of pre-baked moving functions like min, max, movavg, etc
MovingFunctionScript.Factory  
Multibinder<T>
An API to bind multiple values separately, only to later inject them as a complete collection.
Multibinder.RealMultibinder<T>
The actual multibinder plays several roles:
MultiBucketAggregationBuilder
Marker interface to indicate that the AggregationBuilder is for a multi-bucket aggregation.
MultiBucketCollector
A BucketCollector which allows running a bucket collection with several BucketCollectors.
MultiBucketConsumerService
An aggregation service that creates instances of MultiBucketConsumerService.MultiBucketConsumer.
MultiBucketConsumerService.MultiBucketConsumer
An IntConsumer that throws a MultiBucketConsumerService.TooManyBucketsException when the sum of the provided values is above the limit (`search.max_buckets`).
MultiBucketConsumerService.TooManyBucketsException  
MultiBucketsAggregation
An aggregation that returns multiple buckets
MultiBucketsAggregation.Bucket
A bucket represents a criteria to which all documents that fall in it adhere to.
MultiCandidateGeneratorWrapper  
MultiFileTransfer<Request extends MultiFileTransfer.ChunkRequest>
File chunks are sent/requested sequentially by at most one thread at any time.
MultiFileTransfer.ChunkRequest  
MultiFileWriter  
MultiGeoPointValues
A stateful lightweight per document set of GeoPoint values.
MultiGetAction  
MultiGetItemResponse
A single multi get response.
MultiGetRequest  
MultiGetRequest.Item
A single get item.
MultiGetRequestBuilder
A multi get document action request builder.
MultiGetResponse  
MultiGetResponse.Failure
Represents a failure.
MultiGetShardRequest  
MultiGetShardResponse  
MultiLineStringBuilder  
MultiMatchQuery  
MultiMatchQueryBuilder
Same as MatchQueryBuilder but supports multiple fields.
MultiMatchQueryBuilder.Type  
MultiOrdinals
Ordinals implementation which is efficient at storing field data ordinals for multi-valued or sparse fields.
MultiPhrasePrefixQuery  
MultiPointBuilder  
MultiPolygonBuilder  
MultiSearchAction  
MultiSearchRequest
A multi search API request.
MultiSearchRequestBuilder
A request builder for multiple search requests.
MultiSearchResponse
A multi search response.
MultiSearchResponse.Item
A search response item, holding the actual search response, or an error message if it failed.
MultiTermQueryBuilder  
MultiTermVectorsAction  
MultiTermVectorsItemResponse
A single multi get response.
MultiTermVectorsRequest  
MultiTermVectorsRequestBuilder  
MultiTermVectorsResponse  
MultiTermVectorsResponse.Failure
Represents a failure.
MultiTermVectorsShardRequest  
MultiTermVectorsShardResponse  
MultiValueMode
Defines what values to pick in the case a document contains multiple values for a particular field.
MultiValuesSource<VS extends ValuesSource>
Class to encapsulate a set of ValuesSource objects labeled by field name
MultiValuesSource.NumericMultiValuesSource  
MultiValuesSourceAggregationBuilder<VS extends ValuesSource,​AB extends MultiValuesSourceAggregationBuilder<VS,​AB>>
Similar to ValuesSourceAggregationBuilder, except it references multiple ValuesSources (e.g.
MultiValuesSourceAggregationBuilder.LeafOnly<VS extends ValuesSource,​AB extends MultiValuesSourceAggregationBuilder<VS,​AB>>  
MultiValuesSourceAggregatorFactory<VS extends ValuesSource>  
MultiValuesSourceFieldConfig  
MultiValuesSourceFieldConfig.Builder  
MultiValuesSourceParseHelper  
Murmur3HashFunction
Hash function based on the Murmur3 algorithm, which is the default as of Elasticsearch 2.0.
MurmurHash3
MurmurHash3 hashing functions.
MurmurHash3.Hash128
A 128-bits hash.
MutualInformation  
MutualInformation.MutualInformationBuilder  
Named
Annotates named things.
NamedAnalyzer
Named analyzer is an analyzer wrapper around an actual analyzer (NamedAnalyzer.analyzer that is associated with a name (NamedAnalyzer.name().
NamedDiff<T extends Diffable<T>>
Diff that also support NamedWriteable interface
NamedDiffable<T>
Diff that also support VersionedNamedWriteable interface
NamedDiffableValueSerializer<T extends NamedDiffable<T>>
Value Serializer for named diffables
NamedRegistry<T>
A registry from String to some class implementation.
NamedWriteable
A Writeable object identified by its name.
NamedWriteableAwareStreamInput
Wraps a StreamInput and associates it with a NamedWriteableRegistry
NamedWriteableRegistry
A registry for Writeable.Reader readers of NamedWriteable.
NamedWriteableRegistry.Entry
An entry in the registry, made up of a category class and name, and a reader for that category class.
NamedXContentProvider
Provides named XContent parsers.
NameOrDefinition  
Names
Utility methods for use with @Named.
Nested
A nested aggregation.
NestedAggregationBuilder  
NestedAggregator  
NestedAggregatorFactory  
NestedHelper
Utility class to filter parent and children clauses when building nested queries.
NestedQueryBuilder  
NestedScope
During query parsing this keeps track of the current nested level.
NestedSortBuilder  
NetworkAddress
Utility functions for presentation of network addresses.
NetworkExceptionHelper  
NetworkMessage
Represents a transport message sent over the network.
NetworkModule
A module to handle registering and binding all network related classes.
NetworkPlugin
Plugin for extending network and transport related classes
NetworkService  
NetworkService.CustomNameResolver
A custom name resolver can support custom lookup keys (my_net_key:ipv4) and also change the default inet address used in case no settings is provided.
NetworkUtils
Utilities for network interfaces / addresses binding and publishing.
NoClassSettingsException
A specific type of SettingsException indicating failure to load a class based on a settings value.
Node
A node represent a node within a cluster (cluster.name).
NodeAllocationResult
This class represents the shard allocation decision and its explanation for a single node.
NodeAllocationResult.ShardStoreInfo
A class that captures metadata about a shard store on a node.
NodeAndClusterIdConverter
Pattern converter to format the node_and_cluster_id variable into JSON fields node.id and cluster.uuid.
NodeAndClusterIdStateListener
The NodeAndClusterIdStateListener listens to cluster state changes and ONLY when receives the first update it sets the clusterUUID and nodeID in log4j pattern converter NodeAndClusterIdConverter.
NodeClient
Client that executes actions on the local node.
NodeClosedException
An exception indicating that node is closed.
NodeConnectionsService
This component is responsible for maintaining connections from this node to all the nodes listed in the cluster state, and for disconnecting from nodes once they are removed from the cluster state.
NodeDisconnectedException  
NodeEnvironment
A component that holds all data paths for a single node.
NodeEnvironment.NodeLock  
NodeEnvironment.NodePath  
NodeEnvironment.ShardLocker
A functional interface that people can use to reference NodeEnvironment.shardLock(ShardId, String, long)
NodeHotThreads  
NodeIndicesStats
Global information on indices stats running on a specific node.
NodeInfo
Node information (static, does not change over time).
NodeJoinController
This class processes incoming join request (passed zia ZenDiscovery).
NodeJoinController.ElectionCallback  
NodeMappingRefreshAction  
NodeMappingRefreshAction.NodeMappingRefreshRequest  
NodeMetaData
Metadata associated with this node: its persistent node ID and its version.
NodeNamePatternConverter
Converts %node_name in log4j patterns into the current node name.
NodeNotConnectedException
An exception indicating that a message is sent to a node that is not connected.
NodePersistentTasksExecutor
This component is responsible for execution of persistent tasks.
NodeRemovalClusterStateTaskExecutor  
NodeRemovalClusterStateTaskExecutor.Task  
NodeRepurposeCommand  
NodeService  
NodesFaultDetection
A fault detection of multiple nodes.
NodesFaultDetection.Listener  
NodesFaultDetection.PingRequest  
NodesFaultDetection.PingResponse  
NodesHotThreadsAction  
NodesHotThreadsRequest  
NodesHotThreadsRequestBuilder  
NodesHotThreadsResponse  
NodeShouldNotConnectException  
NodesInfoAction  
NodesInfoRequest
A request to get node (cluster) level information.
NodesInfoRequestBuilder  
NodesInfoResponse  
NodesOperationRequestBuilder<Request extends BaseNodesRequest<Request>,​Response extends BaseNodesResponse,​RequestBuilder extends NodesOperationRequestBuilder<Request,​Response,​RequestBuilder>>  
NodesReloadSecureSettingsAction  
NodesReloadSecureSettingsRequest
Request for a reload secure settings action.
NodesReloadSecureSettingsRequestBuilder
Builder for the reload secure settings nodes request
NodesReloadSecureSettingsResponse
The response for the reload secure settings action
NodesReloadSecureSettingsResponse.NodeResponse  
NodesStatsAction  
NodesStatsRequest
A request to get node (cluster) level stats.
NodesStatsRequestBuilder  
NodesStatsResponse  
NodeStats
Node statistics (dynamic, changes depending on when created).
NodesUsageAction  
NodesUsageRequest  
NodesUsageRequestBuilder  
NodesUsageResponse
The response for the nodes usage api which contains the individual usage statistics for all nodes queried.
NodeToolCli  
NodeUsage  
NodeValidationException
An exception thrown during node validation.
NodeVersionAllocationDecider
An allocation decider that prevents relocation or allocation from nodes that might not be version compatible.
NoMasterBlockService  
NonCollectingAggregator
An aggregator that is not collected, this can typically be used when running an aggregation over a field that doesn't have a mapping.
NoneCircuitBreakerService
Class that returns a breaker that never breaks
NoneRecycler<T>  
NoneRecycler.NV<T>  
NonNegativeScoresSimilarity
A Similarity that rejects negative scores.
NoNodeAvailableException
An exception indicating no node is available to perform the operation.
NoopCircuitBreaker
A CircuitBreaker that doesn't increment or adjust, and all operations are basically noops
NoOpEngine
NoOpEngine is an engine implementation that does nothing but the bare minimum required in order to have an engine.
NormalizingCharFilterFactory
A CharFilterFactory that also supports normalization The default implementation of NormalizingCharFilterFactory.normalize(Reader) delegates to CharFilterFactory.create(Reader)
NormalizingTokenFilterFactory
A TokenFilterFactory that may be used for normalization The default implementation delegates NormalizingTokenFilterFactory.normalize(TokenStream) to TokenFilterFactory.create(TokenStream)}.
NoShardAvailableActionException  
NoSuchNodeException  
NoSuchRemoteClusterException
An exception that remote cluster is missing or connectivity to the remote connection is failing
NotCompressedException
Exception indicating that we were expecting something compressed, which was not compressed or corrupted so that the compression format could not be detected.
NotifyOnceListener<Response>
A listener that ensures that only one of onResponse or onFailure is called.
NotMasterException
Thrown when a node join request or a master ping reaches a node which is not currently acting as a master or when a cluster state update task is to be executed on a node that is no longer master.
NotSerializableExceptionWrapper
This exception can be used to wrap a given, not serializable exception to serialize via StreamOutput.writeException(Throwable).
NotSerializableTransportException  
NotXContentException
Exception indicating that we were expecting some XContent but could not detect its type.
Nullability
Whether a member supports null values injected.
NumberFieldMapper
A FieldMapper for numeric types: byte, short, int, long, float and double.
NumberFieldMapper.Builder  
NumberFieldMapper.Defaults  
NumberFieldMapper.NumberFieldType  
NumberFieldMapper.NumberType  
NumberFieldMapper.TypeParser  
Numbers
A set of utilities for numbers.
NumberSortScript  
NumberSortScript.Factory
A factory to construct stateful NumberSortScript factories for a specific index.
NumberSortScript.LeafFactory
A factory to construct NumberSortScript instances.
NumericDoubleValues
A per-document numeric value.
NumericMetricsAggregation  
NumericMetricsAggregation.MultiValue  
NumericMetricsAggregation.SingleValue  
NumericMetricsAggregator  
NumericMetricsAggregator.MultiValue  
NumericMetricsAggregator.SingleValue  
NXYSignificanceHeuristic  
NXYSignificanceHeuristic.Frequencies  
NXYSignificanceHeuristic.NXYBuilder  
ObjectArray<T>
Abstraction of an array of object values.
ObjectMapper  
ObjectMapper.Builder<T extends ObjectMapper.Builder,​Y extends ObjectMapper>  
ObjectMapper.Defaults  
ObjectMapper.Dynamic  
ObjectMapper.Nested  
ObjectMapper.TypeParser  
ObjectParserHelper<Value,​Context>
This class provides helpers for ObjectParser that allow dealing with classes outside of the xcontent dependencies.
OneMergeHelper
Allows pkg private access
OnGoingMerge
Represents a single on going merge within an index.
OpenIndexAction  
OpenIndexClusterStateUpdateRequest
Cluster state update request that allows to open one or more indices
OpenIndexClusterStateUpdateResponse
A cluster state update response with specific fields for index opening.
OpenIndexRequest
A request to open an index.
OpenIndexRequestBuilder
Builder for for open index request
OpenIndexResponse
A response for a open index action.
OperationRouting  
Operator  
Ordinals
A thread safe ordinals abstraction.
Ordinals.ValuesHolder  
OrdinalsBuilder
Simple class to build document ID <-> ordinal mapping.
OriginalIndices
Used to keep track of original indices within internal (e.g.
OriginSettingClient
A Client that sends requests with the origin set to a particular value and calls its ActionListener in its original ThreadContext.
OsInfo  
OsProbe
The OsProbe class retrieves information about the physical and swap size of the machine memory, as well as the system load average and cpu load.
OsService  
OsStats  
OsStats.Cgroup
Encapsulates basic cgroup statistics.
OsStats.Cgroup.CpuStat
Encapsulates CPU time statistics.
OsStats.Cpu  
OsStats.Mem  
OsStats.Swap  
OutOfScopeException
Thrown from Provider.get() when an attempt is made to access a scoped object while the scope in question is not currently active.
OutputStreamStreamOutput  
OverrideNodeVersionCommand  
PageCacheRecycler
A recycler of fixed-size pages.
PageCacheRecycler.Type  
PagedBytesAtomicFieldData  
PagedBytesIndexFieldData  
PagedBytesIndexFieldData.Builder  
PagedBytesReference
A page based bytes reference, internally holding the bytes in a paged data structure.
ParentTaskAssigningClient
A Client that sets the parent task on all requests that it makes.
ParseContext  
ParseContext.Document
Fork of Document with additional functionality.
ParseContext.InternalParseContext  
ParsedAdjacencyMatrix  
ParsedAdjacencyMatrix.ParsedBucket  
ParsedAggregation
An implementation of Aggregation that is parsed from a REST response.
ParsedAutoDateHistogram  
ParsedAutoDateHistogram.ParsedBucket  
ParsedAvg  
ParsedBinaryRange  
ParsedBinaryRange.ParsedBucket  
ParsedBucketMetricValue  
ParsedCardinality  
ParsedComposite  
ParsedComposite.ParsedBucket  
ParsedDateHistogram  
ParsedDateHistogram.ParsedBucket  
ParsedDateRange  
ParsedDateRange.ParsedBucket  
ParsedDerivative  
ParsedDocument
The result of parsing a document.
ParsedDoubleTerms  
ParsedDoubleTerms.ParsedBucket  
ParsedExtendedStats  
ParsedExtendedStatsBucket  
ParsedFilter  
ParsedFilters  
ParsedFilters.ParsedBucket  
ParsedGeoBounds  
ParsedGeoCentroid
Serialization and merge logic for GeoCentroidAggregator.
ParsedGeoDistance  
ParsedGeoDistance.ParsedBucket  
ParsedGeoGrid  
ParsedGeoGridBucket  
ParsedGeoHashGrid  
ParsedGeoHashGridBucket  
ParsedGeoTileGrid  
ParsedGeoTileGridBucket  
ParsedGlobal  
ParsedHDRPercentileRanks  
ParsedHDRPercentiles  
ParsedHistogram  
ParsedLongTerms  
ParsedLongTerms.ParsedBucket  
ParsedMax  
ParsedMedianAbsoluteDeviation  
ParsedMin  
ParsedMissing  
ParsedMultiBucketAggregation<B extends MultiBucketsAggregation.Bucket>  
ParsedMultiBucketAggregation.ParsedBucket  
ParsedNested  
ParsedPercentiles  
ParsedPercentilesBucket  
ParsedQuery
The result of parsing a query.
ParsedRange  
ParsedRange.ParsedBucket  
ParsedReverseNested  
ParsedSampler  
ParsedScriptedMetric  
ParsedSignificantLongTerms  
ParsedSignificantLongTerms.ParsedBucket  
ParsedSignificantStringTerms  
ParsedSignificantStringTerms.ParsedBucket  
ParsedSignificantTerms  
ParsedSignificantTerms.ParsedBucket  
ParsedSimpleValue  
ParsedSingleBucketAggregation
A base class for all the single bucket aggregations.
ParsedSingleValueNumericMetricsAggregation  
ParsedStats  
ParsedStatsBucket  
ParsedStringTerms  
ParsedStringTerms.ParsedBucket  
ParsedSum  
ParsedTDigestPercentileRanks  
ParsedTDigestPercentiles  
ParsedTerms  
ParsedTerms.ParsedBucket  
ParsedTopHits  
ParsedValueCount  
ParsedWeightedAvg  
ParseFieldRegistry<T>
Registry for looking things up using ParseField semantics.
ParsingException
Exception that can be used when parsing queries with a given XContentParser.
PathTrie<T>  
PathTrie.Decoder  
PeerFinder  
PeerFinder.ConfiguredHostsResolver  
PeerFinder.TransportAddressConnector  
PeerRecoverySourceService
The source recovery accepts recovery requests from other peer shards and start the recovery process from this source shard to the target shard.
PeerRecoverySourceService.Actions  
PeerRecoveryTargetService
The recovery target handles recoveries of peer shards of the shard+node to recover to.
PeerRecoveryTargetService.Actions  
PeerRecoveryTargetService.RecoveryListener  
PeersRequest  
PeersResponse  
PendingClusterStatesQueue
A queue that holds all "in-flight" incoming cluster states from the master.
PendingClusterStateStats
Class encapsulating stats about the PendingClusterStatsQueue
PendingClusterTask  
PendingClusterTasksAction  
PendingClusterTasksRequest  
PendingClusterTasksRequestBuilder  
PendingClusterTasksResponse  
PercentageScore  
PercentageScore.PercentageScoreBuilder  
Percentile  
PercentileRanks
An aggregation that computes approximate percentiles given values.
PercentileRanksAggregationBuilder  
Percentiles
An aggregation that computes approximate percentiles.
PercentilesAggregationBuilder  
PercentilesBucket  
PercentilesBucketPipelineAggregationBuilder  
PercentilesBucketPipelineAggregator  
PercentilesMethod
An enum representing the methods for calculating percentiles
PerFieldMappingPostingFormatCodec
This postings format is the default PostingsFormat for Elasticsearch.
PersistedClusterStateService
Stores cluster metadata in a bare Lucene index (per data path) split across a number of documents.
PersistedClusterStateService.OnDiskState  
PersistedClusterStateService.Writer  
PersistentTaskParams
Parameters used to start persistent task
PersistentTaskPlugin
Plugin for registering persistent tasks executors.
PersistentTaskResponse
Response upon a successful start or an persistent task
PersistentTasksClusterService
Component that runs only on the master node and is responsible for assigning running tasks to nodes
PersistentTasksCustomMetaData
A cluster state record that contains a list of all running persistent tasks
PersistentTasksCustomMetaData.Assignment  
PersistentTasksCustomMetaData.Builder  
PersistentTasksCustomMetaData.PersistentTask<P extends PersistentTaskParams>
A record that represents a single running persistent task
PersistentTasksExecutor<Params extends PersistentTaskParams>
An executor of tasks that can survive restart of requesting or executing node.
PersistentTasksExecutorRegistry
Components that registers all persistent task executors
PersistentTasksNodeService
This component is responsible for coordination of execution of persistent tasks on individual nodes.
PersistentTasksNodeService.Status  
PersistentTasksService
This service is used by persistent tasks and allocated persistent tasks to communicate changes to the master node so that the master can update the cluster state and can track of the states of the persistent tasks.
PersistentTasksService.WaitForPersistentTaskListener<P extends PersistentTaskParams>  
PersistentTaskState
PersistentTaskState represents the state of the persistent tasks, as it is persisted in the cluster state.
PhraseSuggester  
PhraseSuggestion
Suggestion entry returned from the PhraseSuggester.
PhraseSuggestion.Entry  
PhraseSuggestion.Entry.Option  
PhraseSuggestionBuilder
Defines the actual suggest command for phrase suggestions ( phrase).
PhraseSuggestionBuilder.CandidateGenerator
PidFile
Process ID file abstraction that writes the current pid into a file and optionally removes it on system exit.
PingContextProvider  
Pipeline
A pipeline is a list of Processor instances grouped under a unique id.
PipelineAggregationBuilder
A factory that knows how to create an PipelineAggregator of a specific type.
PipelineAggregator  
PipelineAggregator.Parser
PipelineAggregatorBuilders  
PipelineConfiguration
Encapsulates a pipeline's id and configuration as a blob
PipelineProcessor  
PipelineProcessor.Factory  
PlainActionFuture<T>  
PlainBlobMetaData  
PlainHighlighter  
PlainListenableActionFuture<T>  
PlainShardIterator
The PlainShardIterator is a ShardsIterator which iterates all shards or a given shard id
PlainShardsIterator
A simple ShardsIterator that iterates a list or sub-list of shard indexRoutings.
PlainTransportFuture<V extends TransportResponse>  
Platforms
Encapsulates platform-dependent methods for handling native components of plugins.
Plugin
An extension point allowing to plug in custom functionality.
PluginInfo
An in-memory representation of the plugin descriptor.
PluginsAndModules
Information about plugins and modules
PluginsService  
PointBuilder  
PolygonBuilder
The PolygonBuilder implements the groundwork to create polygons.
PortsRange  
PortsRange.PortCallback  
PreBuiltAnalyzerProvider  
PreBuiltAnalyzerProviderFactory  
PreBuiltAnalyzers  
PreBuiltCacheFactory  
PreBuiltCacheFactory.CachingStrategy
The strategy of caching the analyzer ONE Exactly one version is stored.
PreBuiltCacheFactory.PreBuiltCache<T>  
PreBuiltTokenizers  
PreConfiguredAnalysisComponent<T>
Shared implementation for pre-configured analysis components.
PreConfiguredCharFilter
Provides pre-configured, shared CharFilters.
PreConfiguredTokenFilter
Provides pre-configured, shared TokenFilters.
PreConfiguredTokenizer
Provides pre-configured, shared Tokenizers.
Preference
Routing Preference Type
PrefixQueryBuilder
A Query that matches documents containing terms with a specified prefix.
PreProcessModule
A module can implement this interface to allow to pre process other modules before an injector is created.
PreVoteCollector  
PreVoteRequest  
PreVoteResponse  
PrimaryMissingActionException  
PrimaryReplicaSyncer  
PrimaryReplicaSyncer.ResyncRequest  
PrimaryReplicaSyncer.ResyncTask  
PrimaryReplicaSyncer.ResyncTask.Status  
PrimaryReplicaSyncer.SyncAction  
PrimaryShardAllocator
The primary shard allocator allocates unassigned primary shards to nodes that hold valid copies of the unassigned primaries.
PrioritizedCallable<T>  
PrioritizedEsThreadPoolExecutor
A prioritizing executor which uses a priority queue as a work queue.
PrioritizedEsThreadPoolExecutor.Pending  
PrioritizedRunnable  
Priority  
PriorityComparator
A comparator that compares ShardRouting based on it's indexes priority (index.priority), it's creation date (index.creation_date), or eventually by it's index name in reverse order.
PrivateBinder
Returns a binder whose configuration information is hidden from its environment by default.
PrivateElements
A private collection of elements that are hidden from the enclosing injector or module by default.
PrivateElementsImpl  
PrivateModule
A module whose configuration information is hidden from its environment by default.
Probes  
ProcessClusterEventTimeoutException  
ProcessInfo  
Processor
A processor implementation may modify the data belonging to a document.
Processor.Factory
A factory that knows how to construct a processor based on a map of maps.
Processor.Parameters
Infrastructure class that holds services that can be used by processor factories to create processor instances and that gets passed around to all IngestPlugins.
ProcessorInfo  
ProcessProbe  
ProcessService  
ProcessStats  
ProcessStats.Cpu  
ProcessStats.Mem  
ProfileResult
This class is the internal representation of a profiled Query, corresponding to a single node in the query tree.
Profilers
Wrapper around all the profilers that makes management easier.
ProfileShardResult  
ProfileWeight
Weight wrapper that will compute how much time it takes to build the Scorer and then return a Scorer that is wrapped in order to compute timings as well.
ProfilingAggregator  
ProfilingLeafBucketCollector  
ProvidedBy
A pointer to the default provider type for a type.
Provider<T>
An object capable of providing instances of type T.
ProviderBinding<T extends Provider<?>>
A binding to a Provider that delegates to the binding for the provided type.
ProviderInstanceBinding<T>
A binding to a provider instance.
ProviderInstanceBindingImpl<T>  
ProviderKeyBinding<T>
A binding to a provider key.
ProviderLookup<T>
A lookup of the provider for a type.
ProviderLookup.ProviderImpl<T>  
ProviderMethod<T>
A provider that invokes a method and returns its result.
ProviderMethodsModule
Creates bindings to methods annotated with @Provides.
Providers
Static utility methods for creating and working with instances of Provider.
ProviderWithDependencies<T>
A provider with dependencies on other injected types.
Provides
Annotates methods of a Module to create a provider method binding.
ProvisionException
Indicates that there was a runtime failure while providing an instance.
ProxyConnectionStrategy  
ProxyConnectionStrategy.ProxyModeInfo  
Publication  
PublicationTransportHandler  
PublicationTransportHandler.PublicationContext  
PublishClusterStateAction  
PublishClusterStateAction.CommitClusterStateRequest  
PublishClusterStateAction.IncomingClusterStateListener  
PublishClusterStateStats
Class encapsulating stats about the PublishClusterStateAction
PublishRequest
Request which is used by the master node to publish cluster state changes.
PublishResponse
Response to a PublishRequest, carrying the term and version of the request.
PublishWithJoinResponse
Response to a PublishRequest.
PutIndexTemplateAction  
PutIndexTemplateRequest
A request to create an index template.
PutIndexTemplateRequestBuilder  
PutMappingAction  
PutMappingClusterStateUpdateRequest
Cluster state update request that allows to put a mapping
PutMappingRequest
Puts mapping definition registered under a specific type into one or more indices.
PutMappingRequestBuilder
Builder for a put mapping request
PutPipelineAction  
PutPipelineRequest  
PutPipelineRequestBuilder  
PutPipelineTransportAction  
PutRepositoryAction
Register repository action
PutRepositoryRequest
Register repository request.
PutRepositoryRequestBuilder
Register repository request builder
PutStoredScriptAction  
PutStoredScriptRequest  
PutStoredScriptRequestBuilder  
Queries  
QueryBuilder  
QueryBuilders
Utility class to create search queries.
QueryCache  
QueryCacheStats  
QueryExplanation  
QueryFetchSearchResult  
QueryParser<QB extends QueryBuilder>
Defines a query parser that is able to parse QueryBuilders from XContent.
QueryParserHelper
Helpers to extract and expand field names and boosts
QueryParsers  
QueryPhase
Query phase of a search request, used to run the query and get back from each shard information about the matching documents (document ids and score or sort criteria) so that matches can be reduced on the coordinating node
QueryPhaseExecutionException  
QueryProfileBreakdown
A record of timings for the various operations that may happen during query execution.
QueryProfiler
This class acts as a thread-local storage for profiling a query.
QueryProfileShardResult
A container class to hold the profile results for a single shard in the request.
QueryRescoreMode  
QueryRescorer  
QueryRescorer.QueryRescoreContext  
QueryRescorerBuilder  
QueryRewriteContext
Context object used to rewrite QueryBuilder instances into simplified version.
QuerySearchRequest  
QuerySearchResult  
QueryShardContext
Context object used to create lucene queries on the shard level.
QueryShardException
Exception that is thrown when creating lucene queries on the shard
QueryStringQueryBuilder
A query that parses a query string and runs it.
QueryStringQueryParser
A XQueryParser that uses the MapperService in order to build smarter queries based on the mapping information.
QueryTimingType  
QueryValidationException
This exception can be used to indicate various reasons why validation of a query has failed.
QueueResizingEsThreadPoolExecutor
An extension to thread pool executor, which automatically adjusts the queue size of the ResizableBlockingQueue according to Little's Law.
RamAccountingTermsEnum
TermsEnum that takes a CircuitBreaker, increasing the breaker every time .next(...) is called.
Randomness
Provides factory methods for producing reproducible sources of randomness.
RandomScoreFunction
Pseudo randomly generate a score for each LeafScoreFunction.score(int, float).
RandomScoreFunctionBuilder
A function that computes a random score for the matched documents
Range
A range aggregation.
Range.Bucket
A bucket associated with a specific range
RangeAggregationBuilder  
RangeAggregator  
RangeAggregator.Range  
RangeAggregator.Unmapped<R extends RangeAggregator.Range>  
RangeAggregatorFactory  
RangeFieldMapper
A FieldMapper for indexing numeric and date ranges, and creating queries
RangeFieldMapper.Builder  
RangeFieldMapper.Defaults  
RangeFieldMapper.Range
Class defining a range
RangeFieldMapper.RangeFieldType  
RangeFieldMapper.TypeParser  
RangeHistogramAggregator  
RangeQueryBuilder
A Query that matches documents within an range of terms.
RangeType
Enum defining the type of range
RangeType.LengthType  
RareTerms  
RareTerms.Bucket
A bucket that is associated with a single term
RareTermsAggregationBuilder  
RareTermsAggregatorFactory  
RareTermsAggregatorFactory.ExecutionMode  
RateLimitingInputStream
Rate limiting wrapper for InputStream
RateLimitingInputStream.Listener  
RatioValue
Utility class to represent ratio and percentage values between 0 and 100
RawTaskStatus
Raw, unparsed status from the task results index.
ReadOnlyEngine
A basic read-only engine that allows switching a shard to be true read-only temporarily or permanently.
RealtimeRequest
Indicates that a request can execute in realtime (reads from the translog).
RebalanceOnlyWhenActiveAllocationDecider
Only allow rebalancing when all shards are active within the shard replication group.
ReceiveTimeoutTransportException  
Reconfigurator
Computes the optimal configuration of voting nodes in the cluster.
RecoverFilesRecoveryException  
RecoveriesCollection
This class holds a collection of all on going recoveries on the current node (i.e., the node is the target node of those recoveries).
RecoveriesCollection.RecoveryRef
a reference to RecoveryTarget, which implements AutoCloseable.
RecoveryAction
Recovery information action
RecoveryCleanFilesRequest  
RecoveryEngineException  
RecoveryFailedException  
RecoveryFileChunkRequest  
RecoveryFilesInfoRequest  
RecoveryRequest
Request for recovery information
RecoveryRequestBuilder
Recovery information request builder.
RecoveryResponse
Information regarding the recovery state of indices and their associated shards.
RecoveryResponse  
RecoverySettings  
RecoverySource
Represents the recovery source of a shard.
RecoverySource.EmptyStoreRecoverySource
Recovery from a fresh copy
RecoverySource.ExistingStoreRecoverySource
Recovery from an existing on-disk store
RecoverySource.LocalShardsRecoverySource
recovery from other shards on same node (shrink index action)
RecoverySource.PeerRecoverySource
peer recovery from a primary shard
RecoverySource.SnapshotRecoverySource
recovery from a snapshot
RecoverySource.Type  
RecoverySourceHandler
RecoverySourceHandler handles the three phases of shard recovery, which is everything relating to copying the segment files as well as sending translog operations across the wire once the segments have been copied.
RecoveryState
Keeps track of state related to shard recovery.
RecoveryState.File  
RecoveryState.Index  
RecoveryState.Stage  
RecoveryState.Timer  
RecoveryState.Translog  
RecoveryState.VerifyIndex  
RecoveryStats
Recovery related statistics, starting at the shard level and allowing aggregation to indices and node level
RecoveryTarget
Represents a recovery where the current node is the target node of the recovery.
RecoveryTargetHandler  
RecoveryTranslogOperationsRequest  
Recycler<T>
A recycled object, note, implementations should support calling obtain and then recycle on different threads.
Recycler.C<T>  
Recycler.Factory<T>  
Recycler.V<T>  
Recyclers  
ReduceSearchPhaseException
A failure during a reduce phase (when receiving results from several shards, and reducing them into one or more results and possible actions).
RefreshAction  
RefreshFailedEngineException  
RefreshListeners
Allows for the registration of listeners that are called when a change becomes visible for search.
RefreshRequest
A refresh request making all operations performed since the last refresh available for search.
RefreshRequestBuilder
A refresh request making all operations performed since the last refresh available for search.
RefreshResponse
The response of a refresh action.
RefreshStats  
Regex  
RegexOptions
Regular expression options for completion suggester
RegexOptions.Builder
Options for regular expression queries
RegexpFlag
Regular expression syntax flags.
RegexpQueryBuilder
A Query that does fuzzy matching for a specific value.
ReindexAction  
ReindexRequest
Request to reindex some documents from one index to another.
ReindexRequestBuilder  
RejectAwareActionListener<T>  
Releasable
Specialization of AutoCloseable that may only throw an ElasticsearchException.
ReleasableBytesReference
An extension to BytesReference that requires releasing its content.
ReleasableBytesStreamOutput
An bytes stream output that allows providing a BigArrays instance expecting it to require releasing its content (ReleasableBytesStreamOutput.bytes()) once done.
ReleasableLock
Releasable lock used inside of Engine implementations
Releasables
Utility methods to work with Releasables.
ReloadableCustomAnalyzer  
ReloadablePlugin
An extension point for Plugins that can be reloaded.
RemoteClusterAware
Base class for all services and components that need up-to-date information about the registered remote clusters
RemoteClusterAwareRequest  
RemoteClusterService
Basic service for accessing remote clusters via gateway nodes
RemoteConnectionInfo
This class encapsulates all remote cluster information to be rendered on _remote/info requests.
RemoteConnectionInfo.ModeInfo  
RemoteConnectionManager  
RemoteConnectionStrategy  
RemoteInfo  
RemoteInfoAction  
RemoteInfoRequest  
RemoteInfoRequestBuilder  
RemoteInfoResponse  
RemoteRecoveryTargetHandler  
RemoteTransportException
A remote exception for an action.
RemovalListener<K,​V>  
RemovalNotification<K,​V>  
RemovalNotification.RemovalReason  
RemoveCorruptedLuceneSegmentsAction
Removes corrupted Lucene index segments
RemoveCorruptedShardDataCommand  
RemoveCorruptedShardDataCommand.CleanStatus  
RemoveCustomsCommand  
RemovePersistentTaskAction  
RemovePersistentTaskAction.Request  
RemovePersistentTaskAction.RequestBuilder  
RemovePersistentTaskAction.TransportAction  
RemoveSettingsCommand  
ReplicaAfterPrimaryActiveAllocationDecider
An allocation strategy that only allows for a replica to be allocated when the primary is active.
ReplicaShardAllocator  
ReplicatedWriteRequest<R extends ReplicatedWriteRequest<R>>
Requests that are both ReplicationRequests (run on a shard's primary first, then the replica) and WriteRequest (modify documents on a shard), for example BulkShardRequest, IndexRequest, and DeleteRequest.
ReplicationGroup
Replication group for a shard.
ReplicationOperation<Request extends ReplicationRequest<Request>,​ReplicaRequest extends ReplicationRequest<ReplicaRequest>,​PrimaryResultT extends ReplicationOperation.PrimaryResult<ReplicaRequest>>  
ReplicationOperation.Primary<RequestT extends ReplicationRequest<RequestT>,​ReplicaRequestT extends ReplicationRequest<ReplicaRequestT>,​PrimaryResultT extends ReplicationOperation.PrimaryResult<ReplicaRequestT>>
An encapsulation of an operation that is to be performed on the primary shard
ReplicationOperation.PrimaryResult<RequestT extends ReplicationRequest<RequestT>>  
ReplicationOperation.ReplicaResponse
An interface to encapsulate the metadata needed from replica shards when they respond to operations performed on them.
ReplicationOperation.Replicas<RequestT extends ReplicationRequest<RequestT>>
An encapsulation of an operation that will be executed on the replica shards, if present.
ReplicationOperation.RetryOnPrimaryException  
ReplicationRequest<Request extends ReplicationRequest<Request>>
Requests that are run on a particular replica, first on the primary and then on the replicas like IndexRequest or TransportShardRefreshAction.
ReplicationRequestBuilder<Request extends ReplicationRequest<Request>,​Response extends ActionResponse,​RequestBuilder extends ReplicationRequestBuilder<Request,​Response,​RequestBuilder>>  
ReplicationResponse
Base class for write action responses.
ReplicationResponse.ShardInfo  
ReplicationResponse.ShardInfo.Failure  
ReplicationTask
Task that tracks replication actions.
ReplicationTask.Status  
ReplicationTracker
This class is responsible for tracking the replication group with its progress and safety markers (local and global checkpoints).
ReplicationTracker.CheckpointState  
ReplicationTracker.PrimaryContext
Represents the sequence number component of the primary context.
RepositoriesMetaData
Contains metadata about registered snapshot repositories
RepositoriesModule
Sets up classes for Snapshot/Restore.
RepositoriesService
Service responsible for maintaining and providing access to snapshot repositories on nodes.
Repository
An interface for interacting with a repository in snapshot and restore.
Repository.Factory
An factory interface for constructing repositories.
RepositoryCleanupInProgress  
RepositoryCleanupInProgress.Entry  
RepositoryCleanupResult  
RepositoryData
A class that represents the data in a repository, as captured in the repository's index blob.
RepositoryException
Generic repository exception
RepositoryMetaData
Metadata about registered repository
RepositoryMissingException
Repository missing exception
RepositoryOperation
Coordinates of an operation that modifies a repository, assuming that repository at a specific generation.
RepositoryPlugin
An extension point for Plugin implementations to add custom snapshot repositories.
RepositoryVerificationException
Repository verification exception
RequestCacheStats  
RequestHandlerRegistry<Request extends TransportRequest>  
Requests
A handy one stop shop for creating requests (make sure to import static this class).
RequestValidators<T extends ActionRequest>  
RequestValidators.RequestValidator<T extends ActionRequest>
A validator that validates an request associated with indices before executing it.
RerouteExplanation
Class encapsulating the explanation for a single AllocationCommand taken from the Deciders
RerouteService
Asynchronously performs a cluster reroute, updating any shard states and rebalancing the cluster if appropriate.
RescoreContext
Context available to the rescore while it is running.
RescorePhase
Rescore phase of a search request, used to run potentially expensive scoring models against the top matching documents.
Rescorer
A query rescorer interface used to re-rank the Top-K results of a previously executed search.
RescorerBuilder<RB extends RescorerBuilder<RB>>
The abstract base builder for instances of RescorerBuilder.
ResizeAction  
ResizeAllocationDecider
An allocation decider that ensures we allocate the shards of a target index for resize operations next to the source primaries
ResizeRequest
Request class to shrink an index into a single shard
ResizeRequestBuilder  
ResizeResponse
A response for a resize index action, either shrink or split index.
ResizeType
The type of the resize operation
ResourceAlreadyExistsException  
ResourceNotFoundException
Generic ResourceNotFoundException corresponding to the RestStatus.NOT_FOUND status code
ResourceWatcher
Abstract resource watcher interface.
ResourceWatcherService
Generic resource watcher service Other elasticsearch services can register their resource watchers with this service using ResourceWatcherService.add(ResourceWatcher) method.
ResourceWatcherService.Frequency  
ResponseCollectorService
Collects statistics about queue size, response time, and service time of tasks executed on each node, making the EWMA of the values available to the coordinating node.
ResponseCollectorService.ComputedNodeStats
Struct-like class encapsulating a point-in-time snapshot of a particular node's statistics.
ResponseHandlerFailureTransportException
A failure to handle the response of a transaction action.
RestActionListener<Response>
An action listener that requires RestActionListener.processResponse(Object) to be implemented and will automatically handle failures.
RestActions  
RestActions.NodesResponseRestListener<NodesResponse extends BaseNodesResponse & ToXContent>
NodesResponseRestBuilderListener automatically translates any BaseNodesResponse (multi-node) response that is ToXContent-compatible into a RestResponse with the necessary header info (e.g., "cluster_name").
RestAddVotingConfigExclusionAction  
RestAliasAction  
RestAllocationAction  
RestAnalyzeAction  
RestAnalyzeAction.Fields  
RestBuilderListener<Response>
A REST action listener that builds an XContentBuilder based response.
RestBulkAction
{ "index" : { "_index" : "test", "_type" : "type1", "_id" : "1" } { "type1" : { "field1" : "value1" } } { "delete" : { "_index" : "test", "_type" : "type1", "_id" : "2" } } { "create" : { "_index" : "test", "_type" : "type1", "_id" : "1" } { "type1" : { "field1" : "value1" } }
RestCancelTasksAction  
RestCatAction  
RestCatRecoveryAction
RestRecoveryAction provides information about the status of replica recovery in a string format, designed to be used at the command line.
RestChannel
A channel used to construct bytes / builder based outputs, and send responses.
RestCleanupRepositoryAction
Cleans up a repository
RestClearIndicesCacheAction  
RestClearScrollAction  
RestClearVotingConfigExclusionsAction  
RestCloseIndexAction  
RestClusterAllocationExplainAction
Class handling cluster allocation explanation at the REST level
RestClusterGetSettingsAction  
RestClusterHealthAction  
RestClusterRerouteAction  
RestClusterSearchShardsAction  
RestClusterStateAction  
RestClusterStatsAction  
RestClusterUpdateSettingsAction  
RestController  
RestCountAction  
RestCountAction  
RestCreateIndexAction  
RestCreateSnapshotAction
Creates a new snapshot
RestDeleteAction  
RestDeleteIndexAction  
RestDeleteIndexTemplateAction  
RestDeletePipelineAction  
RestDeleteRepositoryAction
Unregisters a repository
RestDeleteSnapshotAction
Deletes a snapshot
RestDeleteStoredScriptAction  
RestExplainAction
Rest action for computing a score explanation for specific documents.
RestFieldCapabilitiesAction  
RestFielddataAction
Cat API class to display information about the size of fielddata fields per node
RestFlushAction  
RestForceMergeAction  
RestGetAction  
RestGetAliasesAction
The REST handler for get alias and head alias APIs.
RestGetFieldMappingAction  
RestGetIndexTemplateAction
The REST handler for get template and head template APIs.
RestGetIndicesAction
The REST handler for get index and head index APIs.
RestGetMappingAction  
RestGetPipelineAction  
RestGetRepositoriesAction
Returns repository information
RestGetScriptContextAction  
RestGetScriptLanguageAction  
RestGetSettingsAction  
RestGetSnapshotsAction
Returns information about snapshot
RestGetSourceAction
The REST handler for get source and head source APIs.
RestGetStoredScriptAction  
RestGetTaskAction  
RestHandler
Handler for REST requests
RestHeaderDefinition
A definition for an http header that should be copied to the ThreadContext when reading the request on the rest layer.
RestHealthAction  
RestIndexAction  
RestIndexDeleteAliasesAction  
RestIndexPutAliasAction  
RestIndicesAction  
RestIndicesAliasesAction  
RestIndicesSegmentsAction  
RestIndicesShardStoresAction
Rest action for IndicesShardStoresAction
RestIndicesStatsAction  
RestListTasksAction  
RestMainAction  
RestMasterAction  
RestMultiGetAction  
RestMultiSearchAction  
RestMultiTermVectorsAction  
RestNodeAttrsAction  
RestNodesAction  
RestNodesHotThreadsAction  
RestNodesInfoAction  
RestNodesStatsAction  
RestNodesUsageAction  
RestOpenIndexAction  
RestoreClusterStateListener  
RestoreInfo
Information about successfully completed restore operation.
RestoreInProgress
Meta data about restore processes that are currently executing
RestoreInProgress.Builder  
RestoreInProgress.Entry
Restore metadata
RestoreInProgress.ShardRestoreStatus
Represents status of a restored shard
RestoreInProgress.State
Shard restore process state
RestoreInProgressAllocationDecider
This AllocationDecider prevents shards that have failed to be restored from a snapshot to be allocated.
RestoreService
Service responsible for restoring snapshots
RestoreService.RestoreCompletionResponse  
RestoreService.RestoreInProgressUpdater  
RestoreSnapshotAction
Restore snapshot action
RestoreSnapshotRequest
Restore snapshot request
RestoreSnapshotRequestBuilder
Restore snapshot request builder
RestoreSnapshotResponse
Contains information about restores snapshot
RestPendingClusterTasksAction  
RestPendingClusterTasksAction  
RestPluginsAction  
RestPutIndexTemplateAction  
RestPutMappingAction  
RestPutPipelineAction  
RestPutRepositoryAction
Registers repositories
RestPutStoredScriptAction  
RestRecoveryAction
REST handler to report on index recoveries.
RestRefreshAction  
RestReloadSecureSettingsAction  
RestRemoteClusterInfoAction  
RestRepositoriesAction
Cat API class to display information about snapshot repositories
RestRequest  
RestRequest.BadParameterException  
RestRequest.ContentTypeHeaderException  
RestRequest.Method  
RestResizeHandler  
RestResizeHandler.RestCloneIndexAction  
RestResizeHandler.RestShrinkIndexAction  
RestResizeHandler.RestSplitIndexAction  
RestResponse  
RestResponseListener<Response>
A REST enabled action listener that has a basic onFailure implementation, and requires sub classes to only implement RestResponseListener.buildResponse(Object).
RestRestoreSnapshotAction
Restores a snapshot
RestRolloverIndexAction  
RestSearchAction  
RestSearchScrollAction  
RestSegmentsAction  
RestShardsAction  
RestSimulatePipelineAction  
RestSnapshotAction
Cat API class to display information about snapshots
RestSnapshotsStatusAction
Returns status of currently running snapshot
RestStatus  
RestStatusToXContentListener<Response extends StatusToXContentObject>
Content listener that extracts that RestStatus from the response.
RestSyncedFlushAction  
RestTable  
RestTasksAction  
RestTemplatesAction  
RestTermVectorsAction
This class parses the json request and translates it into a TermVectorsRequest.
RestThreadPoolAction  
RestToXContentListener<Response extends ToXContentObject>
A REST based action listener that assumes the response is of type ToXContent and automatically builds an XContent based response (wrapping the toXContent in startObject/endObject).
RestUpdateAction  
RestUpdateSettingsAction  
RestUpgradeAction  
RestUpgradeStatusAction  
RestUtils  
RestValidateQueryAction  
RestVerifyRepositoryAction  
ResyncReplicationRequest
Represents a batch of operations sent from the primary to its replicas during the primary-replica resync.
ResyncReplicationResponse  
RetentionLease
A "shard history retention lease" (or "retention lease" for short) is conceptually a marker containing a retaining sequence number such that all operations with sequence number at least that retaining sequence number will be retained during merge operations (which could otherwise merge away operations that have been soft deleted).
RetentionLeaseActions
This class holds all actions related to retention leases.
RetentionLeaseActions.Add  
RetentionLeaseActions.Add.TransportAction  
RetentionLeaseActions.AddRequest  
RetentionLeaseActions.Remove  
RetentionLeaseActions.Remove.TransportAction  
RetentionLeaseActions.RemoveRequest  
RetentionLeaseActions.Renew  
RetentionLeaseActions.Renew.TransportAction  
RetentionLeaseActions.RenewRequest  
RetentionLeaseActions.Response  
RetentionLeaseAlreadyExistsException  
RetentionLeaseBackgroundSyncAction
Replication action responsible for background syncing retention leases to replicas.
RetentionLeaseBackgroundSyncAction.Request  
RetentionLeaseInvalidRetainingSeqNoException  
RetentionLeaseNotFoundException  
RetentionLeases
Represents a versioned collection of retention leases.
RetentionLeaseStats
Represents retention lease stats.
RetentionLeaseSyncAction
Write action responsible for syncing retention leases to replicas.
RetentionLeaseSyncAction.Request  
RetentionLeaseSyncAction.Response  
RetentionLeaseSyncer  
RetentionLeaseSyncer.BackgroundSyncAction
Represents an action that is invoked periodically to sync retention leases to replica shards after some retention lease has been renewed or expired.
RetentionLeaseSyncer.SyncAction
Represents an action that is invoked to sync retention leases to replica shards after a retention lease is added or removed on the primary.
Retry
Encapsulates synchronous and asynchronous retry logic.
ReverseNested
A reverse nested aggregation.
ReverseNestedAggregationBuilder  
ReverseNestedAggregator  
ReverseNestedAggregatorFactory  
Rewriteable<T>
A basic interface for rewriteable classes.
RolloverAction  
RolloverInfo
Class for holding Rollover related information within an index
RolloverRequest
Request class to swap index under an alias upon satisfying conditions Note: there is a new class with the same name for the Java HLRC that uses a typeless format.
RolloverRequestBuilder  
RolloverResponse
Response object for RolloverRequest API Note: there is a new class with the same name for the Java HLRC that uses a typeless format.
RootObjectMapper  
RootObjectMapper.Builder  
RootObjectMapper.Defaults  
RootObjectMapper.TypeParser  
RotationShardShuffler
Basic ShardShuffler implementation that uses an AtomicInteger to generate seeds and uses a rotation to permute shards.
Rounding
A strategy for rounding date/time based values.
Rounding Deprecated.
Rounding.Builder  
Rounding.Builder  
Rounding.DateTimeUnit  
Rounding.Streams  
RoutingAllocation
The RoutingAllocation keep the state of the current allocation of shards and holds the AllocationDeciders which are responsible for the current routing state.
RoutingAllocation.DebugMode  
RoutingChangesObserver
Records changes made to RoutingNodes during an allocation round.
RoutingChangesObserver.AbstractRoutingChangesObserver
Abstract implementation of RoutingChangesObserver that does not take any action.
RoutingChangesObserver.DelegatingRoutingChangesObserver  
RoutingException
A base Exceptions for all exceptions thrown by routing related operations.
RoutingExplanations
Class used to encapsulate a number of RerouteExplanation explanations.
RoutingFieldMapper  
RoutingFieldMapper.Builder  
RoutingFieldMapper.Defaults  
RoutingFieldMapper.TypeParser  
RoutingMissingException  
RoutingNode
A RoutingNode represents a cluster node associated with a single DiscoveryNode including all shards that are hosted on that nodes.
RoutingNodes
RoutingNodes represents a copy the routing information contained in the cluster state.
RoutingNodes.UnassignedShards  
RoutingNodesChangedObserver
Records if changes were made to RoutingNodes during an allocation round.
RoutingTable
Represents a global cluster-wide routing table for all indices including the version of the current routing state.
RoutingTable.Builder
Builder for the routing table.
RunOnce
Runnable that can only be run one time.
SafeCommitInfo
Information about the safe commit, for making decisions about recoveries.
SameShardAllocationDecider
An allocation decider that prevents multiple instances of the same shard to be allocated on the same node.
Sampler
A filter aggregation that defines a single bucket to hold a sample of top-matching documents.
SamplerAggregationBuilder  
SamplerAggregator
Aggregate on only the top-scoring docs on a shard.
SamplerAggregator.ExecutionMode  
SamplerAggregatorFactory  
ScalingExecutorBuilder
A builder for scaling executors.
Scheduler
Scheduler that allows to schedule one-shot and periodic commands.
Scheduler.Cancellable
This interface represents an object whose execution may be cancelled during runtime.
Scheduler.ReschedulingRunnable
This class encapsulates the scheduling of a Runnable that needs to be repeated on a interval.
Scheduler.SafeScheduledThreadPoolExecutor
This subclass ensures to properly bubble up Throwable instances of both type Error and Exception thrown in submitted/scheduled tasks to the uncaught exception handler
Scheduler.ScheduledCancellable
A scheduled cancellable allow cancelling and reading the remaining delay of a scheduled task.
Scope
A scope is a level of visibility that instances provided by Guice may have.
ScopeAnnotation
Annotates annotations which are used for scoping.
ScopeBinding
Registration of a scope annotation with the scope that implements it.
ScopedBindingBuilder
See the EDSL examples at Binder.
Scopes
Built-in scope implementations.
Scoping
References a scope, either directly (as a scope instance), or indirectly (as a scope annotation).
ScoreFunction  
ScoreFunctionBuilder<FB extends ScoreFunctionBuilder<FB>>  
ScoreFunctionBuilders
Static method aliases for constructors of known ScoreFunctionBuilders.
ScoreFunctionParser<FB extends ScoreFunctionBuilder<FB>>
Parses XContent into a ScoreFunctionBuilder.
ScorerAware  
ScoreScript
A script used for adjusting the score on a per document basis.
ScoreScript.ExplanationHolder
A helper to take in an explanation from a script and turn it into an Explanation
ScoreScript.Factory
A factory to construct stateful ScoreScript factories for a specific index.
ScoreScript.LeafFactory
A factory to construct ScoreScript instances.
ScoreScriptUtils  
ScoreScriptUtils.DecayDateExp  
ScoreScriptUtils.DecayDateGauss  
ScoreScriptUtils.DecayDateLinear  
ScoreScriptUtils.DecayGeoExp  
ScoreScriptUtils.DecayGeoGauss  
ScoreScriptUtils.DecayGeoLinear  
ScoreScriptUtils.DecayNumericExp  
ScoreScriptUtils.DecayNumericGauss  
ScoreScriptUtils.DecayNumericLinear  
ScoreScriptUtils.RandomScoreDoc  
ScoreScriptUtils.RandomScoreField  
ScoreSortBuilder
A sort builder allowing to sort by score.
Script
Script represents used-defined input that can be used to compile and execute a script from the ScriptService based on the ScriptType.
ScriptBytesValues
SortedBinaryDocValues implementation that reads values from a script.
ScriptContext<FactoryType>
The information necessary to compile and run a script.
ScriptContextInfo  
ScriptContextInfo.ScriptMethodInfo  
ScriptContextInfo.ScriptMethodInfo.ParameterInfo  
ScriptDocValues<T>
Script level doc values, the assumption is that any implementation will implement a getValue method.
ScriptDocValues.Booleans  
ScriptDocValues.BytesRefs  
ScriptDocValues.Dates  
ScriptDocValues.Doubles  
ScriptDocValues.GeoPoints  
ScriptDocValues.Longs  
ScriptDocValues.Strings  
ScriptDoubleValues
SortingNumericDoubleValues implementation which is based on a script
ScriptedMetric
A metric aggregation that computes both its final and intermediate states using scripts.
ScriptedMetricAggContexts  
ScriptedMetricAggContexts.CombineScript  
ScriptedMetricAggContexts.CombineScript.Factory  
ScriptedMetricAggContexts.InitScript  
ScriptedMetricAggContexts.InitScript.Factory  
ScriptedMetricAggContexts.MapScript  
ScriptedMetricAggContexts.MapScript.Factory  
ScriptedMetricAggContexts.MapScript.LeafFactory  
ScriptedMetricAggContexts.ReduceScript  
ScriptedMetricAggContexts.ReduceScript.Factory  
ScriptedMetricAggregationBuilder  
ScriptedSimilarity
A Similarity implementation that allows scores to be scripted.
ScriptedSimilarity.Doc
Statistics that are specific to a document.
ScriptedSimilarity.Field
Statistics that are specific to a given field.
ScriptedSimilarity.Query
Scoring factors that come from the query.
ScriptedSimilarity.Term
Statistics that are specific to a given term.
ScriptEngine
A script language implementation.
ScriptException
Exception from a scripting engine.
ScriptFactory
Contains utility methods for compiled scripts without impacting concrete script signatures
ScriptFieldsContext  
ScriptFieldsContext.ScriptField  
ScriptFieldsPhase  
ScriptHeuristic  
ScriptLanguagesInfo
The allowable types, languages and their corresponding contexts.
ScriptLongValues
LongValues implementation which is based on a script
ScriptMetaData
ScriptMetaData is used to store user-defined scripts as part of the ClusterState using only an id as the key.
ScriptMetaData.Builder
A builder used to modify the currently stored scripts data held within the ClusterState.
ScriptMetrics  
ScriptModule
Manages building ScriptService.
ScriptPlugin
An additional extension point for Plugins that extends Elasticsearch's scripting functionality.
ScriptQueryBuilder  
ScriptScoreFunction  
ScriptScoreFunctionBuilder
A function that uses a script to compute or influence the score of documents that match with the inner query or filter.
ScriptScoreQuery
A query that uses a script to compute documents' scores.
ScriptScoreQueryBuilder
A query that computes a document score based on the provided script
ScriptService  
ScriptSortBuilder
Script sort builder allows to sort based on a custom script expression.
ScriptSortBuilder.ScriptSortType  
ScriptStats  
ScriptType
ScriptType represents the way a script is stored and retrieved from the ScriptService.
Scroll
A scroll enables scrolling of search request.
ScrollableHitSource
A scrollable source of results.
ScrollableHitSource.AsyncResponse  
ScrollableHitSource.BasicHit
An implementation of ScrollableHitSource.Hit that uses getters and setters.
ScrollableHitSource.Hit
A document returned as part of the response.
ScrollableHitSource.Response
Response from each scroll batch.
ScrollableHitSource.SearchFailure
A failure during search.
ScrollContext
Wrapper around information that needs to stay around when scrolling.
ScrollQueryFetchSearchResult  
ScrollQuerySearchResult  
SearchAction  
SearchAfterBuilder  
SearchAfterSortedDocQuery
A Query that only matches documents that are greater than the provided FieldDoc.
SearchContext
This class encapsulates the state needed to execute a search.
SearchContext.Lifetime
The life time of an object that is used during search execution.
SearchContextAggregations
The aggregation context that is part of the search context.
SearchContextHighlight  
SearchContextHighlight.Field  
SearchContextHighlight.FieldOptions  
SearchContextMissingException  
SearchException  
SearchExecutionStatsCollector
A wrapper of search action listeners (search results) that unwraps the query result to get the piggybacked queue size and service time EWMA, adding those values to the coordinating nodes' ResponseCollectorService.
SearchExtBuilder
Intermediate serializable representation of a search ext section.
SearchHit
A single search hit.
SearchHit.Fields  
SearchHit.NestedIdentity
Encapsulates the nested identity of a hit.
SearchHits  
SearchHits.Fields  
SearchIndexNameMatcher
A predicate that checks whether an index pattern matches the current search shard target.
SearchLookup  
SearchModule
Sets up things that can be done at search time like queries, aggregations, and suggesters.
SearchOperationListener
An listener for search, fetch and context events.
SearchOperationListener.CompositeListener
A Composite listener that multiplexes calls to each of the listeners methods.
SearchParseException  
SearchPhase
Represents a phase of a search request e.g.
SearchPhase.SearchContextSourcePrinter  
SearchPhaseController  
SearchPhaseController.ReducedQueryPhase  
SearchPhaseExecutionException  
SearchPhaseResult
This class is a base class for all search related results.
SearchPlugin
Plugin for extending search time behavior.
SearchPlugin.AggregationSpec
Specification for an Aggregation.
SearchPlugin.FetchPhaseConstructionContext
Context available during fetch phase construction.
SearchPlugin.PipelineAggregationSpec
Specification for a PipelineAggregator.
SearchPlugin.QuerySpec<T extends QueryBuilder>
Specification of custom Query.
SearchPlugin.RescorerSpec<T extends RescorerBuilder<T>>  
SearchPlugin.ScoreFunctionSpec<T extends ScoreFunctionBuilder<T>>
Specification of custom ScoreFunction.
SearchPlugin.SearchExtensionSpec<W extends NamedWriteable,​P>
Specification of search time behavior extension like a custom MovAvgModel or ScoreFunction.
SearchPlugin.SearchExtSpec<T extends SearchExtBuilder>
Specification for a SearchExtBuilder which represents an additional section that can be parsed in a search request (within the ext element).
SearchPlugin.SignificanceHeuristicSpec<T extends SignificanceHeuristic>
Specification of custom SignificanceHeuristic.
SearchPlugin.SuggesterSpec<T extends SuggestionBuilder<T>>
Specification for a Suggester.
SearchProfileShardResults
A container class to hold all the profile results across all shards.
SearchProgressActionListener
An ActionListener for search requests that allows to track progress of the SearchAction.
SearchRequest
A request to execute search against one or more indices (or all).
SearchRequestBuilder
A search action request builder.
SearchResponse
A response of a search request.
SearchResponse.Clusters
Holds info about the clusters that the search was executed on: how many in total, how many of them were successful and how many of them were skipped.
SearchResponseSections
Base class that holds the various sections which a search response is composed of (hits, aggs, suggestions etc.) and allows to retrieve them.
SearchScrollAction  
SearchScrollRequest  
SearchScrollRequestBuilder
A search scroll action request builder.
SearchService  
SearchService.CanMatchResponse  
SearchShard
A class that encapsulates the ShardId and the cluster alias of a shard used during the search action.
SearchShardIterator
Extension of PlainShardIterator used in the search api, which also holds the OriginalIndices of the search request (useful especially with cross-cluster search, as each cluster has its own set of original indices) as well as the cluster alias.
SearchShardTarget
The target that the search request was executed on.
SearchShardTask
Task storing information about a currently running search shard request.
SearchSlowLog  
SearchSortValues  
SearchSourceBuilder
A search source builder allowing to easily build search source.
SearchSourceBuilder.IndexBoost  
SearchSourceBuilder.ScriptField  
SearchSourceBuilderException  
SearchStats  
SearchStats.Stats  
SearchTask
Task storing information about a currently running SearchRequest.
SearchTransportService
An encapsulation of SearchService operations exposed through transport.
SearchTransportService.SearchFreeContextResponse  
SearchType
Search type represent the manner at which the search operation is executed.
SecureSetting<T>
A secure setting.
SecureSettings
An accessor for settings which are securely stored.
SecureString
A String implementations which allows clearing the underlying char array.
SeedHostsProvider
A pluggable provider of the list of seed hosts to use for discovery.
SeedHostsProvider.HostsResolver
Helper object that allows to resolve a list of hosts to a list of transport addresses.
SeedHostsResolver  
Segment  
SegmentsStats  
SendRequestTransportException  
SeqNoFieldMapper
Mapper for the _seq_no field.
SeqNoFieldMapper.Builder  
SeqNoFieldMapper.SeqNoDefaults  
SeqNoFieldMapper.SequenceIDFields
A sequence ID, which is made up of a sequence number (both the searchable and doc_value version of the field) and the primary term.
SeqNoFieldMapper.TypeParser  
SeqNoPrimaryTermPhase  
SeqNoStats  
SequenceNumbers
A utility class for handling sequence numbers.
SequenceNumbers.CommitInfo  
SerialDiffPipelineAggregationBuilder  
SerialDiffPipelineAggregator  
SetBackedScalingCuckooFilter
An approximate set membership datastructure that scales as more unique values are inserted.
Sets  
Setting<T>
A setting.
Setting.AffixKey
A key that allows for static pre and suffix.
Setting.AffixSetting<T>  
Setting.AffixSettingDependency
Allows an affix setting to declare a dependency on another affix setting.
Setting.GroupKey  
Setting.Key  
Setting.ListKey  
Setting.Property  
Setting.SettingDependency
Allows a setting to declare a dependency on another setting being set.
Setting.SimpleKey  
Setting.Validator<T>
Represents a validator for a setting.
Settings
An immutable settings implementation.
Settings.Builder
A builder allowing to put different settings and then Settings.Builder.build() an immutable settings implementation.
SettingsBasedSeedHostsProvider
An implementation of SeedHostsProvider that reads hosts/ports from the "discovery.seed_hosts" node setting.
SettingsException
A generic failure to handle settings.
SettingsFilter
A class that allows to filter settings objects by simple regular expression patterns or full settings keys.
SettingsModule
A module that binds the provided settings to the Settings interface.
SettingUpgrader<T>
Represents the logic to upgrade a setting.
ShapeBuilder<T extends org.locationtech.spatial4j.shape.Shape,​G extends Geometry,​E extends ShapeBuilder<T,​G,​E>>
Basic class for building GeoJSON shapes like Polygons, Linestrings, etc
ShapeBuilder.Edge
This helper class implements a linked list for Coordinate.
ShapeBuilder.Orientation  
ShapeParser
first point of entry for a shape parser
ShapeRelation
Enum representing the relationship between a Query / Filter Shape and indexed Shapes that will be used to determine if a Document should be matched or not
ShapesAvailability  
ShardAllocationDecision
Represents the decision taken for the allocation of a single shard.
ShardBitsetFilterCache  
ShardCoreKeyMap
A map between segment core cache keys and the shard that these segments belong to.
ShardFetchRequest
Shard level fetch base request.
ShardFetchSearchRequest
Shard level fetch request used with search.
ShardFieldData  
ShardFlushRequest  
ShardGenerations  
ShardGenerations.Builder  
ShardGetService  
ShardId
Allows for shard level components to be injected with the shard id.
ShardIndexWarmerService  
ShardIterator
Allows to iterate over a set of shard instances (routing) within a shard id group.
ShardLock
A shard lock guarantees exclusive access to a shards data directory.
ShardLockObtainFailedException
Exception used when the in-memory lock for a shard cannot be obtained
ShardNotFoundException  
ShardNotInPrimaryModeException  
ShardOperationFailedException
An exception indicating that a failure occurred performing an operation on the shard.
ShardPath  
ShardRequestCache
Tracks the portion of the request cache in use for a particular shard.
ShardRouting
ShardRouting immutably encapsulates information about shard indexRoutings like id, state, version, etc.
ShardRoutingState
Represents the current state of a ShardRouting as defined by the cluster.
ShardsAcknowledgedResponse  
ShardsAllocator
A ShardsAllocator is the main entry point for shard allocation on nodes in the cluster.
ShardSearchFailure
Represents a failure to search on a specific shard.
ShardSearchRequest
Shard level request that represents a search.
ShardSearchStats  
ShardSegments  
ShardShuffler
A shuffler for shards whose primary goal is to balance load.
ShardsIterator
Allows to iterate over unrelated shards.
ShardsLimitAllocationDecider
This AllocationDecider limits the number of shards per node on a per index or node-wide basis.
ShardsSyncedFlushResult
Result for all copies of a shard
ShardStateAction  
ShardStateAction.FailedShardEntry  
ShardStateAction.NoLongerPrimaryShardException  
ShardStateAction.ShardFailedClusterStateTaskExecutor  
ShardStateAction.ShardStartedClusterStateTaskExecutor  
ShardStateAction.StartedShardEntry  
ShardStateMetaData  
ShardStats  
ShardToolCli
Class encapsulating and dispatching commands from the elasticsearch-shard command line tool
ShardUpgradeRequest  
ShardUpgradeStatus  
ShardUtils  
ShardValidateQueryRequest
Internal validate request executed directly against a specific index shard.
ShingleTokenFilterFactory  
ShingleTokenFilterFactory.Factory  
ShrinkAction  
ShuffleForcedMergePolicy
A FilterMergePolicy that interleaves eldest and newest segments picked by MergePolicy.findForcedMerges(org.apache.lucene.index.SegmentInfos, int, java.util.Map<org.apache.lucene.index.SegmentCommitInfo, java.lang.Boolean>, org.apache.lucene.index.MergePolicy.MergeContext) and MergePolicy.findForcedDeletesMerges(org.apache.lucene.index.SegmentInfos, org.apache.lucene.index.MergePolicy.MergeContext).
SiblingPipelineAggregator  
SignificanceHeuristic
Heuristic for that SignificantTerms uses to pick out significant terms.
SignificanceHeuristicBuilder  
SignificantLongTerms
Result of the running the significant terms aggregation on a numeric field.
SignificantLongTermsAggregator  
SignificantStringTerms
Result of the running the significant terms aggregation on a String field.
SignificantStringTerms.Bucket  
SignificantStringTermsAggregator
An aggregator of significant string values.
SignificantTerms
An aggregation that collects significant terms in comparison to a background set.
SignificantTerms.Bucket  
SignificantTermsAggregationBuilder  
SignificantTermsAggregatorFactory  
SignificantTermsAggregatorFactory.ExecutionMode  
SignificantTermsHeuristicScoreScript
A script used in significant terms heuristic scoring.
SignificantTermsHeuristicScoreScript.Factory  
SignificantTextAggregationBuilder  
SignificantTextAggregator  
SignificantTextAggregatorFactory  
SimilarityProvider
Wrapper around a Similarity and its name.
SimilarityScript
A script that is used to build ScriptedSimilarity instances.
SimilarityScript.Factory  
SimilarityService  
SimilarityWeightScript
A script that is used to compute scoring factors that are the same for all documents.
SimilarityWeightScript.Factory  
SimpleAnalyzerProvider  
SimpleFragmentsBuilder
Direct Subclass of Lucene's org.apache.lucene.search.vectorhighlight.SimpleFragmentsBuilder that corrects offsets for broken analysis chains.
SimpleMappedFieldType
MappedFieldType base impl for field types that are neither dates nor ranges.
SimpleModel
Calculate a simple unweighted (arithmetic) moving average
SimpleModel.SimpleModelBuilder  
SimpleQueryStringBuilder
SimpleQuery is a query parser that acts similar to a query_string query, but won't throw exceptions for any weird string syntax.
SimpleQueryStringFlag
Flags for the XSimpleQueryString parser
SimpleQueryStringQueryParser
Wrapper class for Lucene's SimpleQueryStringQueryParser that allows us to redefine different types of queries.
SimpleQueryStringQueryParser.Settings
Class encapsulating the settings for the SimpleQueryString query, with their default values
SimpleValue  
SimulatedAnealingMinimizer
A cost minimizer which will fit a MovAvgModel to the data.
SimulateDocumentBaseResult
Holds the end result of what a pipeline did to sample document provided via the simulate api.
SimulateDocumentResult  
SimulateDocumentVerboseResult
Holds the result of what a pipeline did to a sample document via the simulate api, but instead of SimulateDocumentBaseResult this result class holds the intermediate result each processor did to the sample document.
SimulatePipelineAction  
SimulatePipelineRequest  
SimulatePipelineRequest.Fields  
SimulatePipelineRequestBuilder  
SimulatePipelineResponse  
SimulatePipelineTransportAction  
SimulateProcessorResult  
SingleBucketAggregation
A single bucket aggregation
SingleBucketAggregator
A bucket aggregator that doesn't create new buckets.
SingleFieldsVisitor
StoredFieldVisitor that loads a single field value.
SingleObjectCache<T>
A very simple single object cache that allows non-blocking refresh calls triggered by expiry time.
SinglePackedOrdinals  
SingleShardOperationRequestBuilder<Request extends SingleShardRequest<Request>,​Response extends ActionResponse,​RequestBuilder extends SingleShardOperationRequestBuilder<Request,​Response,​RequestBuilder>>  
SingleShardRequest<Request extends SingleShardRequest<Request>>  
Singleton
Apply this to implementation classes when you want only one instance (per Injector) to be reused for all injections for that binding.
SizeBlockingQueue<E>
A size based queue wrapping another blocking queue to provide (somewhat relaxed) capacity checks.
SizeUnit  
SizeValue  
SliceBuilder
A slice builder allowing to split a scroll in multiple partitions.
SlicedInputStream
A SlicedInputStream is a logical concatenation one or more input streams.
SliceQuery
An abstract Query that defines an hash function to partition the documents in multiple slices.
SlowLogLevel  
SmoothingModel  
Snapshot
Basic information about a snapshot - a SnapshotId and the repository that the snapshot belongs to.
SnapshotCreationException
Thrown when snapshot creation fails completely
SnapshotDeletionsInProgress
A class that represents the snapshot deletions that are in progress in the cluster.
SnapshotDeletionsInProgress.Entry
A class representing a snapshot deletion request entry in the cluster state.
SnapshotException
Generic snapshot exception
SnapshotFailedEngineException  
SnapshotFiles
Contains a list of files participating in a snapshot
SnapshotId
SnapshotId - snapshot name + snapshot UUID
SnapshotIndexShardStage  
SnapshotIndexShardStatus  
SnapshotIndexStatus
Represents snapshot status of all shards in the index
SnapshotInfo
Information about a snapshot
SnapshotInfo.SnapshotInfoBuilder  
SnapshotInProgressAllocationDecider
This AllocationDecider prevents shards that are currently been snapshotted to be moved to other nodes.
SnapshotInProgressException
Thrown on the attempt to execute an action that requires that no snapshot is in progress.
SnapshotMissingException
Thrown if requested snapshot doesn't exist
SnapshotRestoreException
Snapshot restore exception
SnapshotShardFailure
Stores information about failures that occurred during shard snapshotting process
SnapshotShardsService
This service runs on data and master nodes and controls currently snapshotted shards on these nodes.
SnapshotShardsService.UpdateIndexShardSnapshotStatusRequest
Internal request that is used to send changes in snapshot status to master
SnapshotShardsStats
Status of a snapshot shards
SnapshotsInProgress
Meta data about snapshots that are currently executing
SnapshotsInProgress.Entry  
SnapshotsInProgress.ShardSnapshotStatus  
SnapshotsInProgress.ShardState  
SnapshotsInProgress.State  
SnapshotsService
Service responsible for creating snapshots
SnapshotsStatusAction
Snapshots status action
SnapshotsStatusRequest
Get snapshot status request
SnapshotsStatusRequestBuilder
Snapshots status request builder
SnapshotsStatusResponse
Snapshot status response
SnapshotState
Represents the state that a snapshot can be in
SnapshotStats  
SnapshotStatus
Status of a snapshot
SnapshotUtils
Snapshot utilities
SniffConnectionStrategy  
SniffConnectionStrategy.SniffModeInfo  
Snippet
Represents a scored highlighted snippet.
SortAndFormats  
SortBuilder<T extends SortBuilder<T>>  
SortBuilders
A set of static factory methods for SortBuilders.
SortBy
An enum representing the valid sorting options
SortedBinaryDocValues
A list of per-document binary values, sorted according to BytesRef.compareTo(BytesRef).
SortedNumericDoubleValues
Clone of SortedNumericDocValues for double values.
SortedNumericDVIndexFieldData
FieldData backed by LeafReader.getSortedNumericDocValues(String)
SortedSetDVBytesAtomicFieldData
An AtomicFieldData implementation that uses Lucene SortedSetDocValues.
SortedSetDVOrdinalsIndexFieldData  
SortFieldAndFormat  
SortingBinaryDocValues
Base class for building SortedBinaryDocValues instances based on unsorted content.
SortingNumericDocValues
Base class for building SortedNumericDocValues instances based on unsorted content.
SortingNumericDoubleValues
Base class for building SortedNumericDoubleValues instances based on unsorted content.
SortMode
Elasticsearch supports sorting by array or multi-valued fields.
SortOrder
A sorting order.
SourceFieldMapper  
SourceFieldMapper.Builder  
SourceFieldMapper.Defaults  
SourceFieldMapper.TypeParser  
SourceLookup  
SourcePrioritizedRunnable
PrioritizedRunnable that also has a source string
SourceProvider
Provides access to the calling line of code.
SourceScoreOrderFragmentsBuilder  
SourceSimpleFragmentsBuilder  
SourceToParse  
SourceToParse.Origin  
SpanBooleanQueryRewriteWithMaxClause
A span rewrite method that extracts the first maxExpansions terms that match the MultiTermQuery in the terms dictionary.
SpanContainingQueryBuilder
Builder for SpanContainingQuery.
SpanFirstQueryBuilder  
SpanMatchNoDocsQuery
A SpanQuery that matches no documents.
SpanMultiTermQueryBuilder
Query that allows wrapping a MultiTermQueryBuilder (one of wildcard, fuzzy, prefix, term, range or regexp query) as a SpanQueryBuilder so it can be nested.
SpanNearQueryBuilder
Matches spans which are near one another.
SpanNearQueryBuilder.SpanGapQueryBuilder
SpanGapQueryBuilder enables gaps in a SpanNearQuery.
SpanNotQueryBuilder  
SpanOrQueryBuilder
Span query that matches the union of its clauses.
SpanQueryBuilder
Marker interface for a specific type of QueryBuilder that allows to build span queries.
SpanQueryBuilder.SpanQueryBuilderUtil  
SpanTermQueryBuilder
A Span Query that matches documents containing a term.
SpanWithinQueryBuilder
Builder for SpanWithinQuery.
SpatialStrategy  
SpecialPermission
Elasticsearch-specific permission to check before entering AccessController.doPrivileged() blocks.
StackTraceElements
Creates stack trace elements for members.
Stage
The stage we're running in.
StaleShard
A class that represents a stale shard copy.
StandardAnalyzerProvider  
StandardTokenizerFactory  
StartJoinRequest
Represents the action of requesting a join vote (see Join) from a node.
StartPersistentTaskAction
This action can be used to add the record for the persistent action to the cluster state.
StartPersistentTaskAction.Request  
StartPersistentTaskAction.RequestBuilder  
StartPersistentTaskAction.TransportAction  
StartRecoveryRequest
Represents a request for starting a peer recovery.
StaticInjectionRequest
A request to inject the static fields and methods of a type.
Stats
Statistics over a set of values (either aggregated over field data or scripts)
StatsAggregationBuilder  
StatsBucket
Statistics over a set of buckets
StatsBucketPipelineAggregationBuilder  
StatsBucketPipelineAggregator  
StatusToXContentObject
Objects that can both render themselves in as json/yaml/etc and can provide a RestStatus for their response.
StepListener<Response>
A StepListener provides a simple way to write a flow consisting of multiple asynchronous steps without having nested callbacks.
StopAnalyzerProvider  
StopTokenFilterFactory  
Stopwatch
Enables simple performance monitoring.
StopWatch
Simple stop watch, allowing for timing of a number of tasks, exposing total running time and running time for each named task.
StopWatch.TaskInfo
Inner class to hold data about one task executed within the stop watch.
Store
A Store provides plain access to files written by an elasticsearch index shard.
Store.MetadataSnapshot
Represents a snapshot of the current directory build from the latest Lucene commit.
Store.OnClose
A listener that is executed once the store is closed and all references to it are released
Store.RecoveryDiff
A class representing the diff between a recovery source and recovery target
StoredFieldsContext
Context used to fetch the stored_fields.
StoredScriptSource
StoredScriptSource represents user-defined parameters for a script saved in the ClusterState.
StoreFileMetaData  
StoreStats  
StreamInput
A stream from this node to another node.
StreamOutput
A stream from another node to this node.
Streams
Simple utility methods for file and stream copying.
StrictDynamicMappingException  
StrictISODateTimeFormat
Factory that creates instances of DateTimeFormatter based on the ISO8601 standard.
StringFieldType
Base class for MappedFieldType implementations that use the same representation for internal index terms as the external representation so that partial matching queries such as prefix, wildcard and fuzzy queries can be implemented.
StringRareTerms  
StringRareTerms.Bucket  
StringRareTermsAggregator
An aggregator that finds "rare" string values (e.g.
Strings
String utilities.
Strings  
StringSortScript  
StringSortScript.Factory
A factory to construct stateful StringSortScript factories for a specific index.
StringSortScript.LeafFactory
A factory to construct StringSortScript instances.
StringTerms
Result of the TermsAggregator when the field is a String.
StringTerms.Bucket  
StringTermsAggregator
An aggregator of string values.
StupidBackoff
A "stupid-backoff" smoothing model similar to Katz's Backoff.
SubSearchContext  
SuccessfullyProcessed
Suggest
Top level suggest result, containing the result for each suggestion.
Suggest.Suggestion<T extends Suggest.Suggestion.Entry>
The suggestion responses corresponding with the suggestions in the request.
Suggest.Suggestion.Entry<O extends Suggest.Suggestion.Entry.Option>
Represents a part from the suggest text with suggested options.
Suggest.Suggestion.Entry.Option
Contains the suggested text with its document frequency and score.
SuggestBuilder
Defines how to perform suggesting.
SuggestBuilders
A static factory for building suggester lookup queries
Suggester<T extends SuggestionSearchContext.SuggestionContext>  
SuggestingErrorOnUnknown  
SuggestionBuilder<T extends SuggestionBuilder<T>>
Base class for the different suggestion implementations.
SuggestionSearchContext  
SuggestionSearchContext.SuggestionContext  
SuggestPhase
Suggest phase of a search request, used to collect suggestions
Sum
An aggregation that computes the sum of the values in the current bucket.
SumAggregationBuilder  
SumBucketPipelineAggregationBuilder  
SumBucketPipelineAggregator  
SuppressLoggerChecks
Annotation to suppress logging usage checks errors inside a whole class or a method.
SyncedFlushAction  
SyncedFlushRequest
A synced flush request to sync flush one or more indices.
SyncedFlushRequestBuilder  
SyncedFlushResponse
The result of performing a sync flush operation on all shards of multiple indices
SyncedFlushService  
SyncedFlushService.InFlightOpsRequest  
SyncedFlushService.PreShardSyncedFlushRequest  
SyncedFlushService.ShardSyncedFlushRequest  
SyncedFlushService.ShardSyncedFlushResponse
Response for third step of synced flush (writing the sync id) for one shard copy
Table  
Table.Cell  
Task
Current task information
Task.Status
Report of the internal status of a task.
TaskAwareRequest
An interface for a request that can be used to register a task manager task
TaskBatcher
Batching support for PrioritizedEsThreadPoolExecutor Tasks that share the same batching key are batched (see TaskBatcher.BatchedTask.batchingKey)
TaskCancelledException
A generic exception that can be thrown by a task when it's cancelled by the task manager API
TaskGroup
Information about a currently running task and all its subtasks.
TaskGroup.Builder  
TaskId
Task id that consists of node id and id of the task on the node
TaskInfo
Information about a currently running task.
TaskListener<Response>
Listener for Task success or failure.
TaskManager
Task Manager service for keeping track of currently running tasks on the nodes
TaskOperationFailure
Information about task operation failures The class is final due to serialization limitations
TaskResult
Information about a running task or a task that stored its result.
TaskResultsService
Service that can store task results.
TasksRequestBuilder<Request extends BaseTasksRequest<Request>,​Response extends BaseTasksResponse,​RequestBuilder extends TasksRequestBuilder<Request,​Response,​RequestBuilder>>
Builder for task-based requests
TaskTransportChannel  
TcpChannel
This is a tcp channel representing a single channel connection to another node.
TcpChannel.ChannelStats  
TcpHeader  
TcpServerChannel
This is a tcp channel representing a server channel listening for new connections.
TcpTransport  
TcpTransport.HttpRequestOnTransportException
A helper exception to mark an incoming connection as potentially being HTTP so an appropriate error code can be returned
TcpTransport.ProfileSettings
Representation of a transport profile settings for a transport.profiles.$profilename.*
TcpTransportChannel  
TDigestState
Extension of TDigest with custom serialization.
TemplateScript
A string template rendered as a script.
TemplateScript.Factory  
TemplateUpgradeService
Upgrades Templates on behalf of installed Plugins when a node joins the cluster
TermQueryBuilder
A Query that matches documents containing a term.
Terms
A terms aggregation.
Terms.Bucket
A bucket that is associated with a single term
TermsAggregationBuilder  
TermsAggregator  
TermsAggregator.BucketCountThresholds  
TermsAggregatorFactory  
TermsAggregatorFactory.ExecutionMode  
TermsLookup
Encapsulates the parameters needed to fetch terms.
TermsQueryBuilder
A filter for a field based on several terms matching on any of them.
TermsSetQueryBuilder  
TermsSetQueryScript  
TermsSetQueryScript.Factory
A factory to construct stateful TermsSetQueryScript factories for a specific index.
TermsSetQueryScript.LeafFactory
A factory to construct TermsSetQueryScript instances.
TermsSliceQuery
A SliceQuery that uses the terms dictionary of a field to do the slicing.
TermSuggester  
TermSuggestion
The suggestion responses corresponding with the suggestions in the request.
TermSuggestion.Entry
Represents a part from the suggest text with suggested options.
TermSuggestion.Entry.Option
Contains the suggested text with its document frequency and score.
TermSuggestion.Frequency  
TermSuggestion.Score  
TermSuggestionBuilder
Defines the actual suggest command.
TermSuggestionBuilder.StringDistanceImpl
An enum representing the valid string edit distance algorithms for determining suggestions.
TermSuggestionBuilder.SuggestMode
An enum representing the valid suggest modes.
TermsValuesSourceBuilder
A CompositeValuesSourceBuilder that builds a ValuesSource from a Script or a field name.
TermVectorsAction  
TermVectorsFields
This class represents the result of a TermVectorsRequest.
TermVectorsFilter  
TermVectorsFilter.ScoreTerm  
TermVectorsRequest
Request returning the term vector (doc frequency, positions, offsets) for a document.
TermVectorsRequest.FilterSettings  
TermVectorsRequest.Flag  
TermVectorsRequestBuilder
The builder class for a term vector request.
TermVectorsResponse  
TermVectorsService  
Text
Both String and BytesReference representation of the text.
TextFieldMapper
A FieldMapper for full-text fields.
TextFieldMapper.Builder  
TextFieldMapper.Defaults  
TextFieldMapper.TextFieldType  
TextFieldMapper.TypeParser  
ThreadContext
A ThreadContext is a map of string headers and a transient map of keyed objects that are associated with a thread.
ThreadContext.StoredContext  
ThreadedActionListener<Response>
An action listener that wraps another action listener and threading its execution.
ThreadedActionListener.Wrapper
Wrapper that can be used to automatically wrap a listener in a threaded listener if needed.
ThreadingModel  
ThreadPool  
ThreadPool.Info  
ThreadPool.Names  
ThreadPool.ThreadPoolType  
ThreadPoolInfo  
ThreadPoolStats  
ThreadPoolStats.Stats  
ThrottlingAllocationDecider
ThrottlingAllocationDecider controls the recovery process per node in the cluster.
TimeoutClusterStateListener
An exception to cluster state listener that allows for timeouts and for post added notifications.
Timer
Helps measure how much time is spent running some methods.
TimestampParsingException  
TokenFilterFactory  
TokenizerFactory  
TopDocsAndMaxScore
Wrapper around a TopDocs instance and the maximum score.
TopHits
Accumulation of the most relevant hits for a bucket this aggregation falls into.
TopHitsAggregationBuilder  
ToStringBuilder
Helps with toString() methods.
TrackingResultProcessor
Processor to be used within Simulate API to keep track of processors executed in pipeline.
TragicExceptionHolder  
Translog
A Translog is a per index shard component that records all non-committed index operations in a durable manner.
Translog.Delete  
Translog.Durability  
Translog.Index  
Translog.Location  
Translog.NoOp  
Translog.Operation
A generic interface representing an operation performed on the transaction log.
Translog.Operation.Type  
Translog.Snapshot
A snapshot of the transaction log, allows to iterate over all the transaction log operations.
Translog.Source  
Translog.TranslogGeneration
References a transaction log generation
TranslogConfig  
TranslogCorruptedException  
TranslogDeletionPolicy  
TranslogException  
TranslogLeafReader
Internal class that mocks a single doc read from the transaction log as a leaf reader.
TranslogReader
an immutable translog filereader
TranslogStats  
TranslogWriter  
Transport  
Transport.Connection
A unidirectional connection to a DiscoveryNode
Transport.ResponseContext<T extends TransportResponse>
This class represents a response context that encapsulates the actual response handler, the action and the connection it was executed on.
Transport.ResponseHandlers
This class is a registry that allows
TransportAction<Request extends ActionRequest,​Response extends ActionResponse>  
TransportActionNodeProxy<Request extends ActionRequest,​Response extends ActionResponse>
A generic proxy that will execute the given action against a specific node.
TransportActionProxy
TransportActionProxy allows an arbitrary action to be executed on a defined target node while the initial request is sent to a second node that acts as a request proxy to the target node.
TransportActions  
TransportAddress
A transport address used for IP socket address (wraps InetSocketAddress).
TransportAddVotingConfigExclusionsAction  
TransportAliasesExistAction  
TransportAnalyzeAction
Transport action used to execute analyze requests
TransportBroadcastAction<Request extends BroadcastRequest<Request>,​Response extends BroadcastResponse,​ShardRequest extends BroadcastShardRequest,​ShardResponse extends BroadcastShardResponse>  
TransportBroadcastByNodeAction<Request extends BroadcastRequest<Request>,​Response extends BroadcastResponse,​ShardOperationResult extends Writeable>
Abstraction for transporting aggregated shard-level operations in a single request (NodeRequest) per-node and executing the shard-level operations serially on the receiving node.
TransportBroadcastByNodeAction.EmptyResult
Can be used for implementations of shardOperation for which there is no shard-level return value.
TransportBroadcastReplicationAction<Request extends BroadcastRequest<Request>,​Response extends BroadcastResponse,​ShardRequest extends ReplicationRequest<ShardRequest>,​ShardResponse extends ReplicationResponse>
Base class for requests that should be executed on all shards of an index or several indices.
TransportBulkAction
Groups bulk request items by shard, optionally creating non-existent indices and delegates to TransportShardBulkAction for shard-level bulk execution
TransportCancelTasksAction
Transport action that can be used to cancel currently running cancellable tasks.
TransportChannel
A transport channel allows to send a response to a request on the channel.
TransportCleanupRepositoryAction
Repository cleanup action for repository implementations based on BlobStoreRepository.
TransportClearIndicesCacheAction
Indices clear cache action.
TransportClearScrollAction  
TransportClearVotingConfigExclusionsAction  
TransportClient Deprecated.
TransportClient is deprecated in favour of the High Level REST client and will be removed in Elasticsearch 8.0.
TransportClient.HostFailureListener
Listener that allows to be notified whenever a node failure / disconnect happens
TransportCloseIndexAction
Close index action
TransportClusterAllocationExplainAction
The TransportClusterAllocationExplainAction is responsible for actually executing the explanation of a shard's allocation on the master node in the cluster.
TransportClusterHealthAction  
TransportClusterInfoAction<Request extends ClusterInfoRequest<Request>,​Response extends ActionResponse>  
TransportClusterRerouteAction  
TransportClusterSearchShardsAction  
TransportClusterStateAction  
TransportClusterStatsAction  
TransportClusterStatsAction.ClusterStatsNodeRequest  
TransportClusterUpdateSettingsAction  
TransportConnectionListener
A listener interface that allows to react on transport events.
TransportCreateIndexAction
Create index action.
TransportCreateSnapshotAction
Transport action for create snapshot operation
TransportDeleteAction Deprecated.
TransportDeleteIndexAction
Delete index action.
TransportDeleteIndexTemplateAction
Delete index action.
TransportDeleteRepositoryAction
Transport action for unregister repository operation
TransportDeleteSnapshotAction
Transport action for delete snapshot operation
TransportDeleteStoredScriptAction  
TransportException  
TransportExplainAction
Explain transport action.
TransportFieldCapabilitiesAction  
TransportFieldCapabilitiesIndexAction  
TransportFlushAction
Flush ActionType.
TransportForceMergeAction
ForceMerge index/indices action.
TransportFuture<V>  
TransportGetAction
Performs the get operation.
TransportGetAliasesAction  
TransportGetFieldMappingsAction  
TransportGetFieldMappingsIndexAction
Transport action used to retrieve the mappings related to fields that belong to a specific index
TransportGetIndexAction
Get index action.
TransportGetIndexTemplatesAction  
TransportGetMappingsAction  
TransportGetRepositoriesAction
Transport action for get repositories operation
TransportGetScriptContextAction  
TransportGetScriptLanguageAction  
TransportGetSettingsAction  
TransportGetSnapshotsAction
Transport Action for get snapshots operation
TransportGetStoredScriptAction  
TransportGetTaskAction
ActionType to get a single task.
TransportIndexAction Deprecated.
TransportIndicesAliasesAction
Add/remove aliases action
TransportIndicesExistsAction
Indices exists action.
TransportIndicesSegmentsAction  
TransportIndicesShardStoresAction
Transport action that reads the cluster state for shards with the requested criteria (see ClusterHealthStatus) of specific indices and fetches store information from all the nodes using TransportNodesListGatewayStartedShards
TransportIndicesStatsAction  
TransportInfo  
TransportInstanceSingleOperationAction<Request extends InstanceShardOperationRequest<Request>,​Response extends ActionResponse>  
TransportInterceptor
This interface allows plugins to intercept requests on both the sender and the receiver side.
TransportInterceptor.AsyncSender
TransportListTasksAction  
TransportLivenessAction  
TransportLogger  
TransportMainAction  
TransportMasterNodeAction<Request extends MasterNodeRequest<Request>,​Response extends ActionResponse>
A base class for operations that needs to be performed on the master node.
TransportMasterNodeReadAction<Request extends MasterNodeReadRequest<Request>,​Response extends ActionResponse>
A base class for read operations that needs to be performed on the master node.
TransportMessage  
TransportMessageListener  
TransportMultiGetAction  
TransportMultiSearchAction  
TransportMultiTermVectorsAction  
TransportNodesAction<NodesRequest extends BaseNodesRequest<NodesRequest>,​NodesResponse extends BaseNodesResponse,​NodeRequest extends BaseNodeRequest,​NodeResponse extends BaseNodeResponse>  
TransportNodesHotThreadsAction  
TransportNodesHotThreadsAction.NodeRequest  
TransportNodesInfoAction  
TransportNodesInfoAction.NodeInfoRequest  
TransportNodesListGatewayMetaState  
TransportNodesListGatewayMetaState.NodeGatewayMetaState  
TransportNodesListGatewayMetaState.NodeRequest  
TransportNodesListGatewayMetaState.NodesGatewayMetaState  
TransportNodesListGatewayMetaState.Request  
TransportNodesListGatewayStartedShards
This transport action is used to fetch the shard version from each node during primary allocation in GatewayAllocator.
TransportNodesListGatewayStartedShards.NodeGatewayStartedShards  
TransportNodesListGatewayStartedShards.NodeRequest  
TransportNodesListGatewayStartedShards.NodesGatewayStartedShards  
TransportNodesListGatewayStartedShards.Request  
TransportNodesListShardStoreMetaData  
TransportNodesListShardStoreMetaData.NodeRequest  
TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData  
TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData  
TransportNodesListShardStoreMetaData.Request  
TransportNodesListShardStoreMetaData.StoreFilesMetaData  
TransportNodesReloadSecureSettingsAction  
TransportNodesReloadSecureSettingsAction.NodeRequest  
TransportNodesSnapshotsStatus
Transport client that collects snapshot shard statuses from data nodes
TransportNodesSnapshotsStatus.NodeRequest  
TransportNodesSnapshotsStatus.NodeSnapshotStatus  
TransportNodesSnapshotsStatus.NodesSnapshotStatus  
TransportNodesSnapshotsStatus.Request  
TransportNodesStatsAction  
TransportNodesStatsAction.NodeStatsRequest  
TransportNodesUsageAction  
TransportNodesUsageAction.NodeUsageRequest  
TransportOpenIndexAction
Open index action
TransportPendingClusterTasksAction  
TransportPutIndexTemplateAction
Put index template action.
TransportPutMappingAction
Put mapping action.
TransportPutRepositoryAction
Transport action for register repository operation
TransportPutStoredScriptAction  
TransportRecoveryAction
Transport action for shard recovery operation.
TransportRefreshAction
Refresh action.
TransportRemoteInfoAction  
TransportReplicationAction<Request extends ReplicationRequest<Request>,​ReplicaRequest extends ReplicationRequest<ReplicaRequest>,​Response extends ReplicationResponse>
Base class for requests that should be executed on a primary copy followed by replica copies.
TransportReplicationAction.ConcreteReplicaRequest<R extends TransportRequest>  
TransportReplicationAction.ConcreteShardRequest<R extends TransportRequest>
a wrapper class to encapsulate a request when being sent to a specific allocation id
TransportReplicationAction.PrimaryResult<ReplicaRequest extends ReplicationRequest<ReplicaRequest>,​Response extends ReplicationResponse>  
TransportReplicationAction.ReplicaResponse  
TransportReplicationAction.ReplicaResult  
TransportReplicationAction.RetryOnReplicaException  
TransportRequest  
TransportRequest.Empty  
TransportRequestDeduplicator<T extends TransportRequest>
Deduplicator for TransportRequests that keeps track of TransportRequests that should not be sent in parallel.
TransportRequestHandler<T extends TransportRequest>  
TransportRequestOptions  
TransportRequestOptions.Builder  
TransportRequestOptions.Type  
TransportResizeAction
Main class to initiate resizing (shrink / split) an index into a new index
TransportResponse  
TransportResponse.Empty  
TransportResponseHandler<T extends TransportResponse>  
TransportRestoreSnapshotAction
Transport action for restore snapshot operation
TransportResyncReplicationAction  
TransportRolloverAction
Main class to swap the index pointed to by an alias, given some conditions
Transports  
TransportSearchAction  
TransportSearchScrollAction  
TransportSerializationException  
TransportService  
TransportService.ContextRestoreResponseHandler<T extends TransportResponse>
This handler wrapper ensures that the response thread executes with the correct thread context.
TransportService.HandshakeResponse  
TransportSettings  
TransportShardBulkAction
Performs shard-level bulk (index, delete or update) operations
TransportShardFlushAction  
TransportShardMultiGetAction  
TransportShardMultiTermsVectorAction  
TransportShardRefreshAction  
TransportSingleItemBulkWriteAction<Request extends ReplicatedWriteRequest<Request>,​Response extends ReplicationResponse & WriteResponse> Deprecated.
TransportSingleShardAction<Request extends SingleShardRequest<Request>,​Response extends ActionResponse>
A base class for operations that need to perform a read operation on a single shard copy.
TransportSnapshotsStatusAction  
TransportStats  
TransportStatus  
TransportSyncedFlushAction
Synced flush ActionType.
TransportTasksAction<OperationTask extends Task,​TasksRequest extends BaseTasksRequest<TasksRequest>,​TasksResponse extends BaseTasksResponse,​TaskResponse extends Writeable>
The base class for transport actions that are interacting with currently running tasks.
TransportTermVectorsAction
Performs the get operation.
TransportTypesExistsAction
Types exists transport action.
TransportUpdateAction  
TransportUpdateSettingsAction  
TransportUpgradeAction
Upgrade index/indices action.
TransportUpgradeSettingsAction  
TransportUpgradeStatusAction  
TransportValidateQueryAction  
TransportVerifyRepositoryAction
Transport action for verifying repository operation
TransportVerifyShardBeforeCloseAction  
TransportVerifyShardBeforeCloseAction.ShardRequest  
TransportWriteAction<Request extends ReplicatedWriteRequest<Request>,​ReplicaRequest extends ReplicatedWriteRequest<ReplicaRequest>,​Response extends ReplicationResponse & WriteResponse>
Base class for transport actions that modify data in some shard like index, delete, and shardBulk.
TransportWriteAction.WritePrimaryResult<ReplicaRequest extends ReplicatedWriteRequest<ReplicaRequest>,​Response extends ReplicationResponse & WriteResponse>
Result of taking the action on the primary.
TransportWriteAction.WriteReplicaResult<ReplicaRequest extends ReplicatedWriteRequest<ReplicaRequest>>
Result of taking the action on the replica.
TriConsumer<S,​T,​U>
Represents an operation that accepts three arguments and returns no result.
TriFunction<S,​T,​U,​R>
Represents a function that accepts three arguments and produces a result.
TruncatedTranslogException  
TruncateTranslogAction  
TypeConverter
Converts constant string values to a different type.
TypeConverterBinding
Registration of type converters for matching target types.
TypeEncounter<I>
Context of an injectable type encounter.
TypeFieldMapper  
TypeFieldMapper.Defaults  
TypeFieldMapper.TypeFieldType  
TypeFieldMapper.TypeParser  
TypeFieldMapper.TypesQuery
Specialization for a disjunction over many _type
TypeListener
Listens for Guice to encounter injectable types.
TypeListenerBinding
Binds types (picked using a Matcher) to an type listener.
TypeLiteral<T>
Represents a generic type T.
TypeMissingException  
TypeParsers  
TypeQueryBuilder  
Types
Static methods for working with types.
TypesExistsAction  
TypesExistsRequest  
TypesExistsRequestBuilder Deprecated.
TypesExistsResponse
Whether all of the existed types exist.
Uid  
UnassignedInfo
Holds additional information as to why the shard is in unassigned state.
UnassignedInfo.AllocationStatus
Captures the status of an unsuccessful allocation attempt for the shard, causing it to remain in the unassigned state.
UnassignedInfo.Reason
Reason why the shard is in unassigned state.
UnavailableShardsException  
UncategorizedExecutionException  
UnicastZenPing  
UnicastZenPing.UnicastPingRequest  
UnicastZenPing.UnicastPingResponse  
UnifiedHighlighter  
UniqueAnnotations  
UnknownNamedObjectException
UnmappedRareTerms
Result of the RareTerms aggregation when the field is unmapped.
UnmappedRareTerms.Bucket  
UnmappedSampler  
UnmappedSignificantTerms
Result of the running the significant terms aggregation on an unmapped field.
UnmappedSignificantTerms.Bucket
Concrete type that can't be built because Java needs a concrete type so InternalTerms.Bucket can have a self type but UnmappedTerms doesn't ever need to build it because it never returns any buckets.
UnmappedTerms
Result of the TermsAggregator when the field is unmapped.
UnmappedTerms.Bucket
Concrete type that can't be built because Java needs a concrete type so InternalTerms.Bucket can have a self type but UnmappedTerms doesn't ever need to build it because it never returns any buckets.
UnsafeBootstrapMasterCommand  
UntargettedBinding<T>
An untargetted binding.
UntargettedBindingImpl<T>  
UpdateAction  
UpdateByQueryAction  
UpdateByQueryRequest
Request to update some documents.
UpdateByQueryRequestBuilder  
UpdateHelper
Helper for translating an update request to an index, delete request or update response.
UpdateHelper.ContextFields
Field names used to populate the script context
UpdateHelper.Result  
UpdatePersistentTaskStatusAction  
UpdatePersistentTaskStatusAction.Request  
UpdatePersistentTaskStatusAction.RequestBuilder  
UpdatePersistentTaskStatusAction.TransportAction  
UpdateRequest  
UpdateRequestBuilder  
UpdateResponse  
UpdateResponse.Builder
Builder class for UpdateResponse.
UpdateScript
An update script.
UpdateScript.Factory  
UpdateSettingsAction  
UpdateSettingsClusterStateUpdateRequest
Cluster state update request that allows to update settings for some indices
UpdateSettingsRequest
Request for an update index settings action
UpdateSettingsRequestBuilder
Builder for an update index settings request
UpgradeAction
Upgrade index/indices action.
UpgradeKeyStoreCommand
A sub-command for the keystore CLI that enables upgrading the keystore format.
UpgradeRequest
A request to upgrade one or more indices.
UpgradeRequest.Defaults  
UpgradeRequestBuilder
A request to upgrade one or more indices.
UpgradeResponse
A response for the upgrade action.
UpgradeSettingsAction  
UpgradeSettingsClusterStateUpdateRequest
Cluster state update request that allows to change minimum compatibility settings for some indices
UpgradeSettingsRequest
Request for an update index settings action
UpgradeSettingsRequestBuilder
Builder for an update index settings request
UpgradeStatusAction  
UpgradeStatusRequest  
UpgradeStatusRequestBuilder  
UpgradeStatusResponse  
URIPattern
URI Pattern matcher The pattern is URI in which authority, path, query and fragment can be replace with simple pattern.
UsageService
A service to monitor usage of Elasticsearch features.
UTF8StreamWriter  
UUIDs  
ValidateActions  
ValidateJoinRequest  
ValidateQueryAction  
ValidateQueryRequest
A request to validate a specific query.
ValidateQueryRequestBuilder  
ValidateQueryResponse
The response of the validate action.
ValidationException
Encapsulates an accumulation of validation errors
ValueCount
An get that holds the number of values that the current document set has for a specific field.
ValueCountAggregationBuilder  
ValueSource
Holds a value.
ValueSource.ByteValue  
ValueSource.ListValue  
ValueSource.MapValue  
ValueSource.ObjectValue  
ValueSource.TemplatedValue  
ValuesSource  
ValuesSource.Bytes  
ValuesSource.Bytes.FieldData  
ValuesSource.Bytes.Script
ValuesSource implementation for stand alone scripts returning a Bytes value
ValuesSource.Bytes.WithOrdinals  
ValuesSource.Bytes.WithOrdinals.FieldData  
ValuesSource.Bytes.WithScript
ValuesSource subclass for Bytes fields with a Value Script applied
ValuesSource.GeoPoint  
ValuesSource.GeoPoint.Fielddata  
ValuesSource.Histogram  
ValuesSource.Histogram.Fielddata  
ValuesSource.Numeric  
ValuesSource.Numeric.FieldData  
ValuesSource.Numeric.Script
ValuesSource implementation for stand alone scripts returning a Numeric value
ValuesSource.Numeric.WithScript
ValuesSource subclass for Numeric fields with a Value Script applied
ValuesSource.Range  
ValuesSourceAggregationBuilder<VS extends ValuesSource,​AB extends ValuesSourceAggregationBuilder<VS,​AB>>  
ValuesSourceAggregationBuilder.LeafOnly<VS extends ValuesSource,​AB extends ValuesSourceAggregationBuilder<VS,​AB>>  
ValuesSourceAggregatorFactory<VS extends ValuesSource>  
ValuesSourceConfig<VS extends ValuesSource>
A configuration that tells aggregations how to retrieve data from the index in order to run a specific aggregation.
ValuesSourceParserHelper  
ValuesSourceType
ValuesSourceType wraps the creation of specific per-source instances each ValuesSource needs to provide.
ValueType  
VectorGeoShapeQueryProcessor  
VerificationFailure  
VerifyingIndexOutput
abstract class for verifying what was written.
VerifyNodeRepositoryAction  
VerifyNodeRepositoryAction.VerifyNodeRepositoryRequest  
VerifyRepositoryAction
Unregister repository action
VerifyRepositoryRequest
Unregister repository request.
VerifyRepositoryRequestBuilder
Builder for unregister repository request
VerifyRepositoryResponse
Verify repository response
VerifyRepositoryResponse.NodeView  
Version  
VersionConflictEngineException  
VersionedNamedWriteable
A NamedWriteable that has a minimum version associated with it.
VersionFieldMapper
Mapper for the _version field.
VersionFieldMapper.Defaults  
VersionFieldMapper.TypeParser  
Versions  
VersionsAndSeqNoResolver
Utility class to resolve the Lucene doc ID, version, seqNo and primaryTerms for a given uid.
VersionsAndSeqNoResolver.DocIdAndSeqNo
Wraps an LeafReaderContext, a doc ID relative to the context doc base and a seqNo.
VersionsAndSeqNoResolver.DocIdAndVersion
Wraps an LeafReaderContext, a doc ID relative to the context doc base and a version.
VersionType  
WarmerStats  
WatcherHandle<W extends ResourceWatcher>  
WeightBuilder
A query that multiplies the weight to the score.
WeightedAvg
An aggregation that computes the average of the values in the current bucket.
WeightedAvgAggregationBuilder  
WeightFactorFunction  
WhitespaceAnalyzerProvider  
WildcardQueryBuilder
Implements the wildcard search query.
WordScorer  
WordScorer.WordScorerFactory  
WorkerBulkByScrollTaskState
Task behavior for BulkByScrollTask that does the actual work of querying and indexing
WrappedRunnable  
WrapperQueryBuilder
A Query builder which allows building a query given JSON string or binary data provided as input.
WrappingProcessor
A srapping processor is one that encapsulates an inner processor, or a processor that the wrapped processor enacts upon.
Writeable
Implementers can be written to a StreamOutput and read from a StreamInput.
Writeable.Reader<V>
Reference to a method that can read some object from a stream.
Writeable.Writer<V>
Reference to a method that can write some object to a StreamOutput.
WriteRequest<R extends WriteRequest<R>>
Interface implemented by requests that modify the documents in an index like IndexRequest, UpdateRequest, and BulkRequest.
WriteRequest.RefreshPolicy  
WriteRequestBuilder<B extends WriteRequestBuilder<B>>  
WriteResponse
Interface implemented by responses for actions that modify the documents in an index like IndexResponse, UpdateResponse, and BulkResponse.
WriteStateException
This exception is thrown when there is a problem of writing state to disk.
XContentElasticsearchExtension
SPI extensions for Elasticsearch-specific classes (like the Lucene or Joda dependency classes) that need to be encoded by XContentBuilder in a specific way.
XContentHelper  
XContentMapValues  
XContentParserUtils
A set of static methods to get XContentParser.Token from XContentParser while checking for their types and throw ParsingException if needed.
XIntervals
Replacement for Intervals.wildcard(BytesRef) and Intervals.prefix(BytesRef) until LUCENE-9050 is merged
XMoreLikeThis
Generate "more like this" similarity queries.
XQueryParser
This class is just a workaround to make QueryParserBase.handleBareFuzzy(String, Token, String) accessible by sub-classes.
XRejectedExecutionHandler  
XShapeCollection<S extends org.locationtech.spatial4j.shape.Shape>
Extends spatial4j ShapeCollection for points_only shape indexing support
ZenDiscovery  
ZenDiscovery.RejoinClusterRequest  
ZenPing  
ZenPing.PingCollection
a utility collection of pings where only the most recent ping is stored per node
ZenPing.PingResponse