A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _
All Classes All Packages
All Classes All Packages
A
- abort(String, Exception) - Method in class org.elasticsearch.action.bulk.BulkItemRequest
-
Abort this request, and store a
BulkItemResponse.Failure
response. - ABORTED - org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- ABORTED - org.elasticsearch.cluster.SnapshotsInProgress.State
- ABORTED - org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Snapshot aborted
- ABORTED_BY_USER_MSG - Static variable in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- abortIfNotCompleted(String) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- abortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Set whether or not version conflicts cause the action to abort.
- abortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequestBuilder
- abortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequestBuilder
- abortRelocationHandoff() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Fails a relocation handoff attempt.
- absoluteTimeInMillis() - Method in class org.elasticsearch.threadpool.ThreadPool
-
Returns the value of milliseconds since UNIX epoch.
- AbstractAggregationBuilder<AB extends AbstractAggregationBuilder<AB>> - Class in org.elasticsearch.search.aggregations
-
Base implementation of a
AggregationBuilder
. - AbstractAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Constructs a new aggregation builder.
- AbstractAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Read from a stream.
- AbstractAggregationBuilder(AbstractAggregationBuilder<AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- AbstractAllocateAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Abstract base class for allocating an unassigned shard to a node
- AbstractAllocateAllocationCommand(String, int, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- AbstractAllocateAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Read from a stream.
- AbstractAllocateAllocationCommand.Builder<T extends AbstractAllocateAllocationCommand> - Class in org.elasticsearch.cluster.routing.allocation.command
-
Works around ObjectParser not supporting constructor arguments.
- AbstractAllocationDecision - Class in org.elasticsearch.cluster.routing.allocation
-
An abstract class for representing various types of allocation decisions.
- AbstractAllocationDecision(DiscoveryNode, List<NodeAllocationResult>) - Constructor for class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- AbstractAllocationDecision(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- AbstractAsyncTask - Class in org.elasticsearch.common.util.concurrent
-
A base class for tasks that need to repeat.
- AbstractAsyncTask(Logger, ThreadPool, TimeValue, boolean) - Constructor for class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- AbstractAtomicGeoPointFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractAtomicGeoPointFieldData() - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractAtomicGeoPointFieldData
- AbstractAtomicOrdinalsFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractAtomicOrdinalsFieldData(Function<SortedSetDocValues, ScriptDocValues<?>>) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractAtomicOrdinalsFieldData
- AbstractBinaryDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractBinaryDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractBinaryDocValues
- AbstractBindingBuilder<T> - Class in org.elasticsearch.common.inject.internal
-
Bind a value or constant.
- AbstractBindingBuilder(Binder, List<Element>, Object, Key<T>) - Constructor for class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- AbstractBlobContainer - Class in org.elasticsearch.common.blobstore.support
-
A base abstract blob container that implements higher level container methods.
- AbstractBlobContainer(BlobPath) - Constructor for class org.elasticsearch.common.blobstore.support.AbstractBlobContainer
- AbstractBulkByScrollRequest<Self extends AbstractBulkByScrollRequest<Self>> - Class in org.elasticsearch.index.reindex
- AbstractBulkByScrollRequest(SearchRequest, boolean) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Constructor for actual use.
- AbstractBulkByScrollRequest(StreamInput) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- AbstractBulkByScrollRequestBuilder<Request extends AbstractBulkByScrollRequest<Request>,Self extends AbstractBulkByScrollRequestBuilder<Request,Self>> - Class in org.elasticsearch.index.reindex
- AbstractBulkByScrollRequestBuilder(ElasticsearchClient, ActionType<BulkByScrollResponse>, SearchRequestBuilder, Request) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
- AbstractBulkIndexByScrollRequest<Self extends AbstractBulkIndexByScrollRequest<Self>> - Class in org.elasticsearch.index.reindex
- AbstractBulkIndexByScrollRequest(SearchRequest, boolean) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
-
Constructor for actual use.
- AbstractBulkIndexByScrollRequest(StreamInput) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
- AbstractBulkIndexByScrollRequestBuilder<Request extends AbstractBulkIndexByScrollRequest<Request>,Self extends AbstractBulkIndexByScrollRequestBuilder<Request,Self>> - Class in org.elasticsearch.index.reindex
- AbstractBulkIndexByScrollRequestBuilder(ElasticsearchClient, ActionType<BulkByScrollResponse>, SearchRequestBuilder, Request) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequestBuilder
- AbstractCatAction - Class in org.elasticsearch.rest.action.cat
- AbstractCatAction() - Constructor for class org.elasticsearch.rest.action.cat.AbstractCatAction
- AbstractCharFilterFactory - Class in org.elasticsearch.index.analysis
- AbstractCharFilterFactory(IndexSettings, String) - Constructor for class org.elasticsearch.index.analysis.AbstractCharFilterFactory
- AbstractClient - Class in org.elasticsearch.client.support
- AbstractClient(Settings, ThreadPool) - Constructor for class org.elasticsearch.client.support.AbstractClient
- AbstractDiffable<T extends Diffable<T>> - Class in org.elasticsearch.cluster
-
Abstract diffable object with simple diffs implementation that sends the entire object if object has changed or nothing is object remained the same.
- AbstractDiffable() - Constructor for class org.elasticsearch.cluster.AbstractDiffable
- AbstractDistanceScoreFunction(double, double, double, DecayFunction, MultiValueMode) - Constructor for class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- AbstractGeometryFieldMapper<Parsed,Processed> - Class in org.elasticsearch.index.mapper
-
Base class for
GeoShapeFieldMapper
andLegacyGeoShapeFieldMapper
- AbstractGeometryFieldMapper(String, MappedFieldType, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, Explicit<Boolean>, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- AbstractGeometryFieldMapper.AbstractGeometryFieldType<Parsed,Processed> - Class in org.elasticsearch.index.mapper
- AbstractGeometryFieldMapper.Builder<T extends AbstractGeometryFieldMapper.Builder,Y extends AbstractGeometryFieldMapper> - Class in org.elasticsearch.index.mapper
- AbstractGeometryFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- AbstractGeometryFieldMapper.Indexer<Parsed,Processed> - Interface in org.elasticsearch.index.mapper
-
Interface representing an preprocessor in geo-shape indexing pipeline
- AbstractGeometryFieldMapper.Names - Class in org.elasticsearch.index.mapper
- AbstractGeometryFieldMapper.Parser<Parsed> - Interface in org.elasticsearch.index.mapper
-
interface representing parser in geo shape indexing pipeline
- AbstractGeometryFieldMapper.QueryProcessor - Interface in org.elasticsearch.index.mapper
-
interface representing a query builder that generates a query from the given shape
- AbstractGeometryFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- AbstractGeometryFieldType() - Constructor for class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
- AbstractGeometryFieldType(AbstractGeometryFieldMapper.AbstractGeometryFieldType) - Constructor for class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
- AbstractGeometryQueryBuilder<QB extends AbstractGeometryQueryBuilder<QB>> - Class in org.elasticsearch.index.query
-
Base
QueryBuilder
that builds a Geometry Query - AbstractGeometryQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Creates a new ShapeQueryBuilder whose Query will be against the given field name and will use the Shape found with the given ID
- AbstractGeometryQueryBuilder(String, String, String) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Deprecated.use
AbstractGeometryQueryBuilder(String, String)
instead - AbstractGeometryQueryBuilder(String, Supplier<Geometry>, String, String) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- AbstractGeometryQueryBuilder(String, ShapeBuilder) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Deprecated.use
AbstractGeometryQueryBuilder(String, Geometry)
instead - AbstractGeometryQueryBuilder(String, Geometry) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Creates a new AbstractGeometryQueryBuilder whose Query will be against the given field name using the given Shape
- AbstractGeometryQueryBuilder(String, Geometry, String, String) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- AbstractGeometryQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Read from a stream.
- AbstractGeometryQueryBuilder.ParsedGeometryQueryParams - Class in org.elasticsearch.index.query
-
local class that encapsulates xcontent parsed shape parameters
- AbstractHighlighterBuilder<HB extends AbstractHighlighterBuilder<?>> - Class in org.elasticsearch.search.fetch.subphase.highlight
-
This abstract class holds parameters shared by
HighlightBuilder
andHighlightBuilder.Field
and provides the common setters, equality, hashCode calculation and common serialization - AbstractHighlighterBuilder() - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- AbstractHighlighterBuilder(StreamInput) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Read from a stream.
- AbstractHighlighterBuilder(AbstractHighlighterBuilder<?>, QueryBuilder) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- AbstractHttpServerTransport - Class in org.elasticsearch.http
- AbstractHttpServerTransport(Settings, NetworkService, BigArrays, ThreadPool, NamedXContentRegistry, HttpServerTransport.Dispatcher) - Constructor for class org.elasticsearch.http.AbstractHttpServerTransport
- AbstractIndexAnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer> - Class in org.elasticsearch.index.analysis
- AbstractIndexAnalyzerProvider(IndexSettings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.AbstractIndexAnalyzerProvider
-
Constructs a new analyzer component, with the index name and its settings and the analyzer name.
- AbstractIndexComponent - Class in org.elasticsearch.index
- AbstractIndexComponent(IndexSettings) - Constructor for class org.elasticsearch.index.AbstractIndexComponent
-
Constructs a new index component, with the index name and its settings.
- AbstractIndexFieldData<FD extends AtomicFieldData> - Class in org.elasticsearch.index.fielddata.plain
- AbstractIndexFieldData(IndexSettings, String, IndexFieldDataCache) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData
- AbstractIndexFieldData.PerValueEstimator - Interface in org.elasticsearch.index.fielddata.plain
-
A
PerValueEstimator
is a sub-class that can be used to estimate the memory overhead for loading the data. - AbstractIndexOrdinalsFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractIndexOrdinalsFieldData(IndexSettings, String, IndexFieldDataCache, CircuitBreakerService, double, double, int) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- AbstractIndexShardComponent - Class in org.elasticsearch.index.shard
- AbstractIndexShardComponent(ShardId, IndexSettings) - Constructor for class org.elasticsearch.index.shard.AbstractIndexShardComponent
- AbstractInternalProfileTree<PB extends AbstractProfileBreakdown<?>,E> - Class in org.elasticsearch.search.profile
- AbstractInternalProfileTree() - Constructor for class org.elasticsearch.search.profile.AbstractInternalProfileTree
- AbstractLatLonPointDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractLatLonPointDVIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
- AbstractLatLonPointDVIndexFieldData.LatLonPointDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractLifecycleComponent - Class in org.elasticsearch.common.component
- AbstractLifecycleComponent() - Constructor for class org.elasticsearch.common.component.AbstractLifecycleComponent
- AbstractLifecycleRunnable - Class in org.elasticsearch.common.util.concurrent
-
AbstractLifecycleRunnable
is a service-lifecycle awareAbstractRunnable
. - AbstractLifecycleRunnable(Lifecycle, Logger) - Constructor for class org.elasticsearch.common.util.concurrent.AbstractLifecycleRunnable
-
AbstractLifecycleRunnable
must be aware of the actuallifecycle
to react properly. - AbstractMatcher<T> - Class in org.elasticsearch.common.inject.matcher
-
Implements
and()
andor()
. - AbstractMatcher() - Constructor for class org.elasticsearch.common.inject.matcher.AbstractMatcher
- AbstractModelParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.MovAvgModel.AbstractModelParser
- AbstractModule - Class in org.elasticsearch.common.inject
-
A support class for
Module
s which reduces repetition and results in a more readable configuration. - AbstractModule() - Constructor for class org.elasticsearch.common.inject.AbstractModule
- AbstractNamedDiffable<T extends NamedDiffable<T>> - Class in org.elasticsearch.cluster
-
Abstract diffable object with simple diffs implementation that sends the entire object if object has changed or nothing is object remained the same.
- AbstractNamedDiffable() - Constructor for class org.elasticsearch.cluster.AbstractNamedDiffable
- AbstractNumericDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractNumericDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractNumericDocValues
- AbstractPipelineAggregationBuilder<PAB extends AbstractPipelineAggregationBuilder<PAB>> - Class in org.elasticsearch.search.aggregations.pipeline
-
Base implementation of a
PipelineAggregationBuilder
. - AbstractPipelineAggregationBuilder(String, String, String[]) - Constructor for class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- AbstractPipelineAggregationBuilder(StreamInput, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
-
Read from a stream.
- AbstractProcessor - Class in org.elasticsearch.ingest
-
An Abstract Processor that holds a processorTag field to be used by other processors.
- AbstractProcessor(String) - Constructor for class org.elasticsearch.ingest.AbstractProcessor
- AbstractProfileBreakdown<T extends java.lang.Enum<T>> - Class in org.elasticsearch.search.profile
-
A record of timings for the various operations that may happen during query execution.
- AbstractProfileBreakdown(Class<T>) - Constructor for class org.elasticsearch.search.profile.AbstractProfileBreakdown
-
Sole constructor.
- AbstractProfiler<PB extends AbstractProfileBreakdown<?>,E> - Class in org.elasticsearch.search.profile
- AbstractProfiler(AbstractInternalProfileTree<PB, E>) - Constructor for class org.elasticsearch.search.profile.AbstractProfiler
- AbstractQueryBuilder<QB extends AbstractQueryBuilder<QB>> - Class in org.elasticsearch.index.query
-
Base class for all classes producing lucene queries.
- AbstractQueryBuilder() - Constructor for class org.elasticsearch.index.query.AbstractQueryBuilder
- AbstractQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.AbstractQueryBuilder
- AbstractRangeAggregatorFactory<R extends RangeAggregator.Range> - Class in org.elasticsearch.search.aggregations.bucket.range
- AbstractRangeAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, R[], boolean, InternalRange.Factory<?, ?>, QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeAggregatorFactory
- AbstractRangeBuilder<AB extends AbstractRangeBuilder<AB,R>,R extends RangeAggregator.Range> - Class in org.elasticsearch.search.aggregations.bucket.range
- AbstractRangeBuilder(String, InternalRange.Factory<?, ?>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- AbstractRangeBuilder(StreamInput, InternalRange.Factory<?, ?>, Writeable.Reader<R>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
-
Read from a stream.
- AbstractRangeBuilder(AbstractRangeBuilder<AB, R>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- AbstractRareTermsAggregator<T extends ValuesSource,U extends IncludeExclude.Filter,V> - Class in org.elasticsearch.search.aggregations.bucket.terms
- AbstractRecyclerC<T> - Class in org.elasticsearch.common.recycler
- AbstractRecyclerC() - Constructor for class org.elasticsearch.common.recycler.AbstractRecyclerC
- AbstractResourceWatcher<Listener> - Class in org.elasticsearch.watcher
-
Abstract resource watcher framework, which handles adding and removing listeners and calling resource observer.
- AbstractResourceWatcher() - Constructor for class org.elasticsearch.watcher.AbstractResourceWatcher
- AbstractRestChannel - Class in org.elasticsearch.rest
- AbstractRestChannel(RestRequest, boolean) - Constructor for class org.elasticsearch.rest.AbstractRestChannel
-
Construct a channel for handling the request.
- AbstractRoutingChangesObserver() - Constructor for class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- AbstractRunnable - Class in org.elasticsearch.common.util.concurrent
-
An extension to runnable.
- AbstractRunnable() - Constructor for class org.elasticsearch.common.util.concurrent.AbstractRunnable
- AbstractScopedSettings - Class in org.elasticsearch.common.settings
-
A basic setting service that can be used for per-index and per-cluster settings.
- AbstractScopedSettings(Settings, Set<Setting<?>>, Set<SettingUpgrader<?>>, Setting.Property) - Constructor for class org.elasticsearch.common.settings.AbstractScopedSettings
- AbstractScopedSettings(Settings, Settings, AbstractScopedSettings) - Constructor for class org.elasticsearch.common.settings.AbstractScopedSettings
- AbstractScopedSettings.SettingUpdater<T> - Interface in org.elasticsearch.common.settings
-
Transactional interface to update settings.
- AbstractSortedDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractSortedDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractSortedDocValues
- AbstractSortedNumericDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractSortedNumericDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractSortedNumericDocValues
- AbstractSortedSetDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractSortedSetDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractSortedSetDocValues
- AbstractSortingNumericDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractSortingNumericDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractSortingNumericDocValues
- AbstractTokenFilterFactory - Class in org.elasticsearch.index.analysis
- AbstractTokenFilterFactory(IndexSettings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.AbstractTokenFilterFactory
- AbstractTokenizerFactory - Class in org.elasticsearch.index.analysis
- AbstractTokenizerFactory(IndexSettings, Settings, String) - Constructor for class org.elasticsearch.index.analysis.AbstractTokenizerFactory
- accept() - Method in class org.apache.lucene.analysis.miscellaneous.DeDuplicatingTokenFilter
- accept(int) - Method in class org.elasticsearch.search.aggregations.MultiBucketConsumerService.MultiBucketConsumer
- accept(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.LongFilter
- accept(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.PartitionedLongFilter
- accept(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.SetBackedLongFilter
- accept(long, Exception) - Method in interface org.elasticsearch.index.shard.GlobalCheckpointListeners.GlobalCheckpointListener
-
Callback when the global checkpoint is updated or the shard is closed.
- accept(BytesRef) - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
-
Always accept the term.
- accept(BytesRef) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.StringFilter
- accept(T) - Method in interface org.elasticsearch.common.CheckedConsumer
- accept(T, U) - Method in interface org.elasticsearch.common.CheckedBiConsumer
- acceptDataLoss - Variable in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
- acceptDataLoss - Variable in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand.Builder
- acceptDataLoss() - Method in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
-
The operation only executes if the user explicitly agrees to possible data loss
- ACCEPTED - org.elasticsearch.rest.RestStatus
-
The request has been accepted for processing, but the processing has not been completed.
- acceptedGlobalOrdinals - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- acceptedGlobalOrdinals(SortedSetDocValues) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.OrdinalsFilter
- acceptIncomingRequests() - Method in class org.elasticsearch.transport.TransportService
-
start accepting incoming requests.
- acceptScopingVisitor(BindingScopingVisitor<V>) - Method in interface org.elasticsearch.common.inject.Binding
-
Accepts a scoping visitor.
- acceptScopingVisitor(BindingScopingVisitor<V>) - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in interface org.elasticsearch.common.inject.Binding
-
Accepts a target visitor.
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- acceptVisitor(BindingScopingVisitor<V>) - Method in class org.elasticsearch.common.inject.internal.Scoping
- acceptVisitor(ElementVisitor<R>) - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- acceptVisitor(ElementVisitor<T>) - Method in interface org.elasticsearch.common.inject.spi.Element
-
Accepts an element visitor.
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.Message
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.ScopeBinding
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.StaticInjectionRequest
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.TypeConverterBinding
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.TypeListenerBinding
- acceptVisitor(ElementVisitor<V>) - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class org.elasticsearch.http.CorsHandler
- ACCESS_CONTROL_REQUEST_METHOD - Static variable in class org.elasticsearch.http.CorsHandler
- accessed(long) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- accessed(long) - Method in class org.elasticsearch.search.internal.SearchContext
- accessed(long) - Method in class org.elasticsearch.search.internal.SubSearchContext
- ACCOUNTING - Static variable in interface org.elasticsearch.common.breaker.CircuitBreaker
-
The accounting breaker tracks things held in memory that is independent of the request lifecycle.
- ACCOUNTING_CIRCUIT_BREAKER_LIMIT_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- ACCOUNTING_CIRCUIT_BREAKER_OVERHEAD_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- ACCOUNTING_CIRCUIT_BREAKER_TYPE_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- accuracy() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- accuracy() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the accuracy setting.
- accuracy(float) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- accuracy(float) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets how similar the suggested terms at least need to be compared to the original suggest text tokens.
- accuracy(float) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
s how similar the suggested terms at least need to be compared to the original suggest text tokens.
- ACCURACY_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- AckClusterStatePublishResponseHandler - Class in org.elasticsearch.discovery
-
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 - AckClusterStatePublishResponseHandler(Set<DiscoveryNode>, ClusterStatePublisher.AckListener) - Constructor for class org.elasticsearch.discovery.AckClusterStatePublishResponseHandler
-
Creates a new AckClusterStatePublishResponseHandler
- AckedClusterStateTaskListener - Interface in org.elasticsearch.cluster
- AckedClusterStateUpdateTask<Response> - Class in org.elasticsearch.cluster
-
An extension interface to
ClusterStateUpdateTask
that allows to be notified when all the nodes have acknowledged a cluster state update request - AckedClusterStateUpdateTask(AckedRequest, ActionListener<Response>) - Constructor for class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- AckedClusterStateUpdateTask(Priority, AckedRequest, ActionListener<Response>) - Constructor for class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- AckedRequest - Interface in org.elasticsearch.cluster.ack
-
Identifies a cluster state update request with acknowledgement support
- acknowledged - Variable in class org.elasticsearch.action.support.master.AcknowledgedResponse
- acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutResponse
- acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.RemoveResponse
- AcknowledgedRequest<Request extends MasterNodeRequest<Request>> - Class in org.elasticsearch.action.support.master
-
Abstract class that allows to mark action requests that support acknowledgements.
- AcknowledgedRequest() - Constructor for class org.elasticsearch.action.support.master.AcknowledgedRequest
- AcknowledgedRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedRequest
- AcknowledgedRequestBuilder<Request extends AcknowledgedRequest<Request>,Response extends AcknowledgedResponse,RequestBuilder extends AcknowledgedRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.master
-
Base request builder for master node operations that support acknowledgements
- AcknowledgedRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedRequestBuilder
- AcknowledgedResponse - Class in org.elasticsearch.action.support.master
-
A response that indicates that a request has been acknowledged
- AcknowledgedResponse(boolean) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
- AcknowledgedResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
- AcknowledgedResponse(StreamInput, boolean) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
- ackTimeout() - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
- ackTimeout() - Method in interface org.elasticsearch.cluster.ack.AckedRequest
-
Returns the acknowledgement timeout
- ackTimeout() - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
-
Returns the maximum time interval to wait for acknowledgements
- ackTimeout() - Method in interface org.elasticsearch.cluster.AckedClusterStateTaskListener
-
Acknowledgement timeout, maximum time interval to wait for acknowledgements
- ackTimeout() - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
-
Acknowledgement timeout, maximum time interval to wait for acknowledgements
- ackTimeout(TimeValue) - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
-
Sets the acknowledgement timeout
- acquire() - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
- acquire(T) - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
-
Acquires a lock for the given key.
- acquireAllPrimaryOperationsPermits(ActionListener<Releasable>, TimeValue) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire all primary operation permits.
- acquireAllReplicaOperationsPermits(long, long, long, ActionListener<Releasable>, TimeValue) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire all replica operation permits whenever the shard is ready for indexing (see
IndexShard.acquireAllPrimaryOperationsPermits(ActionListener, TimeValue)
. - acquireFSLockForPaths(IndexSettings, Path...) - Static method in class org.elasticsearch.env.NodeEnvironment
-
Acquires, then releases, all
write.lock
files in the given shard paths. - acquireHistoryRetentionLock(Engine.HistorySource) - Method in class org.elasticsearch.index.engine.Engine
-
Acquires a lock on the translog files and Lucene soft-deleted documents to prevent them from being trimmed
- acquireHistoryRetentionLock(Engine.HistorySource) - Method in class org.elasticsearch.index.engine.InternalEngine
- acquireHistoryRetentionLock(Engine.HistorySource) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- acquireHistoryRetentionLock(Engine.HistorySource) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquires a lock on the translog files and Lucene soft-deleted documents to prevent them from being trimmed
- acquireLastIndexCommit(boolean) - Method in class org.elasticsearch.index.engine.Engine
-
Snapshots the most recent index and returns a handle to it.
- acquireLastIndexCommit(boolean) - Method in class org.elasticsearch.index.engine.InternalEngine
- acquireLastIndexCommit(boolean) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- acquireLastIndexCommit(boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
Creates a new
IndexCommit
snapshot from the currently running engine. - acquirePrimaryOperationPermit(ActionListener<Releasable>, String, Object) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire a primary operation permit whenever the shard is ready for indexing.
- acquirePrimaryOperationPermit(IndexShard, TransportVerifyShardBeforeCloseAction.ShardRequest, ActionListener<Releasable>) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- acquirePrimaryOperationPermit(IndexShard, Request, ActionListener<Releasable>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Executes the logic for acquiring one or more operation permit on a primary shard.
- acquireReplicaOperationPermit(long, long, long, ActionListener<Releasable>, String, Object) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire a replica operation permit whenever the shard is ready for indexing (see
IndexShard.acquirePrimaryOperationPermit(ActionListener, String, Object)
). - acquireReplicaOperationPermit(IndexShard, TransportVerifyShardBeforeCloseAction.ShardRequest, ActionListener<Releasable>, long, long, long) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- acquireReplicaOperationPermit(IndexShard, ReplicaRequest, ActionListener<Releasable>, long, long, long) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Executes the logic for acquiring one or more operation permit on a replica shard.
- acquireRetentionLock() - Method in class org.elasticsearch.index.translog.Translog
-
Acquires a lock on the translog files, preventing them from being trimmed
- acquireSafeIndexCommit() - Method in class org.elasticsearch.index.engine.Engine
-
Snapshots the most recent safe index commit from the engine.
- acquireSafeIndexCommit() - Method in class org.elasticsearch.index.engine.InternalEngine
- acquireSafeIndexCommit() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- acquireSafeIndexCommit() - Method in class org.elasticsearch.index.shard.IndexShard
-
Snapshots the most recent safe index commit from the currently running engine.
- acquireSearcher(String) - Method in class org.elasticsearch.index.engine.Engine
-
Returns a new searcher instance.
- acquireSearcher(String) - Method in class org.elasticsearch.index.shard.IndexShard
- acquireSearcher(String, Engine.SearcherScope) - Method in class org.elasticsearch.index.engine.Engine
-
Returns a new searcher instance.
- acquireSearcherNoWrap(String) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire the searcher without applying the additional reader wrapper.
- acquireThrottle() - Method in class org.elasticsearch.index.engine.Engine.IndexThrottle
- action - Variable in class org.elasticsearch.action.ActionRequestBuilder
- action() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
- action() - Method in exception org.elasticsearch.transport.ActionNotFoundTransportException
- action() - Method in exception org.elasticsearch.transport.ActionTransportException
-
The action to invoke.
- action() - Method in class org.elasticsearch.transport.Transport.ResponseContext
- ACTION_NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- ACTION_NAME - Static variable in class org.elasticsearch.action.bulk.TransportShardBulkAction
- ACTION_NAME - Static variable in class org.elasticsearch.cluster.action.index.NodeMappingRefreshAction
- ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.UnicastZenPing
- ACTION_NAME - Static variable in class org.elasticsearch.gateway.LocalAllocateDangledIndices
- ACTION_NAME - Static variable in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- ACTION_NAME - Static variable in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Add
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Renew
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- ACTION_NAME - Static variable in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData
- ACTION_NAME - Static variable in class org.elasticsearch.repositories.VerifyNodeRepositoryAction
- ACTION_ORIGIN_TRANSIENT_NAME - Static variable in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Name for the
origin
attribute. - ACTION_SHARD_EXISTS - Static variable in class org.elasticsearch.indices.store.IndicesStore
- ActionFilter - Interface in org.elasticsearch.action.support
-
A filter allowing to filter transport actions
- ActionFilter.Simple - Class in org.elasticsearch.action.support
-
A simple base class for injectable action filters that spares the implementation from handling the filter chain.
- ActionFilterChain<Request extends ActionRequest,Response extends ActionResponse> - Interface in org.elasticsearch.action.support
-
A filter chain allowing to continue and process the transport action request
- ActionFilters - Class in org.elasticsearch.action.support
-
Holds the action filters injected through plugins, properly sorted by
ActionFilter.order()
- ActionFilters(Set<ActionFilter>) - Constructor for class org.elasticsearch.action.support.ActionFilters
- ActionFuture<T> - Interface in org.elasticsearch.action
-
An extension to
Future
allowing for simplified "get" operations. - actionGet() - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get()
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet() - Method in class org.elasticsearch.action.support.AdapterActionFuture
- actionGet(long) - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get(long, java.util.concurrent.TimeUnit)
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet(long) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- actionGet(long, TimeUnit) - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get(long, java.util.concurrent.TimeUnit)
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet(long, TimeUnit) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- actionGet(String) - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get(long, java.util.concurrent.TimeUnit)
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet(String) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- actionGet(TimeValue) - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get(long, java.util.concurrent.TimeUnit)
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet(TimeValue) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- ActionHandler(ActionType<Response>, Class<? extends TransportAction<Request, Response>>, Class<?>...) - Constructor for class org.elasticsearch.plugins.ActionPlugin.ActionHandler
-
Create a record of an action, the TransportAction that handles it, and any supporting TransportActions that are needed by that TransportAction.
- ActionListener<Response> - Interface in org.elasticsearch.action
-
A listener for action responses or failures.
- ActionListenerResponseHandler<Response extends TransportResponse> - Class in org.elasticsearch.action
-
A simple base class for action response listeners, defaulting to using the SAME executor (as its very common on response handlers).
- ActionListenerResponseHandler(ActionListener<? super Response>, Writeable.Reader<Response>) - Constructor for class org.elasticsearch.action.ActionListenerResponseHandler
- ActionListenerResponseHandler(ActionListener<? super Response>, Writeable.Reader<Response>, String) - Constructor for class org.elasticsearch.action.ActionListenerResponseHandler
- ActionModule - Class in org.elasticsearch.action
-
Builds and binds the generic action map, all
TransportAction
s, andActionFilters
. - ActionModule(boolean, Settings, IndexNameExpressionResolver, IndexScopedSettings, ClusterSettings, SettingsFilter, ThreadPool, List<ActionPlugin>, NodeClient, CircuitBreakerService, UsageService, ClusterService) - Constructor for class org.elasticsearch.action.ActionModule
- actionName - Variable in class org.elasticsearch.action.support.TransportAction
- ActionNotFoundTransportException - Exception in org.elasticsearch.transport
-
An exception indicating that a transport action was not found.
- ActionNotFoundTransportException(String) - Constructor for exception org.elasticsearch.transport.ActionNotFoundTransportException
- ActionNotFoundTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.ActionNotFoundTransportException
- ActionPlugin - Interface in org.elasticsearch.plugins
-
An additional extension point for
Plugin
s that extends Elasticsearch's scripting functionality. - ActionPlugin.ActionHandler<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.plugins
- ActionRequest - Class in org.elasticsearch.action
- ActionRequest() - Constructor for class org.elasticsearch.action.ActionRequest
- ActionRequest(StreamInput) - Constructor for class org.elasticsearch.action.ActionRequest
- ActionRequestBuilder<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.action
- ActionRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.ActionRequestBuilder
- ActionRequestValidationException - Exception in org.elasticsearch.action
- ActionRequestValidationException() - Constructor for exception org.elasticsearch.action.ActionRequestValidationException
- ActionResponse - Class in org.elasticsearch.action
-
Base class for responses to action requests.
- ActionResponse() - Constructor for class org.elasticsearch.action.ActionResponse
- ActionResponse(StreamInput) - Constructor for class org.elasticsearch.action.ActionResponse
- ActionRunnable<Response> - Class in org.elasticsearch.action
-
Base class for
Runnable
s that need to callActionListener.onFailure(Exception)
in case an uncaught exception or error is thrown while the actual action is run. - ActionRunnable(ActionListener<Response>) - Constructor for class org.elasticsearch.action.ActionRunnable
- actions() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesClusterStateUpdateRequest
-
Returns the alias actions to be performed
- Actions() - Constructor for class org.elasticsearch.indices.recovery.PeerRecoverySourceService.Actions
- Actions() - Constructor for class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- ActionTransportException - Exception in org.elasticsearch.transport
-
An action invocation failure.
- ActionTransportException(String, TransportAddress, String, String, Throwable) - Constructor for exception org.elasticsearch.transport.ActionTransportException
- ActionTransportException(String, TransportAddress, String, Throwable) - Constructor for exception org.elasticsearch.transport.ActionTransportException
- ActionTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.ActionTransportException
- actionType() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Type of the action to perform.
- ActionType<Response extends ActionResponse> - Class in org.elasticsearch.action
-
A generic action.
- ActionType(String, Writeable.Reader<Response>) - Constructor for class org.elasticsearch.action.ActionType
- activate() - Method in class org.elasticsearch.index.engine.Engine.IndexThrottle
-
Activate throttling, which switches the lock to be a real lock
- activate(Optional<DiscoveryNode>, ClusterState) - Method in class org.elasticsearch.cluster.coordination.DiscoveryUpgradeService
- activate(DiscoveryNodes) - Method in class org.elasticsearch.discovery.PeerFinder
- activatePrimaryMode(long) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Initializes the global checkpoint tracker in primary mode (see
ReplicationTracker.primaryMode
. - activateThrottling() - Method in class org.elasticsearch.index.engine.Engine
-
Request that this engine throttle incoming indexing requests to one thread.
- activateThrottling() - Method in class org.elasticsearch.index.engine.InternalEngine
- activateThrottling() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- activateThrottling() - Method in class org.elasticsearch.index.shard.IndexShard
- activateThrottling(IndexShard) - Method in class org.elasticsearch.indices.IndexingMemoryController
-
Asks this shard to throttle indexing to one thread
- activateWithPrimaryContext(ReplicationTracker.PrimaryContext) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Activates the global checkpoint tracker in primary mode (see
ReplicationTracker.primaryMode
. - activateWithPrimaryContext(ReplicationTracker.PrimaryContext) - Method in class org.elasticsearch.index.shard.IndexShard
-
Updates the known allocation IDs and the local checkpoints for the corresponding allocations from a primary relocation source.
- active() - Method in class org.elasticsearch.cluster.routing.ShardRouting
- activeInitializingShardsIt(int) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns an iterator over active and initializing shards.
- activeInitializingShardsRandomIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns an iterator over active and initializing shards.
- activeInitializingShardsRankedIt(ResponseCollectorService, Map<String, Long>) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns an iterator over active and initializing shards, ordered by the adaptive replica selection formula.
- activeOnly() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
-
True if activeOnly flag is set, false otherwise.
- activeOnly(boolean) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
-
Set value of the activeOnly flag.
- activePrimary(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns the active primary shard for the given shard id or
null
if no primary is found or the primary is not active. - activePrimaryShardsGrouped(String[], boolean) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
All the *active* primary shards for the provided indices grouped (each group is a single element, consisting of the primary shard).
- activeReplicaWithHighestVersion(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns one active replica shard for the given shard id or
null
if no active replica is found. - ActiveShardCount - Class in org.elasticsearch.action.support
-
A class whose instances represent a value for counting the number of active shard copies for a given shard in an index.
- activeShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of active shards - ActiveShardsObserver - Class in org.elasticsearch.action.support
-
This class provides primitives for waiting for a configured number of shards to become active before sending a response on an
ActionListener
. - ActiveShardsObserver(ClusterService, ThreadPool) - Constructor for class org.elasticsearch.action.support.ActiveShardsObserver
- activityTimeout() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- actualSizeToRead() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- adaptAutoExpandReplicas(ClusterState) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Checks if the are replicas with the auto-expand feature that need to be adapted.
- AdapterActionFuture<T,L> - Class in org.elasticsearch.action.support
- AdapterActionFuture() - Constructor for class org.elasticsearch.action.support.AdapterActionFuture
- adaptiveSelection() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- adaptiveSelection(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should adaptiveSelection statistics be returned.
- AdaptiveSelectionStats - Class in org.elasticsearch.node
-
Class representing statistics about adaptive replica selection.
- AdaptiveSelectionStats(Map<String, Long>, Map<String, ResponseCollectorService.ComputedNodeStats>) - Constructor for class org.elasticsearch.node.AdaptiveSelectionStats
- AdaptiveSelectionStats(StreamInput) - Constructor for class org.elasticsearch.node.AdaptiveSelectionStats
- add() - Static method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Build a new
AliasAction
to add aliases. - add(byte[]) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.CustomBinaryDocValuesField
- add(byte[], int, int, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Deprecated.
- add(byte[], int, int, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Deprecated.
- add(byte[], int, int, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(byte[], int, int, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds a framed data in binary format
- add(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds a framed data in binary format
- add(int, GetResponse) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
- add(int, MultiGetResponse.Failure) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
- add(int, MultiTermVectorsResponse.Failure) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardResponse
- add(int, TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- add(int, TermVectorsResponse) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardResponse
- add(int, T) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
- add(long) - Method in class org.elasticsearch.common.util.LongHash
-
Try to add
key
. - add(long) - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
-
Add's the provided value to the set for tracking
- add(long, long) - Method in class org.elasticsearch.common.blobstore.DeleteResult
- add(long, long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- add(long, long, long) - Method in class org.elasticsearch.index.flush.FlushStats
- add(long, long, long) - Method in class org.elasticsearch.index.warmer.WarmerStats
- add(long, long, long, long, long, long, long, long, long, double) - Method in class org.elasticsearch.index.merge.MergeStats
- add(Iterable<DocWriteRequest<?>>) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a list of requests to be executed.
- add(String) - Method in class org.elasticsearch.common.blobstore.BlobPath
- add(String) - Method in class org.elasticsearch.index.mapper.ContentPath
- add(String) - Method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo.Builder
- add(String, Object) - Method in class org.elasticsearch.common.inject.internal.ToStringBuilder
- add(String, String) - Method in class org.elasticsearch.action.get.MultiGetRequest
- add(String, String, Iterable<String>) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- add(String, String, Iterable<String>) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
- add(String, String, String) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
Deprecated.Types are in the process of being removed, use
MultiGetRequest.add(String, String)
instead. - add(String, String, String) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- add(String, String, String) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- add(String, String, String...) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- add(String, String, String...) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
- add(String, String, String[], FetchSourceContext, String, XContentParser, boolean) - Method in class org.elasticsearch.action.get.MultiGetRequest
- add(IndexableField) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
- add(LeafReader) - Method in class org.elasticsearch.common.lucene.ShardCoreKeyMap
-
Register a
LeafReader
. - add(Term) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Add a single term at the next position in the phrase.
- add(Term[]) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Add multiple terms at the next position in the phrase.
- add(Term[], int) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Allows to specify the relative position of terms within the phrase.
- add(BytesRef) - Method in class org.elasticsearch.common.util.BytesRefHash
-
Sugar to
add(key, key.hashCode()
. - add(BytesRef) - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
-
Add's the provided value to the set for tracking
- add(BytesRef, int) - Method in class org.elasticsearch.common.util.BytesRefHash
-
Try to add
key
. - add(CommonStats) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- add(ShardStats) - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats.IndexStatsBuilder
- add(DeleteRequest) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds an
DeleteRequest
to the list of actions to execute. - add(DeleteRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds an
DeleteRequest
to the list of actions to execute. - add(DeleteRequest) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
DeleteRequest
to the list of actions to execute. - add(DeleteRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
DeleteRequest
to the list of actions to execute. - add(DocWriteRequest<?>) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds either a delete or an index request.
- add(DocWriteRequest<?>) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Add a request to the current BulkRequest.
- add(DocWriteRequest<?>...) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a list of requests to be executed.
- add(MultiGetRequest.Item) - Method in class org.elasticsearch.action.get.MultiGetRequest
- add(MultiGetRequest.Item) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- add(IndexRequest) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds an
IndexRequest
to the list of actions to execute. - add(IndexRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds an
IndexRequest
to the list of actions to execute. - add(IndexRequest) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
IndexRequest
to the list of actions to execute. - add(IndexRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
IndexRequest
to the list of actions to execute. - add(SearchRequest) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
Add a search request to execute.
- add(SearchRequest) - Method in class org.elasticsearch.action.search.MultiSearchRequestBuilder
-
Add a search request to execute.
- add(SearchRequestBuilder) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
Add a search request to execute.
- add(SearchRequestBuilder) - Method in class org.elasticsearch.action.search.MultiSearchRequestBuilder
-
Add a search request to execute.
- add(TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- add(TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
- add(TermVectorsRequest, XContentParser) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- add(UpdateRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds an
UpdateRequest
to the list of actions to execute. - add(UpdateRequest) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
UpdateRequest
to the list of actions to execute. - add(UpdateRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
UpdateRequest
to the list of actions to execute. - add(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
-
adds a disco node to the builder.
- add(RestoreInProgress.Entry) - Method in class org.elasticsearch.cluster.RestoreInProgress.Builder
- add(AllocationCommand...) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Adds allocation commands to be applied to the cluster.
- add(AllocationCommand...) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
-
Adds allocation commands to be applied to the cluster.
- add(AllocationCommand...) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Adds a set of commands to this collection
- add(Decision) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
-
Add a decision to this
Decision.Multi
decision instance - add(RerouteExplanation) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
- add(IndexRoutingTable) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- add(IndexRoutingTable.Builder) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- add(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- add(DeleteResult) - Method in class org.elasticsearch.common.blobstore.DeleteResult
- add(BytesReference, long) - Method in class org.elasticsearch.index.translog.TranslogWriter
-
Add the given bytes to the translog with the specified sequence number; returns the location the bytes were written to.
- add(BytesReference, String, boolean, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(BytesReference, String, String, boolean, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Deprecated.
- add(BytesReference, String, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds the data from the bytes to be processed by the bulk processor
- add(BytesReference, String, String, String, FetchSourceContext, String, boolean, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
- add(BytesReference, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds the data from the bytes to be processed by the bulk processor
- add(BytesReference, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Deprecated.
- add(BytesReference, String, String, FetchSourceContext, String, boolean, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
- add(BytesReference, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(FieldMemoryStats) - Method in class org.elasticsearch.common.FieldMemoryStats
-
Adds / merges the given field memory stats into this stats instance
- add(Module...) - Method in class org.elasticsearch.common.inject.ModulesBuilder
- add(QueryCacheStats) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- add(RequestCacheStats) - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- add(SegmentsStats) - Method in class org.elasticsearch.index.engine.SegmentsStats
- add(FieldDataStats) - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- add(FlushStats) - Method in class org.elasticsearch.index.flush.FlushStats
- add(GetStats) - Method in class org.elasticsearch.index.get.GetStats
- add(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- add(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- add(MergeStats) - Method in class org.elasticsearch.index.merge.MergeStats
- add(QueryBuilder) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
-
Add a sub-query to this disjunction.
- add(RecoveryStats) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- add(RefreshStats) - Method in class org.elasticsearch.index.refresh.RefreshStats
- add(SearchStats) - Method in class org.elasticsearch.index.search.stats.SearchStats
- add(SearchStats.Stats) - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- add(DocsStats) - Method in class org.elasticsearch.index.shard.DocsStats
- add(IndexingStats) - Method in class org.elasticsearch.index.shard.IndexingStats
- add(IndexingStats.Stats) - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
- add(IndexingStats, boolean) - Method in class org.elasticsearch.index.shard.IndexingStats
- add(StoreStats) - Method in class org.elasticsearch.index.store.StoreStats
- add(Translog.Operation) - Method in class org.elasticsearch.index.translog.Translog
-
Adds an operation to the transaction log.
- add(TranslogStats) - Method in class org.elasticsearch.index.translog.TranslogStats
- add(WarmerStats) - Method in class org.elasticsearch.index.warmer.WarmerStats
- add(FsInfo.Path) - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- add(ScriptFieldsContext.ScriptField) - Method in class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext
- add(CompletionStats) - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- add(Transport.ResponseContext<? extends TransportResponse>) - Method in class org.elasticsearch.transport.Transport.ResponseHandlers
-
Adds a new response context and associates it with a new request ID.
- add(T) - Method in class org.elasticsearch.common.collect.EvictingQueue
-
Add the given element to the queue, possibly forcing an eviction from the head if
EvictingQueue.remainingCapacity()
is zero. - add(W) - Method in class org.elasticsearch.watcher.ResourceWatcherService
-
Register new resource watcher that will be checked in default
MEDIUM
frequency - add(W, ResourceWatcherService.Frequency) - Method in class org.elasticsearch.watcher.ResourceWatcherService
-
Register new resource watcher that will be checked in the given frequency
- Add(String, String, String, String, String, Boolean) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction.Add
-
Build the operation.
- ADD - org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
- addAdditionalFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource
-
to be overridden by subclasses
- addAdditionalFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- addAdditionalFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- addAffixGroupUpdateConsumer(List<Setting.AffixSetting<?>>, BiConsumer<String, Settings>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a affix settings consumer that accepts the settings for a group of settings.
- addAffixMapUpdateConsumer(Setting.AffixSetting<T>, Consumer<Map<String, T>>, BiConsumer<String, T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer for affix settings.
- addAffixUpdateConsumer(Setting.AffixSetting<A>, Setting.AffixSetting<B>, BiConsumer<String, Tuple<A, B>>, BiConsumer<String, Tuple<A, B>>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a affix settings consumer that accepts the values for two settings.
- addAffixUpdateConsumer(Setting.AffixSetting<T>, BiConsumer<String, T>, BiConsumer<String, T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer for affix settings.
- addAggregation(AggregationBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds an aggregation to the search operation.
- addAggregation(PipelineAggregationBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds an aggregation to the search operation.
- addAggregator(AggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- addAlias(String[], String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String[], String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String[], String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String[], String, QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, boolean) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(Alias) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds an alias that will be associated with the index when it gets created
- addAlias(Alias) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Adds an alias that will be added when the index template gets created.
- addAliasAction(IndicesAliasesRequest.AliasActions) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
-
Add the action to this request and validate it.
- addAliasAction(IndicesAliasesRequest.AliasActions) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias action to the request.
- addAliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
- addAll(Collection<? extends T>) - Method in class org.elasticsearch.common.collect.EvictingQueue
-
Add the given elements to the queue, possibly forcing evictions from the head if
EvictingQueue.remainingCapacity()
is zero or becomes zero during the execution of this method. - addAppender(Logger, Appender) - Static method in class org.elasticsearch.common.logging.Loggers
- addAsFromCloseToOpen(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsFromDangling(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsFromOpenToClose(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsNew(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsNewRestore(IndexMetaData, RecoverySource.SnapshotRecoverySource, IntSet) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsRecovery(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsRestore(IndexMetaData, RecoverySource.SnapshotRecoverySource) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addBinding() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a binding builder used to add a new element in the set.
- addBinding() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
- addBinding(K) - Method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a binding builder used to add a new entry in the map.
- addBinding(K) - Method in class org.elasticsearch.common.inject.multibindings.MapBinder.RealMapBinder
-
This creates two bindings.
- addBitsetMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addBlocks(IndexMetaData) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- addBootstrapSeed(KeyStoreWrapper) - Static method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Add the bootstrap seed setting, which may be used as a unique, secure, random value by the node
- addBuiltInJoinValidators(Collection<BiConsumer<DiscoveryNode, ClusterState>>) - Static method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor
- addByte(byte) - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
-
Add a byte to the sequence.
- addCandidateGenerator(PhraseSuggestionBuilder.CandidateGenerator) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Adds a
PhraseSuggestionBuilder.CandidateGenerator
to this suggester. - addCandidates(List<DirectCandidateGenerator.Candidate>) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.CandidateSet
- addCell(Object) - Method in class org.elasticsearch.common.Table
- addCell(Object, String) - Method in class org.elasticsearch.common.Table
- addCharFilter(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- addCharFilter(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Add a name of char filter that will be used before the tokenizer.
- addCharFilter(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- addCharFilter(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Add char filter setting that will be used on top of a tokenizer provided.
- addClause(SpanQueryBuilder) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
-
Add a span clause to the current list of clauses
- addClause(SpanQueryBuilder) - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
-
Add a span clause to the current list of clauses
- addCloseListener(ActionListener<Void>) - Method in interface org.elasticsearch.common.network.CloseableChannel
-
Adds a listener that will be executed when the channel is closed.
- addCloseListener(ActionListener<Void>) - Method in class org.elasticsearch.transport.CloseableConnection
- addCloseListener(ActionListener<Void>) - Method in interface org.elasticsearch.transport.Transport.Connection
-
The listener's
ActionListener.onResponse(Object)
method will be called when this connection is closed. - addConnectionListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.TransportService
- addConnections(int, TransportRequestOptions.Type...) - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Adds a number of connections for one or more types.
- addConnectListener(ActionListener<Void>) - Method in interface org.elasticsearch.transport.TcpChannel
-
Adds a listener that will be executed when the channel is connected.
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
Override in subclass to add custom fields following the common `_shards` field
- addDirectoryPath(Permissions, String, Path, String) - Static method in class org.elasticsearch.bootstrap.FilePermissionUtils
-
Add access to path (and all files underneath it); this also creates the directory if it does not exist.
- addDoc(int) - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Associates the given document id with the current ordinal.
- addDoc(ParseContext.Document) - Method in class org.elasticsearch.index.mapper.ParseContext
- addDoc(ParseContext.Document) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- addDocValueField(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a docvalue based field to load and return.
- addDocValueField(String) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Adds a field to load from doc values and return.
- addDocValueField(String, String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a docvalue based field to load and return.
- addDocValueField(String, String) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Adds a field to load from the docvalue and return.
- addDocValuesMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addDynamicMapper(Mapper) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Add a new mapper dynamically created while parsing.
- addDynamicMapper(Mapper) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- addDynamicMappingsUpdate(Mapping) - Method in class org.elasticsearch.index.mapper.ParsedDocument
- added() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- addedNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- addError(String, Object...) - Method in class org.elasticsearch.common.inject.AbstractModule
- addError(String, Object...) - Method in interface org.elasticsearch.common.inject.Binder
-
Records an error message which will be presented to the user at a later time.
- addError(String, Object...) - Method in class org.elasticsearch.common.inject.PrivateModule
- addError(String, Object...) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Records an error message for type
I
which will be presented to the user at a later time. - addError(Throwable) - Method in class org.elasticsearch.common.inject.AbstractModule
- addError(Throwable) - Method in interface org.elasticsearch.common.inject.Binder
-
Records an exception, the full details of which will be logged, and the message of which will be presented to the user at a later time.
- addError(Throwable) - Method in class org.elasticsearch.common.inject.PrivateModule
- addError(Throwable) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Records an exception for type
I
, the full details of which will be logged, and the message of which will be presented to the user at a later time. - addError(Message) - Method in class org.elasticsearch.common.inject.AbstractModule
- addError(Message) - Method in interface org.elasticsearch.common.inject.Binder
-
Records an error message to be presented to the user at a later time.
- addError(Message) - Method in class org.elasticsearch.common.inject.PrivateModule
- addError(Message) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Records an error message to be presented to the user at a later time.
- addEstimateBytesAndMaybeBreak(long, String) - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
-
Add a number of bytes, tripping the circuit breaker if the aggregated estimates are above the limit.
- addEstimateBytesAndMaybeBreak(long, String) - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
-
add bytes to the breaker and maybe trip
- addEstimateBytesAndMaybeBreak(long, String) - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- addExposureBuilder(ExposureBuilder<?>) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- addFeatures(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- addFeatures(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequestBuilder
- addField(ParseContext.Document, String, String, int, Map<String, Set<String>>) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
-
Adds a context-enabled field for all the defined mappings to
document
seeContextMappings.TypedContextField
- addFieldName(String) - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
-
Adds a field name
field
to the list of fields to load. - addFieldNames(List<String>) - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
-
Adds the field names
fieldNames
to the list of fields to load. - addFieldStringsFromParameter(TermVectorsRequest, String) - Static method in class org.elasticsearch.rest.action.document.RestTermVectorsAction
- addFileDetail(String, long, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addFileSizes(ImmutableOpenMap<String, Long>) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addFilterSettingParams(RestRequest) - Method in class org.elasticsearch.common.settings.SettingsFilter
- addForClosingShard(SearchStats.Stats) - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- addGlobalBlock(ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- addGlobalCheckpointListener(long, GlobalCheckpointListeners.GlobalCheckpointListener, TimeValue) - Method in class org.elasticsearch.index.shard.IndexShard
-
Add a global checkpoint listener.
- addGroup(TaskGroup.Builder) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup.Builder
- addHeader(String, String) - Method in interface org.elasticsearch.http.HttpResponse
- addHeader(String, String) - Method in class org.elasticsearch.rest.RestResponse
-
Add a custom header.
- addHeader(String, String...) - Method in exception org.elasticsearch.ElasticsearchException
-
Adds a new header with the given key.
- addHeader(String, List<String>) - Method in exception org.elasticsearch.ElasticsearchException
-
Adds a new header with the given key.
- addHighPriorityApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Adds a high priority applier of updated cluster states.
- addHighPriorityApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Adds a high priority applier of updated cluster states.
- addHumanReadableSettings(Settings) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
-
Adds human readable version and creation date settings.
- addIds(String...) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
-
Adds ids to the query.
- addIgnoredField(String) - Method in class org.elasticsearch.index.mapper.ParseContext
-
Add the given
field
to the set of ignored fields. - addIgnoredField(String) - Method in class org.elasticsearch.index.mapper.ParseContext.InternalParseContext
- addIgnoreShardForNode(ShardId, String) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- addIndexBlock(String, ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- addIndexBoost(String, float) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the boost a specific index will receive when the query is executed against it.
- addIndexEventListener(IndexEventListener) - Method in class org.elasticsearch.index.IndexModule
-
Adds an
IndexEventListener
for this index. - addIndexOperationListener(IndexingOperationListener) - Method in class org.elasticsearch.index.IndexModule
-
Adds an
IndexingOperationListener
for this index. - addIndexShard(IndexShardRoutingTable) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- addIndexShardCount(ClusterStatsIndices.ShardStats) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
- addIndexWriterMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addIndices(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
- addIndices(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
- addIndices(String...) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequestBuilder
- addIndices(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequestBuilder
- addIngestClusterStateListener(Consumer<ClusterState>) - Method in class org.elasticsearch.ingest.IngestService
-
Adds a listener that gets invoked with the current cluster state before processor factories get invoked.
- addInnerHitDefinition(InnerHitsContext.InnerHitSubContext) - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext
- additionalSettings() - Method in class org.elasticsearch.plugins.Plugin
-
Additional node settings loaded by the plugin.
- ADDITIVE - org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.SeasonalityType
- addJoinVote(Join) - Method in class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- addLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
- addLifecycleListener(LifecycleListener) - Method in interface org.elasticsearch.common.component.LifecycleComponent
- addLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.repositories.FilterRepository
- addListener() - Method in enum org.elasticsearch.action.ThreadingModel
- addListener(Consumer<ClusterInfo>) - Method in interface org.elasticsearch.cluster.ClusterInfoService
-
Add a listener for new cluster information
- addListener(Consumer<ClusterInfo>) - Method in class org.elasticsearch.cluster.EmptyClusterInfoService
- addListener(Consumer<ClusterInfo>) - Method in class org.elasticsearch.cluster.InternalClusterInfoService
- addListener(Listener) - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Registers new listener
- addListener(ActionListener<T>) - Method in interface org.elasticsearch.action.ListenableActionFuture
-
Add an action listener to be invoked when a response has received.
- addListener(ActionListener<T>) - Method in class org.elasticsearch.action.support.PlainListenableActionFuture
- addListener(ActionListener<V>, ExecutorService) - Method in class org.elasticsearch.common.util.concurrent.ListenableFuture
-
Adds a listener to this future.
- addListener(ActionListener<V>, ExecutorService, ThreadContext) - Method in class org.elasticsearch.common.util.concurrent.ListenableFuture
-
Adds a listener to this future.
- addListener(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Add a listener for updated cluster states
- addListener(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Add a listener for updated cluster states
- addListener(MasterFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- addListener(NodesFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
- addListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.ConnectionManager
- addLocalNodeMasterListener(LocalNodeMasterListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Add a listener for on/off local node master events
- addLocalNodeMasterListener(LocalNodeMasterListener) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Add a listener for on/off local node master events
- addLowPriorityApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Adds an applier which will be called after all high priority and normal appliers have been called.
- addLowPriorityApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Adds an applier which will be called after all high priority and normal appliers have been called.
- addMapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- addMapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- addMapping(String, String, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds mapping that will be added when the index gets created.
- addMapping(String, String, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Adds mapping that will be added when the index template gets created.
- addMapping(String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds mapping that will be added when the index gets created.
- addMapping(String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Adds mapping that will be added when the index gets created.
- addMapping(String, XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds mapping that will be added when the index gets created.
- addMapping(String, XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Adds mapping that will be added when the index template gets created.
- addMaskRange(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addMaskRange(String, String)
but uses the mask itself as a key. - addMaskRange(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Add a new range to this aggregation using the CIDR notation.
- addMaxIndexAgeCondition(TimeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Adds condition to check if the index is at least
age
old - addMaxIndexAgeCondition(TimeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- addMaxIndexDocsCondition(long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Adds condition to check if the index has at least
numDocs
- addMaxIndexDocsCondition(long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- addMaxIndexSizeCondition(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Adds a size-based condition to check if the index size is at least
size
. - addMaxIndexSizeCondition(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- addMessage(String, Object...) - Method in class org.elasticsearch.common.inject.internal.Errors
- addMessage(Message) - Method in class org.elasticsearch.common.inject.internal.Errors
- addMessageListener(TransportMessageListener) - Method in class org.elasticsearch.transport.TransportService
- addMetadata(String, String...) - Method in exception org.elasticsearch.ElasticsearchException
-
Adds a new piece of metadata with the given key.
- addMetadata(String, List<String>) - Method in exception org.elasticsearch.ElasticsearchException
-
Adds a new piece of metadata with the given key.
- addModule(PluginInfo) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- addMultiField(Mapper.Builder<?, ?>) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- addNamedQuery(String, Query) - Method in class org.elasticsearch.index.query.QueryShardContext
- addNewHistoryCommit(Directory, Terminal, boolean) - Method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- addNodeStatistics(String, int, long, long) - Method in class org.elasticsearch.node.ResponseCollectorService
- addNormsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addOne(long) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- addOneCandidate(DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.CandidateSet
- addOperation() - Method in enum org.elasticsearch.action.ThreadingModel
- addOption(O) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- addOption(PhraseSuggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- addOptions(List<O>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- addOrNotify(Translog.Location, Consumer<Boolean>) - Method in class org.elasticsearch.index.shard.RefreshListeners
-
Add a listener for refreshes, calling it immediately if the location is already visible.
- addPeerRecoveryRetentionLease(String, long, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Retention leases for peer recovery have source
ReplicationTracker.PEER_RECOVERY_RETENTION_LEASE_SOURCE
, a lease ID containing the persistent node ID calculated byReplicationTracker.getPeerRecoveryRetentionLeaseId(java.lang.String)
, and retain operations with sequence numbers strictly greater than the given global checkpoint. - addPeerRecoveryRetentionLease(String, long, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.shard.IndexShard
- addPending(ClusterState) - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
Add an incoming, not yet committed cluster state
- addPendingDelete(Index, IndexSettings) - Method in class org.elasticsearch.indices.IndicesService
-
Adds a pending delete for the given index.
- addPendingDelete(ShardId, IndexSettings) - Method in interface org.elasticsearch.index.IndexService.ShardStoreDeleter
- addPendingDelete(ShardId, IndexSettings) - Method in class org.elasticsearch.indices.IndicesService
-
Adds a pending delete for the given index shard.
- addPing(ZenPing.PingResponse) - Method in class org.elasticsearch.discovery.zen.ZenPing.PingCollection
-
adds a ping if newer than previous pings from the same node
- addPingResponseToCollection(ZenPing.PingResponse) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.PingingRound
- addPipelineAggregator(PipelineAggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- addPlugin(PluginInfo) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- addPlugins(Collection<Class<? extends Plugin>>, Class<? extends Plugin>...) - Static method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- addPlugins(Collection<Class<? extends Plugin>>, Collection<Class<? extends Plugin>>) - Static method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- addPointsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addProcessedFile(long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Increments number of processed files
- addQueryProfiler() - Method in class org.elasticsearch.search.profile.Profilers
-
Switch to a new profile.
- addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addRange(String, double, double)
but the key will be automatically generated based onfrom
andto
. - addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Same as
GeoDistanceAggregationBuilder.addRange(String, double, double)
but the key will be automatically generated based onfrom
andto
. - addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Same as
RangeAggregationBuilder.addRange(String, double, double)
but the key will be automatically generated based onfrom
andto
. - addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addRange(String, String, String)
but the key will be automatically generated based onfrom
andto
. - addRange(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addRange(String, String, String)
but the key will be automatically generated. - addRange(String, String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, ZonedDateTime, ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(ZonedDateTime, ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addRange(String, ZonedDateTime, ZonedDateTime)
but the key will be automatically generated based onfrom
andto
. - addRange(GeoDistanceAggregationBuilder.Range) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- addRange(IpRangeAggregationBuilder.Range) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Add a new
IpRangeAggregationBuilder.Range
to this aggregation. - addRange(R) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- addReaderCloseListener(DirectoryReader, IndexReader.ClosedListener) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
-
Adds the given listener to the provided directory reader.
- addRecoveredBytesToFile(String, long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addRefreshListener(Translog.Location, Consumer<Boolean>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Add a listener for refreshes.
- addReleasable(Releasable, SearchContext.Lifetime) - Method in class org.elasticsearch.search.internal.SearchContext
-
Schedule the release of a resource.
- addReplica() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- addRepositories(String...) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequestBuilder
-
Adds repositories to the list of repositories to get
- AddRequest(ShardId, String, long, String) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.AddRequest
- addRequestCircuitBreakerBytes(long) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Increment or decrement the number of bytes that have been allocated to service this request and potentially trigger a
CircuitBreakingException
. - addRescore(RescoreContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- addRescore(RescoreContext) - Method in class org.elasticsearch.search.internal.SearchContext
- addRescore(RescoreContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
- addRescorer(RescorerBuilder<?>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a new rescorer.
- addRescorer(RescorerBuilder<?>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- addRescorer(RescorerBuilder<?>, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a new rescorer.
- addResponseHeader(String, String) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Add the
value
for the specifiedkey
Any duplicatevalue
is ignored. - addResponseHeader(String, String, Function<String, String>) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Add the
value
for the specifiedkey
with the specifieduniqueValue
used for de-duplication. - address() - Method in class org.elasticsearch.common.transport.TransportAddress
-
Returns the enclosed
InetSocketAddress
- address() - Method in class org.elasticsearch.http.HttpInfo
- address() - Method in exception org.elasticsearch.transport.ActionTransportException
-
The target address to invoke the action on.
- address() - Method in class org.elasticsearch.transport.TransportInfo
- addressesFromString(String) - Method in class org.elasticsearch.transport.TcpTransport
- addressesFromString(String) - Method in interface org.elasticsearch.transport.Transport
-
Returns an address from its string representation.
- addressesFromString(String) - Method in class org.elasticsearch.transport.TransportService
- addRestHandler(BaseRestHandler) - Method in class org.elasticsearch.usage.UsageService
-
Add a REST handler to this service.
- addResultReader(String, Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Add a reader for the shard level results of the aggregation.
- addResultReader(String, Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Add a reader for the shard level results of the aggregation.
- addResultReader(Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Add a reader for the shard level results of the aggregation with SearchPlugin.SearchExtensionSpec.getName()'s
ParseField.getPreferredName()
as theNamedWriteable.getWriteableName()
. - addResultReader(Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Add a reader for the shard level results of the aggregation with SearchPlugin.SearchExtensionSpec.getName()'s
ParseField.getPreferredName()
as theNamedWriteable.getWriteableName()
. - addRetentionLease(String, long, String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Adds a new retention lease.
- addRetentionLease(String, long, String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Adds a new retention lease.
- addScriptField(String, Script) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a script based field to load and return.
- addScriptField(String, Script) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- addScriptParam(String, Object) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - addScrollId(String) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- addScrollId(String) - Method in class org.elasticsearch.action.search.ClearScrollRequestBuilder
- addSearchExt(SearchExtBuilder) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- addSearchExt(SearchExtBuilder) - Method in class org.elasticsearch.search.internal.SearchContext
- addSearchOperationListener(SearchOperationListener) - Method in class org.elasticsearch.index.IndexModule
-
Adds an
SearchOperationListener
for this index. - addSettingsUpdateConsumer(Consumer<Settings>, List<? extends Setting<?>>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer that is only executed if any setting in the supplied list of settings is changed.
- addSettingsUpdateConsumer(Setting<A>, Setting<B>, BiConsumer<A, B>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer that accepts the values for two settings.
- addSettingsUpdateConsumer(Setting<A>, Setting<B>, BiConsumer<A, B>, BiConsumer<A, B>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer that accepts the values for two settings.
- addSettingsUpdateConsumer(Setting<T>, Consumer<T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer.
- addSettingsUpdateConsumer(Setting<T>, Consumer<T>) - Method in class org.elasticsearch.index.IndexModule
-
Adds a Setting and it's consumer for this index.
- addSettingsUpdateConsumer(Setting<T>, Consumer<T>, Consumer<T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer with a predicate that is only evaluated at update time.
- addSettingsUpdateConsumer(Setting<T>, Consumer<T>, Consumer<T>) - Method in class org.elasticsearch.index.IndexModule
-
Adds a Setting, it's consumer and validator for this index.
- addShard(ShardRouting) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Adds a new shard routing (makes a copy of it), with reference data used from the index shard routing table if it needs to be created.
- addShard(ShardRouting) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- addShardFailureCallback(Consumer<IndexShard.ShardFailure>) - Method in class org.elasticsearch.index.shard.IndexShard
- addSimilarity(String, TriFunction<Settings, Version, ScriptService, Similarity>) - Method in class org.elasticsearch.index.IndexModule
-
Registers the given
Similarity
with the given name. - addSingleFilePath(Permissions, Path, String) - Static method in class org.elasticsearch.bootstrap.FilePermissionUtils
-
Add access to single file path
- addSnapshot(SnapshotId, SnapshotState, List<IndexId>) - Method in class org.elasticsearch.repositories.RepositoryData
-
Add a snapshot and its indices to the repository; returns a new instance.
- addSnapshots(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Adds additional snapshots to the list of snapshots to return
- addSnapshots(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
-
Adds additional snapshots to the list of snapshots to return
- addSort(String, SortOrder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a sort against the given field name and the sort ordering.
- addSort(SortBuilder<?>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a generic sort builder.
- addSort(SortBuilder<?>) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- addSortField(String, SortOrder) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Add a sort against the given field name.
- addSourceThrottling(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addStateApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Adds a applier of updated cluster states.
- addStateApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Adds a applier of updated cluster states.
- addStateNotRecoveredBlock(ClusterState) - Static method in class org.elasticsearch.gateway.ClusterStateUpdaters
- addStoredField(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a stored field to load and return (note, it must be stored) as part of the search request.
- addStoredFieldsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addSuggestion(String, SuggestionBuilder<?>) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
Adds an
SuggestionBuilder
instance under a user defined name. - addSuggestion(String, SuggestionSearchContext.SuggestionContext) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext
- addTargetThrottling(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addTask(String, String, Params, PersistentTasksCustomMetaData.Assignment) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Builder
-
Adds a new task to the builder
- addTerm(T) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- addTermsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addTermVectorsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addThrottleTime(long) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- addTimeoutListener(TimeValue, TimeoutClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Adds a cluster state listener that is expected to be removed during a short period of time.
- addToFilter(SetBackedScalingCuckooFilter, B) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- addToFilter(SetBackedScalingCuckooFilter, LongRareTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms
- addToFilter(SetBackedScalingCuckooFilter, StringRareTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms
- addTokenFilter(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- addTokenFilter(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Add a name of token filter that will be used on top of a tokenizer provided.
- addTokenFilter(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- addTokenFilter(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Add token filter setting that will be used on top of a tokenizer provided.
- addTombstone(Index) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
-
Add a deleted index to the list of tombstones in the cluster state.
- addTombstones(Collection<Index>) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
-
Add a set of deleted indexes to the list of tombstones in the cluster state.
- addToSliceStatuses(BulkByScrollTask.StatusOrException) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- addTotals(FlushStats) - Method in class org.elasticsearch.index.flush.FlushStats
- addTotals(GetStats) - Method in class org.elasticsearch.index.get.GetStats
- addTotals(MergeStats) - Method in class org.elasticsearch.index.merge.MergeStats
- addTotals(RecoveryStats) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- addTotals(RefreshStats) - Method in class org.elasticsearch.index.refresh.RefreshStats
- addTotals(SearchStats) - Method in class org.elasticsearch.index.search.stats.SearchStats
- addTotals(IndexingStats) - Method in class org.elasticsearch.index.shard.IndexingStats
- addTotalsForClosingShard(SearchStats) - Method in class org.elasticsearch.index.search.stats.SearchStats
- addTransportAddress(TransportAddress) - Method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.Adds a transport address that will be used to connect to.
- addTransportAddresses(TransportAddress...) - Method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.Adds a list of transport addresses that will be used to connect to.
- addTypes(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
- addTypes(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequestBuilder
- addUnboundedFrom(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedFrom(String, double)
but the key will be computed automatically. - addUnboundedFrom(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Same as
GeoDistanceAggregationBuilder.addUnboundedFrom(String, double)
but the key will be computed automatically. - addUnboundedFrom(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Same as
RangeAggregationBuilder.addUnboundedFrom(String, double)
but the key will be computed automatically. - addUnboundedFrom(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedFrom(String, String)
but the key will be computed automatically. - addUnboundedFrom(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addUnboundedFrom(String, String)
but the key will be generated automatically. - addUnboundedFrom(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addRange(String, String, String)
but there will be no upper bound. - addUnboundedFrom(String, ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedFrom(String, ZonedDateTime)
but the key will be computed automatically. - addUnboundedTo(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedTo(String, double)
but the key will be computed automatically. - addUnboundedTo(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Same as
GeoDistanceAggregationBuilder.addUnboundedTo(String, double)
but the key will be computed automatically. - addUnboundedTo(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Same as
RangeAggregationBuilder.addUnboundedTo(String, double)
but the key will be computed automatically. - addUnboundedTo(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedTo(String, String)
but the key will be computed automatically. - addUnboundedTo(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addUnboundedTo(String, String)
but the key will be generated automatically. - addUnboundedTo(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addRange(String, String, String)
but there will be no lower bound. - addUnboundedTo(String, ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedTo(String, ZonedDateTime)
but the key will be computed automatically. - addValidationError(String) - Method in exception org.elasticsearch.common.ValidationException
-
Add a new validation error to the accumulating validation errors
- addValidationError(String, String, QueryValidationException) - Static method in exception org.elasticsearch.index.query.QueryValidationException
-
Helper method than can be used to add error messages to an existing
QueryValidationException
. - addValidationError(String, ActionRequestValidationException) - Static method in class org.elasticsearch.action.ValidateActions
- addValidationError(String, QueryValidationException) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- addValidationErrors(Iterable<String>) - Method in exception org.elasticsearch.common.ValidationException
-
Add a sequence of validation errors to the accumulating validation errors
- addValidationErrors(List<String>, QueryValidationException) - Static method in exception org.elasticsearch.index.query.QueryValidationException
-
Helper method than can be used to add error messages to an existing
QueryValidationException
. - addValue(double) - Method in class org.elasticsearch.common.ExponentiallyWeightedMovingAverage
- addVersionMapMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addVote(DiscoveryNode) - Method in class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- addVotingConfigExclusion(CoordinationMetaData.VotingConfigExclusion) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetaData.Builder
- AddVotingConfigExclusionsAction - Class in org.elasticsearch.action.admin.cluster.configuration
- AddVotingConfigExclusionsRequest - Class in org.elasticsearch.action.admin.cluster.configuration
-
A request to add voting config exclusions for certain master-eligible nodes, and wait for these nodes to be removed from the voting configuration.
- AddVotingConfigExclusionsRequest(String[]) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
-
Construct a request to add voting config exclusions for master-eligible nodes matching the given descriptions, and wait for a default 30 seconds for these exclusions to take effect, removing the nodes from the voting configuration.
- AddVotingConfigExclusionsRequest(String[], TimeValue) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
-
Construct a request to add voting config exclusions for master-eligible nodes matching the given descriptions, and wait for these nodes to be removed from the voting configuration.
- AddVotingConfigExclusionsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
- AddVotingConfigExclusionsResponse - Class in org.elasticsearch.action.admin.cluster.configuration
-
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. - AddVotingConfigExclusionsResponse() - Constructor for class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsResponse
- AddVotingConfigExclusionsResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsResponse
- addWithKey(Object, IndexableField) - Method in class org.elasticsearch.index.mapper.ParseContext.Document
-
Add fields so that they can later be fetched using
ParseContext.Document.getByKey(Object)
. - addWithoutBreaking(long) - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
-
Add an exact number of bytes, not checking for tripping the circuit breaker.
- addWithoutBreaking(long) - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
-
Adjust the circuit breaker without tripping
- addWithoutBreaking(long) - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- addZen1Attribute(boolean, Settings.Builder) - Static method in class org.elasticsearch.cluster.coordination.Coordinator
- adjacencyMatrix(String, String, Map<String, QueryBuilder>) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
AdjacencyMatrix
aggregation with the given name and separator - adjacencyMatrix(String, Map<String, QueryBuilder>) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
AdjacencyMatrix
aggregation with the given name. - AdjacencyMatrix - Interface in org.elasticsearch.search.aggregations.bucket.adjacency
-
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 - Interface in org.elasticsearch.search.aggregations.bucket.adjacency
-
A bucket associated with a specific filter or pair (identified by its key)
- AdjacencyMatrixAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- AdjacencyMatrixAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregationBuilder(String, String, Map<String, QueryBuilder>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregationBuilder(String, Map<String, QueryBuilder>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
-
Read from a stream.
- AdjacencyMatrixAggregationBuilder(AdjacencyMatrixAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregator - Class in org.elasticsearch.search.aggregations.bucket.adjacency
-
Aggregation for adjacency matrices.
- AdjacencyMatrixAggregator(String, AggregatorFactories, String, String[], Weight[], SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator
- AdjacencyMatrixAggregator.KeyedFilter - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- AdjacencyMatrixAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- AdjacencyMatrixAggregatorFactory(String, List<AdjacencyMatrixAggregator.KeyedFilter>, String, QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregatorFactory
- ADJUST_PURE_NEGATIVE_DEFAULT - Static variable in class org.elasticsearch.index.query.BoolQueryBuilder
- adjustPureNegative() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- adjustPureNegative(boolean) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
If a boolean query contains only negative ("must not") clauses should the BooleanQuery be enhanced with a
MatchAllDocsQuery
in order to act as a pure exclude. - admin() - Method in interface org.elasticsearch.client.Client
-
The admin client that can be used to perform administrative operations.
- admin() - Method in class org.elasticsearch.client.support.AbstractClient
- AdminClient - Interface in org.elasticsearch.client
-
Administrative actions/operations against the cluster or the indices.
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractBinaryDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractNumericDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortedDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortedNumericDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortedSetDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortingNumericDocValues
- ADVANCE - org.elasticsearch.search.profile.query.QueryTimingType
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.DocValueBits
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.GeoPointValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.MultiGeoPointValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.SortedBinaryDocValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.SortedNumericDoubleValues
-
Advance the iterator to exactly
target
and return whethertarget
has a value. - advanceExact(int) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptBytesValues
- advanceExact(int) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptDoubleValues
- advanceExact(int) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptLongValues
- advanceMaxSeqNo(long) - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
Marks the provided sequence number as seen and updates the max_seq_no if needed.
- advanceMaxSeqNoOfUpdatesOrDeletes(long) - Method in class org.elasticsearch.index.engine.Engine
-
A replica shard receives a new max_seq_no_of_updates from its primary shard, then calls this method to advance this marker to at least the given sequence number.
- advanceMaxSeqNoOfUpdatesOrDeletes(long) - Method in class org.elasticsearch.index.engine.InternalEngine
- advanceMaxSeqNoOfUpdatesOrDeletes(long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- advanceMaxSeqNoOfUpdatesOrDeletes(long) - Method in class org.elasticsearch.index.shard.IndexShard
-
A replica calls this method to advance the max_seq_no_of_updates marker of its engine to at least the max_seq_no_of_updates value (piggybacked in a replication request) that it receives from its primary before executing that replication request.
- advanceMaxSeqNoOfUpdatesOrDeletesOnPrimary(long) - Method in class org.elasticsearch.index.engine.InternalEngine
- affixKeySetting(String, String, Function<String, Setting<T>>, Setting.AffixSetting...) - Static method in class org.elasticsearch.common.settings.Setting
-
This setting type allows to validate settings that have the same type and a common prefix and suffix.
- AffixSetting(Setting.AffixKey, Setting<T>, Function<String, Setting<T>>, Setting.AffixSetting...) - Constructor for class org.elasticsearch.common.settings.Setting.AffixSetting
- after(Priority) - Method in enum org.elasticsearch.common.Priority
- after(Version) - Method in class org.elasticsearch.Version
- AFTER_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- afterBulk(long, BulkRequest, Throwable) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
-
Callback after a failed execution of bulk request.
- afterBulk(long, BulkRequest, BulkResponse) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
-
Callback after a successful execution of bulk request.
- afterClose() - Method in class org.elasticsearch.common.component.LifecycleListener
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.threadpool.Scheduler.SafeScheduledThreadPoolExecutor
- afterIndexCreated(IndexService) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index has been created.
- afterIndexRemoved(Index, IndexSettings, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index has been removed.
- afterIndexRemoved(Index, IndexSettings, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in class org.elasticsearch.search.SearchService
- afterIndexShardClosed(ShardId, IndexShard, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been closed.
- afterIndexShardCreated(IndexShard) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been created.
- afterIndexShardDeleted(ShardId, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been deleted from disk.
- afterIndexShardStarted(IndexShard) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been started.
- afterInjection(I) - Method in interface org.elasticsearch.common.inject.spi.InjectionListener
-
Invoked by Guice after it injects the fields and methods of instance.
- afterKey() - Method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation
-
Returns the last key in this aggregation.
- afterKey() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- afterKey() - Method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite
- afterLoad(TermsEnum, long) - Method in interface org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData.PerValueEstimator
-
Possibly adjust a circuit breaker after field data has been loaded, now that the actual amount of memory used by the field data is known
- afterLoad(TermsEnum, long) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.PagedBytesEstimator
-
Adjust the circuit breaker now that terms have been loaded, getting the actual used either from the parameter (if estimation worked for the entire set), or from the TermsEnum if it has been wrapped in a RamAccountingTermsEnum.
- afterRefresh(boolean) - Method in class org.elasticsearch.index.shard.RefreshListeners
- afterRelease(boolean) - Method in class org.elasticsearch.common.recycler.ConcurrentDequeRecycler
- afterRelease(boolean) - Method in class org.elasticsearch.common.recycler.DequeRecycler
-
Called after a release.
- afterStart() - Method in class org.elasticsearch.common.component.LifecycleListener
- afterStop() - Method in class org.elasticsearch.common.component.LifecycleListener
- afterWriteOperation() - Method in class org.elasticsearch.index.shard.IndexShard
-
Schedules a flush or translog generation roll if needed but will not schedule more than one concurrently.
- AggParseContext(String) - Constructor for class org.elasticsearch.search.aggregations.AggregatorFactories.AggParseContext
- aggregateAfter(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
-
Sets the values that indicates which composite bucket this request should "aggregate after".
- AggregatedDfs - Class in org.elasticsearch.search.dfs
- AggregatedDfs(ObjectObjectHashMap<Term, TermStatistics>, ObjectObjectHashMap<String, CollectionStatistics>, long) - Constructor for class org.elasticsearch.search.dfs.AggregatedDfs
- AggregatedDfs(StreamInput) - Constructor for class org.elasticsearch.search.dfs.AggregatedDfs
- aggregateDfs(Collection<DfsSearchResult>) - Method in class org.elasticsearch.action.search.SearchPhaseController
- aggregation() - Method in class org.elasticsearch.search.aggregations.metrics.InternalScriptedMetric
- aggregation() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedScriptedMetric
- aggregation() - Method in interface org.elasticsearch.search.aggregations.metrics.ScriptedMetric
-
The result of the aggregation.
- aggregation(String, boolean) - Static method in class org.elasticsearch.search.aggregations.BucketOrder
-
Creates a bucket ordering strategy which sorts buckets based on a single-valued sub-aggregation.
- aggregation(String, String, boolean) - Static method in class org.elasticsearch.search.aggregations.BucketOrder
-
Creates a bucket ordering strategy which sorts buckets based on a metric from a multi-valued sub-aggregation.
- aggregation(AggregationBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Add an aggregation to perform as part of the search.
- aggregation(PipelineAggregationBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Add an aggregation to perform as part of the search.
- Aggregation - Interface in org.elasticsearch.search.aggregations
-
An aggregation.
- Aggregation.CommonFields - Class in org.elasticsearch.search.aggregations
-
Common xcontent fields that are shared among addAggregation
- AggregationBuilder - Class in org.elasticsearch.search.aggregations
-
A factory that knows how to create an
Aggregator
of a specific type. - AggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.AggregationBuilder
-
Constructs a new aggregation builder.
- AggregationBuilder(AggregationBuilder, AggregatorFactories.Builder) - Constructor for class org.elasticsearch.search.aggregations.AggregationBuilder
- AggregationBuilder.CommonFields - Class in org.elasticsearch.search.aggregations
-
Common xcontent fields shared among aggregator builders
- AggregationBuilders - Class in org.elasticsearch.search.aggregations
-
Utility class to create aggregations.
- AggregationExecutionException - Exception in org.elasticsearch.search.aggregations
-
Thrown when failing to execute an aggregation
- AggregationExecutionException(String) - Constructor for exception org.elasticsearch.search.aggregations.AggregationExecutionException
- AggregationExecutionException(String, Throwable) - Constructor for exception org.elasticsearch.search.aggregations.AggregationExecutionException
- AggregationExecutionException(StreamInput) - Constructor for exception org.elasticsearch.search.aggregations.AggregationExecutionException
- AggregationInitializationException - Exception in org.elasticsearch.search.aggregations
-
Thrown when failing to execute an aggregation
- AggregationInitializationException(String) - Constructor for exception org.elasticsearch.search.aggregations.AggregationInitializationException
- AggregationInitializationException(String, Throwable) - Constructor for exception org.elasticsearch.search.aggregations.AggregationInitializationException
- AggregationInitializationException(StreamInput) - Constructor for exception org.elasticsearch.search.aggregations.AggregationInitializationException
- AggregationInspectionHelper - Class in org.elasticsearch.search.aggregations.support
-
Provides a set of static helpers to determine if a particular type of InternalAggregation "has a value" or not.
- AggregationInspectionHelper() - Constructor for class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- AggregationPath - Class in org.elasticsearch.search.aggregations.support
-
A path that can be used to sort/order buckets (in some multi-bucket aggregations, e.g.
- AggregationPath(List<AggregationPath.PathElement>) - Constructor for class org.elasticsearch.search.aggregations.support.AggregationPath
- AggregationPath.PathElement - Class in org.elasticsearch.search.aggregations.support
- AggregationPhase - Class in org.elasticsearch.search.aggregations
-
Aggregation phase of a search request, used to collect aggregations
- AggregationPhase() - Constructor for class org.elasticsearch.search.aggregations.AggregationPhase
- AggregationProfileBreakdown - Class in org.elasticsearch.search.profile.aggregation
- AggregationProfileBreakdown() - Constructor for class org.elasticsearch.search.profile.aggregation.AggregationProfileBreakdown
- AggregationProfiler - Class in org.elasticsearch.search.profile.aggregation
- AggregationProfiler() - Constructor for class org.elasticsearch.search.profile.aggregation.AggregationProfiler
- AggregationProfileShardResult - Class in org.elasticsearch.search.profile.aggregation
-
A container class to hold the profile results for a single shard in the request.
- AggregationProfileShardResult(List<ProfileResult>) - Constructor for class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- AggregationProfileShardResult(StreamInput) - Constructor for class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
-
Read from a stream.
- aggregations - Variable in class org.elasticsearch.action.search.SearchResponseSections
- aggregations - Variable in class org.elasticsearch.search.aggregations.Aggregations
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.ParsedSingleBucketAggregation
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- aggregations() - Method in class org.elasticsearch.action.search.SearchResponseSections
- aggregations() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the bytes representing the aggregation builders for this request.
- aggregations() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- aggregations() - Method in class org.elasticsearch.search.internal.SearchContext
- aggregations(InternalAggregations) - Method in class org.elasticsearch.search.query.QuerySearchResult
- aggregations(SearchContextAggregations) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- aggregations(SearchContextAggregations) - Method in class org.elasticsearch.search.internal.SearchContext
- aggregations(SearchContextAggregations) - Method in class org.elasticsearch.search.internal.SubSearchContext
- Aggregations - Class in org.elasticsearch.search.aggregations
-
Represents a set of
Aggregation
s - Aggregations(List<? extends Aggregation>) - Constructor for class org.elasticsearch.search.aggregations.Aggregations
- AGGREGATIONS - Static variable in class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- AGGREGATIONS_FIELD - Static variable in class org.elasticsearch.search.aggregations.Aggregations
- AGGREGATIONS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- AggregationScript - Class in org.elasticsearch.script
- AggregationScript() - Constructor for class org.elasticsearch.script.AggregationScript
- AggregationScript(Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.AggregationScript
- AggregationScript.Factory - Interface in org.elasticsearch.script
-
A factory to construct stateful
AggregationScript
factories for a specific index. - AggregationScript.LeafFactory - Interface in org.elasticsearch.script
-
A factory to construct
AggregationScript
instances. - AggregationSpec(String, Writeable.Reader<? extends AggregationBuilder>, Aggregator.Parser) - Constructor for class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Specification for an
Aggregation
. - AggregationSpec(ParseField, Writeable.Reader<? extends AggregationBuilder>, Aggregator.Parser) - Constructor for class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Specification for an
Aggregation
. - AggregationTimingType - Enum in org.elasticsearch.search.profile.aggregation
- Aggregator - Class in org.elasticsearch.search.aggregations
-
An Aggregator.
- Aggregator() - Constructor for class org.elasticsearch.search.aggregations.Aggregator
- Aggregator.Parser - Interface in org.elasticsearch.search.aggregations
-
Parses the aggregation request and creates the appropriate aggregator factory for it.
- Aggregator.SubAggCollectionMode - Enum in org.elasticsearch.search.aggregations
-
Aggregation mode for sub aggregations.
- AggregatorBase - Class in org.elasticsearch.search.aggregations
-
Base implementation for concrete aggregators.
- AggregatorBase(String, AggregatorFactories, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.AggregatorBase
-
Constructs a new Aggregator.
- AggregatorFactories - Class in org.elasticsearch.search.aggregations
- AggregatorFactories.AggParseContext - Class in org.elasticsearch.search.aggregations
-
Context to parse and aggregation.
- AggregatorFactories.Builder - Class in org.elasticsearch.search.aggregations
- AggregatorFactory - Class in org.elasticsearch.search.aggregations
- AggregatorFactory(String, QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.AggregatorFactory
-
Constructs a new aggregator factory.
- AggregatorFactory.MultiBucketAggregatorWrapper - Class in org.elasticsearch.search.aggregations
- aggregators() - Method in class org.elasticsearch.search.aggregations.SearchContextAggregations
- aggregators(Aggregator[]) - Method in class org.elasticsearch.search.aggregations.SearchContextAggregations
-
Registers all the created aggregators (top level aggregators) for the search execution context.
- AGGS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- aggsUsedForSorting - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- alias() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData
- alias() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
- alias(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Set the alias this action is operating on.
- alias(Alias) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Adds an alias that will be associated with the index when it gets created
- alias(Alias) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- alias(Alias) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Adds an alias that will be added when the index gets created.
- Alias - Class in org.elasticsearch.action.admin.indices.alias
-
Represents an alias, to be associated with an index
- Alias(String) - Constructor for class org.elasticsearch.action.admin.indices.alias.Alias
- Alias(AliasMetaData, IndexMetaData) - Constructor for class org.elasticsearch.cluster.metadata.AliasOrIndex.Alias
- Alias(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.alias.Alias
- AliasAction - Class in org.elasticsearch.cluster.metadata
-
Individual operation to perform on the cluster state as part of an
IndicesAliasesRequest
. - AliasAction.Add - Class in org.elasticsearch.cluster.metadata
-
Operation to add an alias to an index.
- AliasAction.NewAliasValidator - Interface in org.elasticsearch.cluster.metadata
-
Validate a new alias.
- AliasAction.Remove - Class in org.elasticsearch.cluster.metadata
-
Operation to remove an alias from an index.
- AliasAction.RemoveIndex - Class in org.elasticsearch.cluster.metadata
-
Operation to remove an index.
- AliasActions(IndicesAliasesRequest.AliasActions.Type) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- AliasActions(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Read from a stream.
- aliases() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- aliases() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- aliases() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- aliases() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- aliases() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- aliases() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- aliases() - Method in interface org.elasticsearch.action.AliasesRequest
-
Returns the array of aliases that the action relates to
- aliases() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData
- aliases(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the aliases that will be associated with the index when it gets created
- aliases(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Sets the aliases that will be associated with the index when it gets created
- aliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- aliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Aliases to use with this action.
- aliases(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the aliases that will be associated with the index when it gets created
- aliases(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Sets the aliases that will be associated with the index when it gets created
- aliases(Set<Alias>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- aliases(Set<Alias>) - Method in class org.elasticsearch.cluster.metadata.MetaDataIndexTemplateService.PutRequest
- aliases(IndicesAliasesRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Allows to add/remove aliases from indices.
- aliases(IndicesAliasesRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Allows to add/remove aliases from indices.
- aliases(BytesReference) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the aliases that will be associated with the index when it gets created
- aliases(BytesReference) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Sets the aliases that will be associated with the index when it gets created
- aliases(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the aliases that will be associated with the index when it gets created
- aliases(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Sets the aliases that will be associated with the index when it gets created
- ALIASES - org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
- ALIASES - Static variable in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- aliasesExist(GetAliasesRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Check to existence of index aliases.
- aliasesExist(GetAliasesRequest, ActionListener<AliasesExistResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Check the existence of specified index aliases.
- AliasesExistAction - Class in org.elasticsearch.action.admin.indices.alias.exists
- AliasesExistRequestBuilder - Class in org.elasticsearch.action.admin.indices.alias.exists
- AliasesExistRequestBuilder(ElasticsearchClient, AliasesExistAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistRequestBuilder
- AliasesExistResponse - Class in org.elasticsearch.action.admin.indices.alias.exists
- AliasesExistResponse(boolean) - Constructor for class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistResponse
- AliasesNotFoundException - Exception in org.elasticsearch.rest.action.admin.indices
- AliasesNotFoundException(String...) - Constructor for exception org.elasticsearch.rest.action.admin.indices.AliasesNotFoundException
- AliasesNotFoundException(StreamInput) - Constructor for exception org.elasticsearch.rest.action.admin.indices.AliasesNotFoundException
- AliasesRequest - Interface in org.elasticsearch.action
-
Needs to be implemented by all
ActionRequest
subclasses that relate to one or more indices and one or more aliases. - aliasesVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- aliasesVersion(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- aliasFilter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- aliasFilter() - Method in class org.elasticsearch.search.internal.SearchContext
- AliasFilter - Class in org.elasticsearch.search.internal
-
Represents a
QueryBuilder
and a list of alias names that filters the builder is composed of. - AliasFilter(StreamInput) - Constructor for class org.elasticsearch.search.internal.AliasFilter
- AliasFilter(QueryBuilder, String...) - Constructor for class org.elasticsearch.search.internal.AliasFilter
- AliasFilterParsingException - Exception in org.elasticsearch.indices
- AliasFilterParsingException(StreamInput) - Constructor for exception org.elasticsearch.indices.AliasFilterParsingException
- AliasFilterParsingException(Index, String, String, Throwable) - Constructor for exception org.elasticsearch.indices.AliasFilterParsingException
- AliasMetaData - Class in org.elasticsearch.cluster.metadata
- AliasMetaData(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.AliasMetaData
- AliasMetaData.Builder - Class in org.elasticsearch.cluster.metadata
- AliasOrIndex - Interface in org.elasticsearch.cluster.metadata
-
Encapsulates the
IndexMetaData
instances of a concrete index or indices an alias is pointing to. - AliasOrIndex.Alias - Class in org.elasticsearch.cluster.metadata
-
Represents an alias and groups all
IndexMetaData
instances sharing the same alias name together. - AliasOrIndex.Index - Class in org.elasticsearch.cluster.metadata
-
Represents an concrete index and encapsulates its
IndexMetaData
- AliasValidator - Class in org.elasticsearch.cluster.metadata
-
Validator for an alias, to be used before adding an alias to the index metadata and make sure the alias is valid
- AliasValidator() - Constructor for class org.elasticsearch.cluster.metadata.AliasValidator
- all() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Sets to return all the data.
- all() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Sets to return all the data.
- all() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Sets all the request flags.
- all() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Sets all the request flags.
- all() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
-
Sets all the request flags.
- all() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- all() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Include all data
- all() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
Sets all flags to return all stats.
- all() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
Sets all flags to return all stats.
- all() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
-
Sets all flags to return all stats.
- ALL - org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
- ALL - org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
- ALL - org.elasticsearch.index.analysis.AnalysisMode
-
AnalysisMode representing analysis components that can be used both at index and search time
- ALL - org.elasticsearch.index.query.RegexpFlag
-
Enables all available option flags
- ALL - org.elasticsearch.index.query.SimpleQueryStringFlag
- ALL - org.elasticsearch.index.search.MatchQuery.ZeroTermsQuery
- ALL - org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
- ALL - Static variable in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- ALL - Static variable in class org.elasticsearch.action.support.ActiveShardCount
- ALL - Static variable in enum org.elasticsearch.cluster.block.ClusterBlockLevel
- ALL - Static variable in class org.elasticsearch.cluster.metadata.MetaData
- ALL_ACTIONS - Static variable in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- ALL_CONTEXTS - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
Indicates that this custom metadata will be returned as part of an API call, stored as a part of a snapshot global state, and will be persisted between node restarts
- ALL_NODES - Static variable in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- ALL_SNAPSHOTS - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- allActiveShardsGrouped(String[], boolean) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
Return GroupShardsIterator where each active shard routing has it's own shard iterator.
- allAssignedShardsGrouped(String[], boolean) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
Return GroupShardsIterator where each assigned shard routing has it's own shard iterator.
- AllCircuitBreakerStats - Class in org.elasticsearch.indices.breaker
-
Stats class encapsulating all of the different circuit breaker stats
- AllCircuitBreakerStats(StreamInput) - Constructor for class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
- AllCircuitBreakerStats(CircuitBreakerStats[]) - Constructor for class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
- AllFieldMapper - Class in org.elasticsearch.index.mapper
-
Noop mapper that ensures that mappings created in 6x that explicitly disable the _all field can be restored in this version.
- AllFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- AllFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- AllFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- allocate(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- allocate(RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocator
-
Allocates shards to nodes in the cluster.
- allocateDangled(Collection<IndexMetaData>, ActionListener<LocalAllocateDangledIndices.AllocateDangledResponse>) - Method in class org.elasticsearch.gateway.LocalAllocateDangledIndices
- AllocateDangledRequest(StreamInput) - Constructor for class org.elasticsearch.gateway.LocalAllocateDangledIndices.AllocateDangledRequest
- AllocateDangledResponse(StreamInput) - Constructor for class org.elasticsearch.gateway.LocalAllocateDangledIndices.AllocateDangledResponse
- AllocatedPersistentTask - Class in org.elasticsearch.persistent
-
Represents a executor node operation that corresponds to a persistent task
- AllocatedPersistentTask(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.persistent.AllocatedPersistentTask
- AllocatedPersistentTask.State - Enum in org.elasticsearch.persistent
- AllocateEmptyPrimaryAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Allocates an unassigned empty primary shard to a specific node.
- AllocateEmptyPrimaryAllocationCommand(String, int, String, boolean) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
-
Creates a new
AllocateEmptyPrimaryAllocationCommand
- AllocateEmptyPrimaryAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
-
Read from a stream.
- AllocateEmptyPrimaryAllocationCommand.Builder - Class in org.elasticsearch.cluster.routing.allocation.command
- AllocateReplicaAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Allocates an unassigned replica shard to a specific node.
- AllocateReplicaAllocationCommand(String, int, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand
-
Creates a new
AllocateReplicaAllocationCommand
- AllocateReplicaAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand
-
Read from a stream.
- AllocateReplicaAllocationCommand.Builder - Class in org.elasticsearch.cluster.routing.allocation.command
- AllocateStalePrimaryAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Allocates an unassigned stale primary shard to a specific node.
- AllocateStalePrimaryAllocationCommand(String, int, String, boolean) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
-
Creates a new
AllocateStalePrimaryAllocationCommand
- AllocateStalePrimaryAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
-
Read from a stream.
- AllocateStalePrimaryAllocationCommand.Builder - Class in org.elasticsearch.cluster.routing.allocation.command
- allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.gateway.BaseGatewayShardAllocator
-
Allocate unassigned shards to nodes (if any) where valid copies of the shard already exist.
- allocateUnassigned(RoutingAllocation) - Method in class org.elasticsearch.gateway.GatewayAllocator
- AllocateUnassignedDecision - Class in org.elasticsearch.cluster.routing.allocation
-
Represents the allocation decision by an allocator for an unassigned shard.
- AllocateUnassignedDecision(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- ALLOCATION_DELAYED - org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
The allocation decision has been delayed waiting for a replica with a shard copy that left the cluster to rejoin.
- ALLOCATION_FAILED - org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of a failed allocation of the shard.
- AllocationCommand - Interface in org.elasticsearch.cluster.routing.allocation.command
-
A command to move shards in some way.
- AllocationCommands - Class in org.elasticsearch.cluster.routing.allocation.command
-
A simple
AllocationCommand
composite managing severalAllocationCommand
implementations - AllocationCommands(AllocationCommand...) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Creates a new set of
AllocationCommands
- AllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
AllocationDecider
is an abstract base class that allows to make dynamic cluster- or index-wide shard allocation decisions on a per-node basis. - AllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
- AllocationDeciders - Class in org.elasticsearch.cluster.routing.allocation.decider
-
A composite
AllocationDecider
combining the "decision" of multipleAllocationDecider
implementations into a single allocation decision. - AllocationDeciders(Collection<AllocationDecider>) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- AllocationDecision - Enum in org.elasticsearch.cluster.routing.allocation
-
An enum which represents the various decision types that can be taken by the allocators and deciders for allocating a shard to a node.
- allocationExplain(ClusterAllocationExplainRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Explain the allocation of a shard
- allocationExplain(ClusterAllocationExplainRequest, ActionListener<ClusterAllocationExplainResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Explain the allocation of a shard
- allocationId - Variable in class org.elasticsearch.index.engine.Engine
- allocationId - Variable in class org.elasticsearch.index.shard.ShardStateMetaData
- allocationId() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
An id that uniquely identifies an allocation.
- allocationId() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- AllocationId - Class in org.elasticsearch.cluster.routing
-
Uniquely identifies an allocation.
- AllocationService - Class in org.elasticsearch.cluster.routing.allocation
-
This service manages the node allocation of a cluster.
- AllocationService(AllocationDeciders, ShardsAllocator, ClusterInfoService) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
- AllocationService(AllocationDeciders, GatewayAllocator, ShardsAllocator, ClusterInfoService) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
- AllocationService.CommandsResult - Class in org.elasticsearch.cluster.routing.allocation
-
this class is used to describe results of applying a set of
AllocationCommand
- ALLOW_NO_INDICES - org.elasticsearch.action.support.IndicesOptions.Option
- ALLOW_NONE - Static variable in class org.elasticsearch.script.ScriptService
- ALLOW_UNMAPPED - Static variable in class org.elasticsearch.index.IndexSettings
- allowAliasesToMultipleIndices() - Method in class org.elasticsearch.action.support.IndicesOptions
- ALLOWED_CONTENT_FIELD_NAMES - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper
- ALLOWED_INTERVALS - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- allowedRequestHeaders() - Method in class org.elasticsearch.http.CorsHandler.Config
- allowedRequestMethods() - Method in class org.elasticsearch.http.CorsHandler.Config
- allowLeadingWildcard() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- allowLeadingWildcard(Boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Should leading wildcards be allowed or not.
- allowNoIndices() - Method in class org.elasticsearch.action.support.IndicesOptions
- allowPartialSearchResults() - Method in class org.elasticsearch.action.search.SearchRequest
- allowPartialSearchResults() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- allowPartialSearchResults(boolean) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets if this request should allow partial results.
- allowPrimary() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- allowsNull(Annotation[]) - Static method in class org.elasticsearch.common.inject.internal.Nullability
- allPrimaryShardsActive() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Returns
true
if all shards are primary and active. - allPrimaryShardsUnassigned() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Returns
true
if all primary shards are inShardRoutingState.UNASSIGNED
state. - allReplicasActive(ShardId, MetaData) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns
true
iff all replicas are active for the given shard routing. - allShards() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Indicates whether the query should be validated on all shards instead of one random shard
- allShards() - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
All the shards (replicas) for all indices in this routing table.
- allShards(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Indicates whether the query should be validated on all shards instead of one random shard
- allShards(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
All the shards (replicas) for the provided index.
- allShards(String[]) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- allShardsIncludingRelocationTargets(String[]) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- allShardsStarted() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns
true
iff all shards in the routing table are started otherwisefalse
- alpha(double) - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel.EWMAModelBuilder
-
Alpha controls the smoothing of the data.
- alpha(double) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel.HoltLinearModelBuilder
-
Alpha controls the smoothing of the data.
- alpha(double) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
-
Alpha controls the smoothing of the data.
- alreadyClosed() - Method in class org.elasticsearch.search.internal.SearchContext
- ALTERNATIVE_NAME - Static variable in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- ALWAYS - org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
-
Re-balancing is allowed once a shard replication group is active
- ALWAYS - org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
-
Suggest any matching suggest terms based on tokens in the suggest text.
- ALWAYS - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.Decision
- alwaysEnforce() - Method in interface org.elasticsearch.bootstrap.BootstrapCheck
- ambiguousTypeConversion(String, Object, TypeLiteral<?>, MatcherAndConverter, MatcherAndConverter) - Method in class org.elasticsearch.common.inject.internal.Errors
- Analysis - Class in org.elasticsearch.index.analysis
- Analysis() - Constructor for class org.elasticsearch.index.analysis.Analysis
- analysisMode() - Method in class org.elasticsearch.index.analysis.AnalyzerComponents
- AnalysisMode - Enum in org.elasticsearch.index.analysis
-
Enum representing the mode in which token filters and analyzers are allowed to operate.
- AnalysisModule - Class in org.elasticsearch.indices.analysis
-
Sets up
AnalysisRegistry
. - AnalysisModule(Environment, List<AnalysisPlugin>) - Constructor for class org.elasticsearch.indices.analysis.AnalysisModule
- AnalysisModule.AnalysisProvider<T> - Interface in org.elasticsearch.indices.analysis
-
The basic factory interface for analysis components.
- AnalysisPlugin - Interface in org.elasticsearch.plugins
-
An additional extension point for
Plugin
s that extends Elasticsearch's analysis functionality. - analysisRegistry - Variable in class org.elasticsearch.ingest.Processor.Parameters
-
Provide analyzer support
- AnalysisRegistry - Class in org.elasticsearch.index.analysis
-
An internal registry for tokenizer, token filter, char filter and analyzer.
- AnalysisRegistry(Environment, Map<String, AnalysisModule.AnalysisProvider<CharFilterFactory>>, Map<String, AnalysisModule.AnalysisProvider<TokenFilterFactory>>, Map<String, AnalysisModule.AnalysisProvider<TokenizerFactory>>, Map<String, AnalysisModule.AnalysisProvider<AnalyzerProvider<?>>>, Map<String, AnalysisModule.AnalysisProvider<AnalyzerProvider<?>>>, Map<String, PreConfiguredCharFilter>, Map<String, PreConfiguredTokenFilter>, Map<String, PreConfiguredTokenizer>, Map<String, PreBuiltAnalyzerProviderFactory>) - Constructor for class org.elasticsearch.index.analysis.AnalysisRegistry
- analyze(Analyzer, BytesRef, String, DirectCandidateGenerator.TokenConsumer, CharsRefBuilder) - Static method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- analyze(TokenStream, DirectCandidateGenerator.TokenConsumer) - Static method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
-
NOTE: this method closes the TokenStream, even on exception, which is awkward because really the caller who called
Analyzer.tokenStream(java.lang.String, java.io.Reader)
should close it, but when trying that there are recursion issues when we try to use the same TokenStream twice in the same recursion... - analyze(AnalyzeAction.Request) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text under the provided index.
- analyze(AnalyzeAction.Request, ActionListener<AnalyzeAction.Response>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text under the provided index.
- analyze(AnalyzeAction.Request, AnalysisRegistry, IndexService, int) - Static method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- ANALYZE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- AnalyzeAction - Class in org.elasticsearch.action.admin.indices.analyze
- AnalyzeAction.AnalyzeToken - Class in org.elasticsearch.action.admin.indices.analyze
- AnalyzeAction.AnalyzeTokenList - Class in org.elasticsearch.action.admin.indices.analyze
- AnalyzeAction.CharFilteredText - Class in org.elasticsearch.action.admin.indices.analyze
- AnalyzeAction.DetailAnalyzeResponse - Class in org.elasticsearch.action.admin.indices.analyze
- AnalyzeAction.Request - Class in org.elasticsearch.action.admin.indices.analyze
-
A request to analyze a text associated with a specific index.
- AnalyzeAction.Response - Class in org.elasticsearch.action.admin.indices.analyze
- analyzeGraph(TokenStream) - Method in class org.elasticsearch.index.query.IntervalBuilder
- analyzer - Variable in class org.elasticsearch.index.search.MatchQuery
- analyzer - Variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- analyzer() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.DetailAnalyzeResponse
- analyzer() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- analyzer() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
-
The actual analyzer.
- analyzer() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- analyzer() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Get the analyzer to use, if previously set, otherwise
null
- analyzer() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Get the analyzer to use, if previously set, otherwise
null
- analyzer() - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Get the analyzer to use, if previously set, otherwise
null
- analyzer() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Get the analyzer to use, if previously set, otherwise
null
- analyzer() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- analyzer() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- analyzer() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
The optional analyzer used to analyze the query string.
- analyzer() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns the analyzer to use for the query.
- analyzer() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the
SuggestionBuilder.analyzer()
parameter - analyzer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- analyzer(String) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
The analyzer that will be used to analyze the text.
- analyzer(String) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
The optional analyzer used to analyze the query string.
- analyzer(String) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Specify an analyzer to use for the query.
- analyzer(String) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
Sets the analyzer to analyse to suggest text with.
- ANALYZER - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- ANALYZER - Static variable in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction.Fields
- ANALYZER_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- ANALYZER_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- AnalyzerComponents - Class in org.elasticsearch.index.analysis
-
A class that groups analysis components necessary to produce a custom analyzer.
- AnalyzerComponentsProvider - Interface in org.elasticsearch.index.analysis
-
Analyzers that provide access to their token filters should implement this
- AnalyzeRequestBuilder - Class in org.elasticsearch.action.admin.indices.analyze
- AnalyzeRequestBuilder(ElasticsearchClient, AnalyzeAction) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
- AnalyzeRequestBuilder(ElasticsearchClient, AnalyzeAction, String, String...) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
- AnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer> - Interface in org.elasticsearch.index.analysis
- analyzers() - Method in class org.elasticsearch.index.analysis.FieldNameAnalyzer
- AnalyzerScope - Enum in org.elasticsearch.index.analysis
- analyzeSynonyms(TokenStream, int, boolean) - Method in class org.elasticsearch.index.query.IntervalBuilder
- analyzeTerm(TokenStream) - Method in class org.elasticsearch.index.query.IntervalBuilder
- analyzeTerms(TokenStream) - Method in class org.elasticsearch.index.query.IntervalBuilder
- analyzeText(String, int, boolean) - Method in class org.elasticsearch.index.query.IntervalBuilder
- analyzeText(CachingTokenFilter, int, boolean) - Method in class org.elasticsearch.index.query.IntervalBuilder
- AnalyzeToken(String, int, int, int, int, String, Map<String, Object>) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeToken
- AnalyzeTokenList(String, AnalyzeAction.AnalyzeToken[]) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeTokenList
- analyzeWildcard() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- analyzeWildcard() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns whether wildcards should by analyzed.
- analyzeWildcard() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Returns whether to analyze wildcards.
- analyzeWildcard(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Specifies whether wildcards should be analyzed.
- analyzeWildcard(boolean) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Specifies whether to analyze wildcards.
- analyzeWildcard(Boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Set to
true
to enable analysis on wildcard and prefix queries. - and(Matcher<? super T>) - Method in class org.elasticsearch.common.inject.matcher.AbstractMatcher
- and(Matcher<? super T>) - Method in interface org.elasticsearch.common.inject.matcher.Matcher
-
Returns a new matcher which returns
true
if both this and the given matcher returntrue
. - AND - org.elasticsearch.cluster.node.DiscoveryNodeFilters.OpType
- AND - org.elasticsearch.index.query.Operator
- AND - org.elasticsearch.index.query.SimpleQueryStringFlag
- AnnotatedBindingBuilder<T> - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - AnnotatedConstantBindingBuilder - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - AnnotatedElementBuilder - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedConstantBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedElementBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- annotatedWith(Annotation) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- annotatedWith(Annotation) - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- annotatedWith(Annotation) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches elements (methods, classes, etc.) with a given annotation.
- annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedConstantBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedElementBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- annotatedWith(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches elements (methods, classes, etc.) with a given annotation.
- annotatedWithInternal(Annotation) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
-
Sets the binding to a copy with the specified annotation on the bound key
- annotatedWithInternal(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
-
Sets the binding to a copy with the specified annotation on the bound key
- ANNOTATION_ALREADY_SPECIFIED - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- Annotations - Class in org.elasticsearch.common.inject.internal
-
Annotation utilities.
- Annotations() - Constructor for class org.elasticsearch.common.inject.internal.Annotations
- any() - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches any input.
- ANY - org.elasticsearch.search.aggregations.support.ValuesSourceType
- ANY_ORIGIN - Static variable in class org.elasticsearch.http.CorsHandler
- anySet() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- ANYSTRING - org.elasticsearch.index.query.RegexpFlag
-
Enables any string expression:
@
- API - org.elasticsearch.cluster.metadata.MetaData.XContentContext
- API_AND_GATEWAY - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
Indicates that this custom metadata will be returned as part of an API call and will be persisted between node restarts, but will not be a part of a snapshot global state
- API_AND_SNAPSHOT - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
Indicates that this custom metadata will be returned as part of an API call and stored as a part of a snapshot global state, but will not be persisted between node restarts
- API_ONLY - Static variable in class org.elasticsearch.cluster.metadata.MetaData
-
Indicates that this custom metadata will be returned as part of an API call but will not be persisted
- append(Path, Path, int) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Appends the path to the given base and strips N elements off the path if strip is > 0.
- appendElement(T[], T) - Static method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
- appendFieldValue(String, Object) - Method in class org.elasticsearch.ingest.IngestDocument
-
Appends the provided value to the provided path in the document.
- appendFieldValue(TemplateScript.Factory, ValueSource) - Method in class org.elasticsearch.ingest.IngestDocument
-
Appends the provided value to the provided path in the document.
- appendThreadPoolExecutorDetails(StringBuilder) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
-
Append details about this thread pool to the specified
StringBuilder
. - appendThreadPoolExecutorDetails(StringBuilder) - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
- applicationMayFail() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- apply(double) - Method in enum org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- apply(long) - Method in interface org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator.GlobalOrdLookupFunction
- apply(String, ActionRequest, ActionListener<?>) - Method in class org.elasticsearch.action.support.ActionFilter.Simple
-
Applies this filter and returns
true
if the execution chain should proceed, orfalse
if it should be aborted since the filter already handled the request and called the given listener. - apply(DiffableStringMap) - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap.DiffableStringMapDiff
- apply(MetaData.Custom) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.IndexGraveyardDiff
- apply(ImmutableOpenMap<K, T>) - Method in class org.elasticsearch.cluster.DiffableUtils.ImmutableOpenMapDiff
- apply(Settings, Settings) - Method in interface org.elasticsearch.common.settings.AbstractScopedSettings.SettingUpdater
-
Updates this updaters value if it has changed.
- apply(Task, String, Request, ActionListener<Response>, ActionFilterChain<Request, Response>) - Method in interface org.elasticsearch.action.support.ActionFilter
-
Enables filtering the execution of an action on the request side, either by sending a response through the
ActionListener
or by continuing the execution through the givenchain
- apply(Task, String, Request, ActionListener<Response>, ActionFilterChain<Request, Response>) - Method in class org.elasticsearch.action.support.ActionFilter.Simple
- apply(S, T, U) - Method in interface org.elasticsearch.common.TriConsumer
-
Applies this function to the given arguments.
- apply(S, T, U) - Method in interface org.elasticsearch.common.TriFunction
-
Applies this function to the given arguments.
- apply(T) - Method in interface org.elasticsearch.cluster.Diff
-
Applies difference to the specified part and returns the resulted part
- apply(T, Settings, Settings) - Method in interface org.elasticsearch.common.settings.AbstractScopedSettings.SettingUpdater
-
Applies the given value to the updater.
- apply(T, U) - Method in interface org.elasticsearch.common.CheckedBiFunction
- apply(T, U, ActionListener<C>) - Method in interface org.elasticsearch.common.AsyncBiFunction
- applyAsLong(IndicesFieldDataCache.Key, Accountable) - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.FieldDataWeigher
- applyChanges(MetaData, RoutingTable) - Method in class org.elasticsearch.cluster.routing.allocation.IndexMetaDataUpdater
-
Updates the current
MetaData
based on the changes of this RoutingChangesObserver. - applyChanges(RestoreInProgress) - Method in class org.elasticsearch.snapshots.RestoreService.RestoreInProgressUpdater
- applyClusterState(ClusterChangedEvent) - Method in class org.elasticsearch.action.ingest.IngestActionForwarder
- applyClusterState(ClusterChangedEvent) - Method in interface org.elasticsearch.cluster.ClusterStateApplier
-
Called when a new cluster state (
ClusterChangedEvent.state()
needs to be applied. - applyClusterState(ClusterChangedEvent) - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
- applyClusterState(ClusterChangedEvent) - Method in class org.elasticsearch.ingest.IngestService
- applyClusterState(ClusterChangedEvent) - Method in class org.elasticsearch.repositories.RepositoriesService
-
Checks if new repositories appeared in or disappeared from cluster metadata and updates current list of repositories accordingly.
- applyClusterState(ClusterChangedEvent) - Method in class org.elasticsearch.script.ScriptService
- applyClusterState(ClusterChangedEvent) - Method in class org.elasticsearch.snapshots.RestoreService
- applyClusterState(ClusterChangedEvent) - Method in class org.elasticsearch.snapshots.SnapshotsService
- applyClusterState(ClusterChangedEvent) - Method in class org.elasticsearch.tasks.TaskManager
- ApplyCommitRequest - Class in org.elasticsearch.cluster.coordination
-
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.
- ApplyCommitRequest(DiscoveryNode, long, long) - Constructor for class org.elasticsearch.cluster.coordination.ApplyCommitRequest
- ApplyCommitRequest(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.ApplyCommitRequest
- applyContentParser(CheckedConsumer<XContentParser, IOException>) - Method in class org.elasticsearch.rest.RestRequest
-
If there is any content then call
applyParser
with the parser, otherwise do nothing. - applyDeleteOperationOnPrimary(long, String, String, VersionType, long, long) - Method in class org.elasticsearch.index.shard.IndexShard
- applyDeleteOperationOnReplica(long, long, String, String) - Method in class org.elasticsearch.index.shard.IndexShard
- applyFailedShard(ClusterState, ShardRouting, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
- applyFailedShards(ClusterState, List<FailedShard>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
- applyFailedShards(ClusterState, List<FailedShard>, List<StaleShard>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Applies the failed shards.
- applyFailedShards(RoutingAllocation, List<FailedShard>) - Method in class org.elasticsearch.gateway.GatewayAllocator
- applyHardSizeLimit(Settings, String) - Method in class org.elasticsearch.threadpool.ExecutorBuilder
- applyIndexOperationOnPrimary(long, VersionType, SourceToParse, long, long, long, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
- applyIndexOperationOnReplica(long, long, long, boolean, SourceToParse) - Method in class org.elasticsearch.index.shard.IndexShard
- applyMinimumShouldMatch(BooleanQuery, String) - Static method in class org.elasticsearch.common.lucene.search.Queries
- applySettings(Settings) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Applies the given settings to all the settings consumers or to none of them.
- applyStartedShards(ClusterState, List<ShardRouting>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Applies the started shards.
- applyStartedShards(RoutingAllocation, List<ShardRouting>) - Method in class org.elasticsearch.gateway.GatewayAllocator
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- applyTo(Binder) - Method in interface org.elasticsearch.common.inject.spi.Element
-
Writes this module element to the given binder (optional operation).
- applyTo(Binder) - Method in interface org.elasticsearch.common.inject.spi.ExposedBinding
-
Unsupported.
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.Message
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.ScopeBinding
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.StaticInjectionRequest
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.TypeConverterBinding
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.TypeListenerBinding
- applyTo(ScopedBindingBuilder) - Method in class org.elasticsearch.common.inject.internal.Scoping
- applyTranslogOperation(Translog.Operation, Engine.Operation.Origin) - Method in class org.elasticsearch.index.shard.IndexShard
- approximateCardinality() - Method in class org.apache.lucene.util.CombinedBitSet
- ARC - org.elasticsearch.common.geo.GeoDistance
- arcDistance(double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- arcDistance(double, double, double, double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Return the distance (in meters) between 2 lat,lon geo points using the haversine method implemented by lucene
- arcDistanceWithDefault(double, double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- ARCHIVED_SETTINGS_PREFIX - Static variable in class org.elasticsearch.common.settings.AbstractScopedSettings
- archiveUnknownOrInvalidSettings(Settings, Consumer<Map.Entry<String, String>>, BiConsumer<Map.Entry<String, String>, IllegalArgumentException>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Archives invalid or unknown settings.
- areAllConsistent() - Method in class org.elasticsearch.common.settings.ConsistentSettingsService
-
Verifies that the hashes of consistent secure settings in the latest
ClusterState
verify for the values of those same settings on the local node. - areValuesSourcesEmpty() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSource
- array() - Method in class org.elasticsearch.common.bytes.BytesArray
- arrayAsArrayList(E...) - Static method in class org.elasticsearch.common.util.CollectionUtils
- arrayOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns an array type whose elements are all instances of
componentType
. - arrayToCommaDelimitedString(Object[]) - Static method in class org.elasticsearch.common.Strings
-
Convenience method to return a String array as a CSV String.
- arrayToDelimitedString(Object[], String) - Static method in class org.elasticsearch.common.Strings
-
Convenience method to return a String array as a delimited (e.g.
- arrayToDelimitedString(Object[], String, StringBuilder) - Static method in class org.elasticsearch.common.Strings
- ArrayUtils - Class in org.elasticsearch.common.util
- ArrayValueMapperParser - Interface in org.elasticsearch.index.mapper
-
A marker interface indicating that this mapper can handle array value, and the array itself should be passed to it.
- asArrayList(E, E...) - Static method in class org.elasticsearch.common.util.CollectionUtils
- asArrayList(E, E, E...) - Static method in class org.elasticsearch.common.util.CollectionUtils
- asc - Variable in class org.elasticsearch.search.aggregations.InternalOrder
- ASC - org.elasticsearch.search.sort.SortOrder
-
Ascending order.
- asCopy() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Returns a copy of the current
IndexShardSnapshotStatus
. - asDistance() - Method in class org.elasticsearch.common.unit.Fuzziness
- asDistance(String) - Method in class org.elasticsearch.common.unit.Fuzziness
- asEagerSingleton() - Method in interface org.elasticsearch.common.inject.binder.ScopedBindingBuilder
-
Instructs the
Injector
to eagerly initialize this singleton-scoped binding upon creation. - asEagerSingleton() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- asFloat() - Method in class org.elasticsearch.common.unit.Fuzziness
- asJsonArray(Stream<String>) - Static method in class org.elasticsearch.common.logging.ESLogMessage
- asList() - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
Returns the it as a non null list.
- asList() - Method in class org.elasticsearch.search.aggregations.Aggregations
-
The list of
Aggregation
s. - asMap() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- asMap() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
- asMap() - Method in class org.elasticsearch.search.aggregations.Aggregations
-
Returns the
Aggregation
s keyed by aggregation name. - asMap() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
- asMultiBucketAggregator(AggregatorFactory, SearchContext, Aggregator) - Static method in class org.elasticsearch.search.aggregations.AggregatorFactory
-
Utility method.
- asSequentialAccessBits(int, ScorerSupplier) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Return a
Bits
view of the provided scorer. - asSequentialAccessBits(int, ScorerSupplier, long) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Given a
ScorerSupplier
, return aBits
instance that will match all documents contained in the set. - assertClusterOrMasterStateThread() - Method in class org.elasticsearch.cluster.routing.DelayedAllocationService
- assertClusterOrMasterStateThread() - Static method in class org.elasticsearch.cluster.service.ClusterService
- assertCurrentMethodIsNotCalledRecursively() - Static method in class org.elasticsearch.threadpool.ThreadPool
- assertEquivalent(Environment, Environment) - Static method in class org.elasticsearch.env.Environment
-
asserts that the two environments are equivalent for all things the environment cares about (i.e., all but the setting object which may contain different setting)
- Assertions - Class in org.elasticsearch
-
Provides a static final field that can be used to check if assertions are enabled.
- assertMasterUpdateThread() - Static method in class org.elasticsearch.cluster.service.MasterService
- assertMaxSeqNoEqualsToGlobalCheckpoint(long, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- assertNonPrimaryOrigin(Engine.Operation) - Method in class org.elasticsearch.index.engine.InternalEngine
- assertNoOpenTranslogRefs() - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
- assertNotClusterStateUpdateThread(String) - Static method in class org.elasticsearch.cluster.service.ClusterApplierService
-
asserts that the current thread is NOT the cluster state update thread
- assertNotMasterUpdateThread(String) - Static method in class org.elasticsearch.cluster.service.MasterService
- assertNotScheduleThread(String) - Static method in class org.elasticsearch.threadpool.ThreadPool
- assertNotTransportThread(String) - Static method in enum org.elasticsearch.transport.Transports
- assertPrimaryCanOptimizeAddDocument(Engine.Index) - Method in class org.elasticsearch.index.engine.InternalEngine
- assertPrimaryIncomingSequenceNumber(Engine.Operation.Origin, long) - Method in class org.elasticsearch.index.engine.InternalEngine
- assertRetentionLeasesPersisted() - Method in class org.elasticsearch.index.shard.IndexShard
- assertRetentionLeasesPersisted(Path) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
- assertShardStats(RoutingNodes) - Static method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Calculates RoutingNodes statistics by iterating over all
ShardRouting
s in the cluster to ensure the book-keeping is correct. - assertSnapshotOrGenericThread() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- assertTransportThread() - Static method in enum org.elasticsearch.transport.Transports
- assertZValue(boolean, double) - Static method in class org.elasticsearch.common.geo.GeoPoint
- assignedShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of assigned shards, including relocation targets - assignedShards(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns all shards that are not in the state UNASSIGNED with the same shard ID as the given shard.
- assignedToNode() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns
true
iff this shard is assigned to a node ie. - Assignment(String, String) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Assignment
- ASSIGNMENT_PARSER - Static variable in class org.elasticsearch.persistent.PersistentTasksCustomMetaData
- AssignmentDecision - Class in org.elasticsearch.persistent.decider
-
AssignmentDecision
represents the decision made during the process of assigning a persistent task to a node of the cluster. - AssignmentDecision(AssignmentDecision.Type, String) - Constructor for class org.elasticsearch.persistent.decider.AssignmentDecision
- AssignmentDecision.Type - Enum in org.elasticsearch.persistent.decider
- Assisted - Annotation Type in org.elasticsearch.common.inject.assistedinject
-
Annotates an injected parameter or field whose value comes from an argument to a factory method.
- AssistedInject - Annotation Type in org.elasticsearch.common.inject.assistedinject
-
Deprecated.
FactoryProvider
now works better with the standard @Inject annotation. When using that annotation, parameters are matched by name and type rather than by position. In addition, values that use the standard @Inject constructor annotation are eligible for method interception. - associateIndexWithNewTranslog(String) - Method in class org.elasticsearch.index.store.Store
-
Force bakes the given translog generation as recovery information in the lucene index.
- asString() - Method in class org.elasticsearch.common.unit.Fuzziness
- ASYNC - org.elasticsearch.index.translog.Translog.Durability
-
Async durability - translogs are synced based on a time interval.
- AsyncAction(Task, Request, ActionListener<Response>) - Constructor for class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- AsyncBiFunction<T,U,C> - Interface in org.elasticsearch.common
-
A
BiFunction
-like interface designed to be used with asynchronous executions. - AsyncBroadcastAction(Task, Request, ActionListener<Response>) - Constructor for class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- AsyncIOProcessor<Item> - Class in org.elasticsearch.common.util.concurrent
-
This async IO processor allows to batch IO operations and have a single writer processing the write operations.
- AsyncIOProcessor(Logger, int, ThreadContext) - Constructor for class org.elasticsearch.common.util.concurrent.AsyncIOProcessor
- AsyncShardFetch<T extends BaseNodeResponse> - Class in org.elasticsearch.gateway
-
Allows to asynchronously fetch shard related data from other nodes for allocation, without blocking the cluster update thread.
- AsyncShardFetch(Logger, String, ShardId, AsyncShardFetch.Lister<? extends BaseNodesResponse<T>, T>) - Constructor for class org.elasticsearch.gateway.AsyncShardFetch
- AsyncShardFetch.FetchResult<T extends BaseNodeResponse> - Class in org.elasticsearch.gateway
-
The result of a fetch operation.
- AsyncShardFetch.Lister<NodesResponse extends BaseNodesResponse<NodeResponse>,NodeResponse extends BaseNodeResponse> - Interface in org.elasticsearch.gateway
-
An action that lists the relevant shard data that needs to be fetched.
- asyncShardOperation(ExplainRequest, ShardId, ActionListener<ExplainResponse>) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- asyncShardOperation(GetRequest, ShardId, ActionListener<GetResponse>) - Method in class org.elasticsearch.action.get.TransportGetAction
- asyncShardOperation(MultiGetShardRequest, ShardId, ActionListener<MultiGetShardResponse>) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- asyncShardOperation(TermVectorsRequest, ShardId, ActionListener<TermVectorsResponse>) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- asyncShardOperation(Request, ShardId, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- atLeastOneNodeWithYesDecision() - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Returns
true
if there is at least one node that returned aDecision.Type.YES
decision for allocating this shard. - AtomicArray<E> - Class in org.elasticsearch.common.util.concurrent
-
A list backed by an
AtomicReferenceArray
with potential null values, easily allowing to get the concrete values as a list usingAtomicArray.asList()
. - AtomicArray(int) - Constructor for class org.elasticsearch.common.util.concurrent.AtomicArray
- AtomicFieldData - Interface in org.elasticsearch.index.fielddata
-
The thread safe
LeafReader
level cache of the data. - AtomicGeoPointFieldData - Interface in org.elasticsearch.index.fielddata
-
AtomicFieldData
specialization for geo points. - AtomicNumericFieldData - Interface in org.elasticsearch.index.fielddata
-
Specialization of
AtomicFieldData
for numeric data. - AtomicOrdinalsFieldData - Interface in org.elasticsearch.index.fielddata
-
Specialization of
AtomicFieldData
for data that is indexed with ordinals. - attemptSyncedFlush(String[], IndicesOptions, ActionListener<SyncedFlushResponse>) - Method in class org.elasticsearch.indices.flush.SyncedFlushService
-
a utility method to perform a synced flush for all shards of multiple indices.
- attemptSyncedFlush(ShardId, ActionListener<ShardsSyncedFlushResult>) - Method in class org.elasticsearch.indices.flush.SyncedFlushService
- attr - Variable in class org.elasticsearch.common.Table.Cell
- attributes - Variable in class org.elasticsearch.index.engine.Segment
- attributes() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- attributes() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- attributes(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- attributes(List<String>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- ATTRIBUTES - Static variable in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction.Fields
- AUTO - Static variable in class org.elasticsearch.common.unit.Fuzziness
- AUTO_CREATE_INDEX_SETTING - Static variable in class org.elasticsearch.action.support.AutoCreateIndex
- AUTO_INDEX_JTS_GEOMETRY - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
- AUTO_RELEASE_INDEX_ENABLED_KEY - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- AUTO_SLICES - Static variable in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- AUTO_SLICES_VALUE - Static variable in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- AUTO_THROTTLE_SETTING - Static variable in class org.elasticsearch.index.MergeSchedulerConfig
- AUTO_VALIDATE_JTS_GEOMETRY - Static variable in class org.elasticsearch.common.geo.builders.ShapeBuilder
- AutoCreateIndex - Class in org.elasticsearch.action.support
-
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.
- AutoCreateIndex(Settings, ClusterSettings, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.support.AutoCreateIndex
- AutoDateHistogramAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.histogram
- AutoDateHistogramAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
-
Create a new builder with the given name.
- AutoDateHistogramAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
-
Read from a stream, for internal use only.
- AutoDateHistogramAggregationBuilder(AutoDateHistogramAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- AutoDateHistogramAggregationBuilder.RoundingInfo - Class in org.elasticsearch.search.aggregations.bucket.histogram
- AutoDateHistogramAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.histogram
- AutoDateHistogramAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Numeric>, int, AutoDateHistogramAggregationBuilder.RoundingInfo[], QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregatorFactory
- AutoExpandReplicas - Class in org.elasticsearch.cluster.metadata
-
This class acts as a functional wrapper around the
index.auto_expand_replicas
setting. - autoGenerateSynonymsPhraseQuery - Variable in class org.elasticsearch.index.search.MatchQuery
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- autoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
- AutoQueueAdjustingExecutorBuilder - Class in org.elasticsearch.threadpool
-
A builder for executors that automatically adjust the queue length as needed, depending on Little's Law.
- available() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- available() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- available() - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- available() - Method in class org.elasticsearch.common.io.stream.StreamInput
- available() - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
- availableCodecs() - Method in class org.elasticsearch.index.codec.CodecService
-
Returns all registered available codec names
- availableIndexFolders() - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all folder names in ${data.paths}/nodes/{node.id}/indices folder
- availableIndexFolders(Predicate<String>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns folder names in ${data.paths}/nodes/{node.id}/indices folder that don't match the given predicate.
- availableIndexFoldersForPath(NodeEnvironment.NodePath) - Method in class org.elasticsearch.env.NodeEnvironment
-
Return all directory names in the nodes/{node.id}/indices directory for the given node path.
- availableIndexFoldersForPath(NodeEnvironment.NodePath, Predicate<String>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Return directory names in the nodes/{node.id}/indices directory for the given node path that don't match the given predicate.
- availableShardPaths(ShardId) - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all shard paths excluding custom shard path.
- availableShards() - Method in class org.elasticsearch.indices.IndexingMemoryController
- avg - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- avg - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- avg(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Avg
aggregation with the given name. - Avg - org.elasticsearch.search.rescore.QueryRescoreMode
- Avg - Interface in org.elasticsearch.search.aggregations.metrics
-
An aggregation that computes the average of the values in the current bucket.
- AVG - org.elasticsearch.common.lucene.search.function.CombineFunction
- AVG - org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- AVG - org.elasticsearch.search.MultiValueMode
-
Pick the average of all the values.
- AVG - org.elasticsearch.search.sort.SortMode
-
Use the average of all values as sort value.
- AvgAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- AvgAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- AvgAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
-
Read from a stream.
- AvgAggregationBuilder(AvgAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- avgBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- AvgBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- AvgBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregationBuilder
- AvgBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregationBuilder
-
Read from a stream.
- AvgBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- AvgBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregator
-
Read from a stream.
- avgShardsPerNode() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
-
Returns the global average of shards per node
- avgShardsPerNode(String) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
-
Returns the average of shards per node for the given index
- awaitAllNodes(TimeValue) - Method in class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
Allows to wait for all non master nodes to reply to the publish event up to a timeout
- awaitClose(long, TimeUnit) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Closes the processor.
- awaitClose(long, TimeUnit) - Method in class org.elasticsearch.indices.IndicesService
-
Wait for this
IndicesService
to be effectively closed. - awaitClose(long, TimeUnit) - Method in class org.elasticsearch.node.Node
-
Wait for this node to be effectively closed.
- awaitClose(long, TimeUnit) - Method in class org.elasticsearch.node.NodeService
-
Wait for the node to be effectively closed.
- AWAITING_INFO - org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
Waiting on getting shard data from all nodes before making a decision about where to allocate the shard.
- awaitShardSearchActive(Consumer<Boolean>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Registers the given listener and invokes it once the shard is active again and all pending refresh translog location has been refreshed.
- awaitTermination() - Method in interface org.elasticsearch.index.IndexWarmer.TerminationHandle
-
Wait until execution of the warm-up action completes.
- awaitTermination(long, TimeUnit) - Method in class org.elasticsearch.threadpool.ThreadPool
- awaitTermination(ScheduledThreadPoolExecutor, long, TimeUnit) - Static method in interface org.elasticsearch.threadpool.Scheduler
- AwarenessAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This
AllocationDecider
controls shard allocation based onawareness
key-value pairs defined in the node configuration. - AwarenessAllocationDecider(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
B
- BACKGROUND_IS_SUPERSET - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- backgroundFilter() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- backgroundFilter() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- backgroundFilter(QueryBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- backgroundFilter(QueryBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- backgroundIsSuperset - Variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- backgroundIsSuperset - Variable in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYBuilder
- backgroundSync(ShardId, RetentionLeases) - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
-
Background sync the specified retention leases for the specified shard.
- backgroundSync(ShardId, RetentionLeases) - Method in interface org.elasticsearch.index.seqno.RetentionLeaseSyncer
- backoffPolicy - Variable in class org.elasticsearch.index.reindex.ScrollableHitSource
- BackoffPolicy - Class in org.elasticsearch.action.bulk
-
Provides a backoff policy for bulk requests.
- BackoffPolicy() - Constructor for class org.elasticsearch.action.bulk.BackoffPolicy
- BAD_GATEWAY - org.elasticsearch.rest.RestStatus
-
The server, while acting as a gateway or proxy, received an invalid response from the upstream server it accessed in attempting to fulfill the request.
- BAD_REQUEST - org.elasticsearch.rest.RestStatus
-
The request could not be understood by the server due to malformed syntax.
- BALANCED_ALLOCATOR - Static variable in class org.elasticsearch.cluster.ClusterModule
- BalancedShardsAllocator - Class in org.elasticsearch.cluster.routing.allocation.allocator
-
The
BalancedShardsAllocator
re-balances the nodes allocations within an cluster based on aBalancedShardsAllocator.WeightFunction
. - BalancedShardsAllocator(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- BalancedShardsAllocator(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- BalancedShardsAllocator.Balancer - Class in org.elasticsearch.cluster.routing.allocation.allocator
- BalancedShardsAllocator.WeightFunction - Class in org.elasticsearch.cluster.routing.allocation.allocator
-
This class is the primary weight function used to create balanced over nodes and shards in the cluster.
- Balancer(Logger, RoutingAllocation, BalancedShardsAllocator.WeightFunction, float) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
- BAN_PARENT_ACTION_NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.TransportCancelTasksAction
- base64UUID() - Static method in class org.elasticsearch.common.UUIDs
-
Generates a time-based UUID (similar to Flake IDs), which is preferred when generating an ID to be indexed into a Lucene index as primary key.
- BaseAggregationBuilder - Interface in org.elasticsearch.search.aggregations
-
Interface shared by
AggregationBuilder
andPipelineAggregationBuilder
so they can conveniently share the same namespace forXContentParser.namedObject(Class, String, Object)
. - BaseAliasesRequestBuilder<Response extends ActionResponse,Builder extends BaseAliasesRequestBuilder<Response,Builder>> - Class in org.elasticsearch.action.admin.indices.alias.get
- BaseAliasesRequestBuilder(ElasticsearchClient, ActionType<Response>, String...) - Constructor for class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
- BaseFuture<V> - Class in org.elasticsearch.common.util.concurrent
- BaseFuture() - Constructor for class org.elasticsearch.common.util.concurrent.BaseFuture
- BaseGatewayShardAllocator - Class in org.elasticsearch.gateway
-
An abstract class that implements basic functionality for allocating shards to nodes based on shard copies that already exist in the cluster.
- BaseGatewayShardAllocator() - Constructor for class org.elasticsearch.gateway.BaseGatewayShardAllocator
- BaseNodeRequest - Class in org.elasticsearch.action.support.nodes
- BaseNodeRequest() - Constructor for class org.elasticsearch.action.support.nodes.BaseNodeRequest
- BaseNodeRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodeRequest
- BaseNodeResponse - Class in org.elasticsearch.action.support.nodes
-
A base class for node level operations.
- BaseNodeResponse(DiscoveryNode) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodeResponse
- BaseNodeResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodeResponse
- BaseNodesRequest<Request extends BaseNodesRequest<Request>> - Class in org.elasticsearch.action.support.nodes
- BaseNodesRequest(String...) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodesRequest
- BaseNodesRequest(DiscoveryNode...) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodesRequest
- BaseNodesRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodesRequest
- BaseNodesResponse<TNodeResponse extends BaseNodeResponse> - Class in org.elasticsearch.action.support.nodes
- BaseNodesResponse(ClusterName, List<TNodeResponse>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodesResponse
- BaseNodesResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodesResponse
- basePath() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Returns base path of the repository
- basePath() - Method in class org.elasticsearch.repositories.fs.FsRepository
- BasePrimaryAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Abstract base class for allocating an unassigned primary shard to a node
- BasePrimaryAllocationCommand(String, int, String, boolean) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
- BasePrimaryAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
-
Read from a stream.
- BasePrimaryAllocationCommand.Builder<T extends BasePrimaryAllocationCommand> - Class in org.elasticsearch.cluster.routing.allocation.command
- BaseRestHandler - Class in org.elasticsearch.rest
-
Base handler for REST requests.
- BaseRestHandler() - Constructor for class org.elasticsearch.rest.BaseRestHandler
- BaseRestHandler.RestChannelConsumer - Interface in org.elasticsearch.rest
-
REST requests are handled by preparing a channel consumer that represents the execution of the request against a channel.
- BaseTasksRequest<Request extends BaseTasksRequest<Request>> - Class in org.elasticsearch.action.support.tasks
-
A base class for task requests
- BaseTasksRequest() - Constructor for class org.elasticsearch.action.support.tasks.BaseTasksRequest
- BaseTasksRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.tasks.BaseTasksRequest
- BaseTasksResponse - Class in org.elasticsearch.action.support.tasks
-
Base class for responses of task-related operations
- BaseTasksResponse(List<TaskOperationFailure>, List<? extends ElasticsearchException>) - Constructor for class org.elasticsearch.action.support.tasks.BaseTasksResponse
- BaseTasksResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.tasks.BaseTasksResponse
- BaseTermQueryBuilder<QB extends BaseTermQueryBuilder<QB>> - Class in org.elasticsearch.index.query
- BaseTermQueryBuilder(String, boolean) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(String, double) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(String, float) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(String, long) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Read from a stream.
- BaseTranslogReader - Class in org.elasticsearch.index.translog
-
A base class for all classes that allows reading ops from translog files
- BaseTranslogReader(long, FileChannel, Path, TranslogHeader) - Constructor for class org.elasticsearch.index.translog.BaseTranslogReader
- basic() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Gets a new
SnapshotInfo
instance from the givenSnapshotInfo
with all information stripped out except the snapshot id, state, and indices. - Basic(Priority, TimeValue) - Constructor for class org.elasticsearch.cluster.ClusterStateTaskConfig.Basic
- BASIC_DATE - org.elasticsearch.common.time.FormatNames
- BASIC_DATE_TIME - org.elasticsearch.common.time.FormatNames
- BASIC_DATE_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- BASIC_ORDINAL_DATE - org.elasticsearch.common.time.FormatNames
- BASIC_ORDINAL_DATE_TIME - org.elasticsearch.common.time.FormatNames
- BASIC_ORDINAL_DATE_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- BASIC_T_TIME - org.elasticsearch.common.time.FormatNames
- BASIC_T_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- BASIC_TIME - org.elasticsearch.common.time.FormatNames
- BASIC_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- BASIC_WEEK_DATE - org.elasticsearch.common.time.FormatNames
- BASIC_WEEK_DATE_TIME - org.elasticsearch.common.time.FormatNames
- BASIC_WEEK_DATE_TIME_NO_MILLIS - org.elasticsearch.common.time.FormatNames
- basicDate() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a full date as four digit year, two digit month of year, and two digit day of month (yyyyMMdd).
- basicDateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter that combines a basic date and time, separated by a 'T' (yyyyMMdd'T'HHmmss.SSSZ).
- basicDateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter that combines a basic date and time without millis, separated by a 'T' (yyyyMMdd'T'HHmmssZ).
- BasicHit(String, String, String, long) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- basicOrdinalDate() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date, using a four digit year and three digit dayOfYear (yyyyDDD).
- basicOrdinalDateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date and time, using a four digit year and three digit dayOfYear (yyyyDDD'T'HHmmss.SSSZ).
- basicOrdinalDateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date and time without millis, using a four digit year and three digit dayOfYear (yyyyDDD'T'HHmmssZ).
- BasicReplicationRequest - Class in org.elasticsearch.action.support.replication
-
A replication request that has no more information than ReplicationRequest.
- BasicReplicationRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.replication.BasicReplicationRequest
- BasicReplicationRequest(ShardId) - Constructor for class org.elasticsearch.action.support.replication.BasicReplicationRequest
-
Creates a new request with resolved shard id
- basicTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, three digit millis, and time zone offset (HHmmss.SSSZ).
- basicTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and time zone offset (HHmmssZ).
- basicTTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, three digit millis, and time zone offset prefixed by 'T' ('T'HHmmss.SSSZ).
- basicTTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and time zone offset prefixed by 'T' ('T'HHmmssZ).
- basicWeekDate() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a full date as four digit weekyear, two digit week of weekyear, and one digit day of week (xxxx'W'wwe).
- basicWeekDateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter that combines a basic weekyear date and time, separated by a 'T' (xxxx'W'wwe'T'HHmmss.SSSZ).
- basicWeekDateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter that combines a basic weekyear date and time without millis, separated by a 'T' (xxxx'W'wwe'T'HHmmssZ).
- BatchedRerouteService - Class in org.elasticsearch.cluster.routing
-
A
BatchedRerouteService
is aRerouteService
that batches together reroute requests to avoid unnecessary extra reroutes. - BatchedRerouteService(ClusterService, BiFunction<ClusterState, String, ClusterState>) - Constructor for class org.elasticsearch.cluster.routing.BatchedRerouteService
- BatchedTask(Priority, String, Object, Object) - Constructor for class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
- BATCHES_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- batchingKey - Variable in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
-
the object that is used as batching key
- bdd - Variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- becomeMasterAndTrimConflictingNodes(ClusterState, List<JoinTaskExecutor.Task>) - Method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor
- before(Version) - Method in class org.elasticsearch.Version
- beforeBulk(long, BulkRequest) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
-
Callback before the bulk is executed.
- beforeClose() - Method in class org.elasticsearch.common.component.LifecycleListener
- beforeExecute(Thread, Runnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- beforeIndexAddedToCluster(Index, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called on the Master node only before the
IndexService
instances is created to simulate an index creation. - beforeIndexCreated(Index, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index gets created.
- beforeIndexRemoved(IndexService, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index get closed.
- beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index shard gets closed.
- beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.indices.recovery.PeerRecoverySourceService
- beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
- beforeIndexShardClosed(ShardId, IndexShard, Settings) - Method in class org.elasticsearch.snapshots.SnapshotShardsService
- beforeIndexShardCreated(ShardId, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index shard gets created.
- beforeIndexShardDeleted(ShardId, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index shard gets deleted from disk Note: this method is only executed on the first attempt of deleting the shard.
- beforeLoad(Terms) - Method in interface org.elasticsearch.index.fielddata.plain.AbstractIndexFieldData.PerValueEstimator
-
Execute any pre-loading estimations for the terms.
- beforeLoad(Terms) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.PagedBytesEstimator
-
Determine whether the BlockTreeTermsReader.FieldReader can be used for estimating the field data, adding the estimate to the circuit breaker if it can, otherwise wrapping the terms in a RamAccountingTermsEnum to be estimated on a per-term basis.
- beforeRefresh() - Method in class org.elasticsearch.index.shard.RefreshListeners
- beforeRelease() - Method in class org.elasticsearch.common.recycler.ConcurrentDequeRecycler
- beforeRelease() - Method in class org.elasticsearch.common.recycler.DequeRecycler
-
Called before releasing an object, returns true if the object should be recycled and false otherwise.
- beforeStart() - Method in class org.elasticsearch.common.component.LifecycleListener
- beforeStop() - Method in class org.elasticsearch.common.component.LifecycleListener
- BEST_COMPRESSION_CODEC - Static variable in class org.elasticsearch.index.codec.CodecService
- BEST_FIELDS - org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Uses the best matching boolean field as main score and uses a tie-breaker to adjust the score based on remaining field matches
- BestBucketsDeferringCollector - Class in org.elasticsearch.search.aggregations.bucket
-
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. - BestBucketsDeferringCollector(SearchContext, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
-
Sole constructor.
- BestDocsDeferringCollector - Class in org.elasticsearch.search.aggregations.bucket.sampler
-
A specialization of
DeferringBucketCollector
that collects all matches and then replays only the top scoring documents to child aggregations. - beta(double) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel.HoltLinearModelBuilder
-
Equivalent to
alpha
, but controls the smoothing of the trend instead of the data - beta(double) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
-
Equivalent to
alpha
, but controls the smoothing of the trend instead of the data - BG_COUNT - Static variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms
- BigArray - Interface in org.elasticsearch.common.util
-
Base abstraction of an array.
- bigArrays - Variable in class org.elasticsearch.common.io.stream.BytesStreamOutput
- bigArrays - Variable in class org.elasticsearch.http.AbstractHttpServerTransport
- bigArrays() - Method in class org.elasticsearch.index.query.QueryShardContext
-
Return the
BigArrays
instance for this node. - bigArrays() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
- bigArrays() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- bigArrays() - Method in class org.elasticsearch.search.internal.SearchContext
- BigArrays - Class in org.elasticsearch.common.util
-
Utility class to work with arrays.
- BigArrays(PageCacheRecycler, CircuitBreakerService, String) - Constructor for class org.elasticsearch.common.util.BigArrays
- BigArrays(PageCacheRecycler, CircuitBreakerService, String, boolean) - Constructor for class org.elasticsearch.common.util.BigArrays
- bigQuery() - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- bigQuery() - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- BINARY - org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- BINARY - Static variable in interface org.elasticsearch.search.DocValueFormat
- BinaryDocValuesRangeQuery - Class in org.apache.lucene.queries
- BinaryDocValuesRangeQuery(String, BinaryDocValuesRangeQuery.QueryType, RangeType.LengthType, BytesRef, BytesRef, Object, Object) - Constructor for class org.apache.lucene.queries.BinaryDocValuesRangeQuery
- BinaryDocValuesRangeQuery.QueryType - Enum in org.apache.lucene.queries
- BinaryDVAtomicFieldData - Class in org.elasticsearch.index.fielddata.plain
-
AtomicFieldData
impl on top of Lucene's binary doc values. - BinaryDVAtomicFieldData(LeafReader, String) - Constructor for class org.elasticsearch.index.fielddata.plain.BinaryDVAtomicFieldData
- BinaryDVIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- BinaryDVIndexFieldData(Index, String) - Constructor for class org.elasticsearch.index.fielddata.plain.BinaryDVIndexFieldData
- binaryField(FieldInfo, byte[]) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- binaryField(FieldInfo, byte[]) - Method in class org.elasticsearch.index.fieldvisitor.IdOnlyFieldVisitor
- binaryField(FieldInfo, byte[]) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- BinaryFieldMapper - Class in org.elasticsearch.index.mapper
- BinaryFieldMapper(String, MappedFieldType, MappedFieldType, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.BinaryFieldMapper
- BinaryFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- BinaryFieldMapper.CustomBinaryDocValuesField - Class in org.elasticsearch.index.mapper
- BinaryFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- BinaryFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- BinaryRange - Class in org.apache.lucene.document
-
A range field for binary encoded ranges
- BinaryRange(String, byte[]) - Constructor for class org.apache.lucene.document.BinaryRange
-
Create a new BinaryRange from a provided encoded binary range
- BinaryRangeAggregator - Class in org.elasticsearch.search.aggregations.bucket.range
-
A range aggregator for values that are stored in SORTED_SET doc values.
- BinaryRangeAggregator(String, AggregatorFactories, ValuesSource.Bytes, DocValueFormat, List<BinaryRangeAggregator.Range>, boolean, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregator
- BinaryRangeAggregator.Range - Class in org.elasticsearch.search.aggregations.bucket.range
- BinaryRangeAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.range
- BinaryRangeAggregatorFactory(String, ValuesSourceConfig<ValuesSource.Bytes>, List<BinaryRangeAggregator.Range>, boolean, QueryShardContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregatorFactory
- binarySearch(double[], double, double) - Static method in class org.elasticsearch.common.util.ArrayUtils
-
Return the index of
value
inarray
, or-1
if there is no such index. - binaryValue() - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.CustomBinaryDocValuesField
- bind(Class<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- bind(Class<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
See the EDSL examples at
Binder
. - bind(Class<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- bind(String, InetSocketAddress) - Method in class org.elasticsearch.transport.TcpTransport
-
Binds to the given
InetSocketAddress
- bind(InetSocketAddress) - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- bind(Key<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- bind(Key<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
See the EDSL examples at
Binder
. - bind(Key<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- bind(TypeLiteral<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- bind(TypeLiteral<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
See the EDSL examples at
Binder
. - bind(TypeLiteral<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- BIND_HOST - Static variable in class org.elasticsearch.transport.TransportSettings
- BIND_HOST_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- bindConstant() - Method in class org.elasticsearch.common.inject.AbstractModule
- bindConstant() - Method in interface org.elasticsearch.common.inject.Binder
-
See the EDSL examples at
Binder
. - binder - Variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- binder() - Method in class org.elasticsearch.common.inject.AbstractModule
-
Gets direct access to the underlying
Binder
. - binder() - Method in class org.elasticsearch.common.inject.PrivateModule
-
Returns the current binder.
- Binder - Interface in org.elasticsearch.common.inject
-
Collects configuration information (primarily bindings) which will be used to create an
Injector
. - bindHosts - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- BindHttpException - Exception in org.elasticsearch.http
- BindHttpException(String) - Constructor for exception org.elasticsearch.http.BindHttpException
- BindHttpException(String, Throwable) - Constructor for exception org.elasticsearch.http.BindHttpException
- BindHttpException(StreamInput) - Constructor for exception org.elasticsearch.http.BindHttpException
- Binding<T> - Interface in org.elasticsearch.common.inject
-
A mapping from a key (type and optional annotation) to the strategy for getting instances of the type.
- BINDING_TO_NULL - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- bindingAlreadySet(Key<?>, Object) - Method in class org.elasticsearch.common.inject.internal.Errors
- BindingAnnotation - Annotation Type in org.elasticsearch.common.inject
-
Annotates annotations which are used for binding.
- BindingBuilder<T> - Class in org.elasticsearch.common.inject.internal
-
Bind a non-constant key.
- BindingBuilder(Binder, List<Element>, Object, Key<T>) - Constructor for class org.elasticsearch.common.inject.internal.BindingBuilder
- BindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- BindingImpl(Object, Key<T>, Scoping) - Constructor for class org.elasticsearch.common.inject.internal.BindingImpl
- BindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping) - Constructor for class org.elasticsearch.common.inject.internal.BindingImpl
- BindingScopingVisitor<V> - Interface in org.elasticsearch.common.inject.spi
-
Visits each of the strategies used to scope an injection.
- BindingTargetVisitor<T,V> - Interface in org.elasticsearch.common.inject.spi
-
Visits each of the strategies used to find an instance to satisfy an injection.
- bindingToProvider() - Method in class org.elasticsearch.common.inject.internal.Errors
- bindListener(Matcher<? super TypeLiteral<?>>, TypeListener) - Method in class org.elasticsearch.common.inject.AbstractModule
- bindListener(Matcher<? super TypeLiteral<?>>, TypeListener) - Method in interface org.elasticsearch.common.inject.Binder
-
Registers a listener for injectable types.
- bindProperties(Binder, Map<String, String>) - Static method in class org.elasticsearch.common.inject.name.Names
-
Creates a constant binding to
@Named(key)
for each entry inproperties
. - bindProperties(Binder, Properties) - Static method in class org.elasticsearch.common.inject.name.Names
-
Creates a constant binding to
@Named(key)
for each property. - bindScope(Class<? extends Annotation>, Scope) - Method in class org.elasticsearch.common.inject.AbstractModule
- bindScope(Class<? extends Annotation>, Scope) - Method in interface org.elasticsearch.common.inject.Binder
-
Binds a scope to an annotation.
- bindServer() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- bindServer(TcpTransport.ProfileSettings) - Method in class org.elasticsearch.transport.TcpTransport
- BindTransportException - Exception in org.elasticsearch.transport
- BindTransportException(String) - Constructor for exception org.elasticsearch.transport.BindTransportException
- BindTransportException(String, Throwable) - Constructor for exception org.elasticsearch.transport.BindTransportException
- BindTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.BindTransportException
- binFile() - Method in class org.elasticsearch.env.Environment
- BitArray - Class in org.elasticsearch.common.util
- BitArray(int, BigArrays) - Constructor for class org.elasticsearch.common.util.BitArray
- bitsetFilter(Query) - Method in class org.elasticsearch.index.query.QueryShardContext
- bitsetFilterCache() - Method in class org.elasticsearch.index.cache.IndexCache
-
Return the
BitsetFilterCache
for this index. - bitsetFilterCache() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- bitsetFilterCache() - Method in class org.elasticsearch.search.internal.SearchContext
- BitsetFilterCache - Class in org.elasticsearch.index.cache.bitset
-
This is a cache for
BitDocIdSet
based filters and is unbounded by size or time. - BitsetFilterCache(IndexSettings, BitsetFilterCache.Listener) - Constructor for class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- BitsetFilterCache.Listener - Interface in org.elasticsearch.index.cache.bitset
-
A listener interface that is executed for each onCache / onRemoval event
- BitsetFilterCache.Value - Class in org.elasticsearch.index.cache.bitset
- bitsetFromQuery(Query, LeafReaderContext) - Static method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- blend(TermStates[], int, IndexReader) - Method in class org.apache.lucene.queries.BlendedTermQuery
- BlendedTermQuery - Class in org.apache.lucene.queries
-
BlendedTermQuery can be used to unify term statistics across one or more fields in the index.
- BlendedTermQuery(Term[], float[]) - Constructor for class org.apache.lucene.queries.BlendedTermQuery
- blobContainer() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
maintains single lazy instance of
BlobContainer
- blobContainer(BlobPath) - Method in interface org.elasticsearch.common.blobstore.BlobStore
-
Get a blob container instance for storing blobs at the given
BlobPath
. - blobContainer(BlobPath) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
- BlobContainer - Interface in org.elasticsearch.common.blobstore
-
An interface for managing a repository of blob entries, where each blob entry is just a named group of bytes.
- BlobMetaData - Interface in org.elasticsearch.common.blobstore
-
An interface for providing basic metadata about a blob.
- blobName(String) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- BlobPath - Class in org.elasticsearch.common.blobstore
-
The list of paths where a blob can reside.
- BlobPath() - Constructor for class org.elasticsearch.common.blobstore.BlobPath
- blobs() - Method in class org.elasticsearch.repositories.RepositoryCleanupResult
- blobsDeleted() - Method in class org.elasticsearch.common.blobstore.DeleteResult
- blobStore - Variable in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- blobStore() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Maintains single lazy instance of
BlobStore
. - BlobStore - Interface in org.elasticsearch.common.blobstore
-
An interface for storing blobs.
- BlobStoreException - Exception in org.elasticsearch.common.blobstore
- BlobStoreException(String) - Constructor for exception org.elasticsearch.common.blobstore.BlobStoreException
- BlobStoreException(String, Throwable) - Constructor for exception org.elasticsearch.common.blobstore.BlobStoreException
- BlobStoreException(StreamInput) - Constructor for exception org.elasticsearch.common.blobstore.BlobStoreException
- BlobStoreIndexShardSnapshot - Class in org.elasticsearch.index.snapshots.blobstore
-
Shard snapshot metadata
- BlobStoreIndexShardSnapshot(String, long, List<BlobStoreIndexShardSnapshot.FileInfo>, long, long, int, long) - Constructor for class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Constructs new shard snapshot metadata from snapshot metadata
- BlobStoreIndexShardSnapshot.FileInfo - Class in org.elasticsearch.index.snapshots.blobstore
-
Information about snapshotted file
- BlobStoreIndexShardSnapshots - Class in org.elasticsearch.index.snapshots.blobstore
-
Contains information about all snapshots for the given shard in repository
- BlobStoreIndexShardSnapshots(List<SnapshotFiles>) - Constructor for class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
- BlobStoreRepository - Class in org.elasticsearch.repositories.blobstore
-
BlobStore - based implementation of Snapshot Repository
- BlobStoreRepository(RepositoryMetaData, boolean, NamedXContentRegistry, ThreadPool) - Constructor for class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Constructs new BlobStoreRepository
- blockingAllowed() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
- BlockingClusterStatePublishResponseHandler - Class in org.elasticsearch.discovery
-
Handles responses obtained when publishing a new cluster state from master to all non master nodes.
- BlockingClusterStatePublishResponseHandler(Set<DiscoveryNode>) - Constructor for class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
Creates a new BlockingClusterStatePublishResponseHandler
- blockOnFutures(List<ActionFuture<Void>>) - Static method in interface org.elasticsearch.common.network.CloseableChannel
- blocks() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- blocks() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- blocks() - Method in exception org.elasticsearch.cluster.block.ClusterBlockException
- blocks() - Method in class org.elasticsearch.cluster.ClusterState
- blocks(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- blocks(ClusterBlocks) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- blocks(ClusterBlocks) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- blocks(ClusterBlocks.Builder) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- BLOCKS - org.elasticsearch.cluster.ClusterState.Metric
- blocksChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff the cluster level blocks have changed between cluster states. - BOOL_PREFIX - org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Uses the sum of the matching boolean fields to score the query
- BOOLEAN - org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- BOOLEAN - org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- BOOLEAN - org.elasticsearch.index.search.MatchQuery.Type
-
The text is analyzed and terms are added to a boolean query.
- BOOLEAN - org.elasticsearch.search.aggregations.support.ValueType
- BOOLEAN - Static variable in interface org.elasticsearch.search.DocValueFormat
- BOOLEAN_PREFIX - org.elasticsearch.index.search.MatchQuery.Type
-
The text is analyzed, terms are added to a boolean query with the last term acting as a prefix.
- BooleanFieldMapper - Class in org.elasticsearch.index.mapper
-
A field mapper for boolean fields.
- BooleanFieldMapper(String, MappedFieldType, MappedFieldType, Settings, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper
- BooleanFieldMapper.BooleanFieldType - Class in org.elasticsearch.index.mapper
- BooleanFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- BooleanFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- BooleanFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
- BooleanFieldMapper.Values - Class in org.elasticsearch.index.mapper
- BooleanFieldType() - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- BooleanFieldType(BooleanFieldMapper.BooleanFieldType) - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- Booleans(SortedNumericDocValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- boolQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents matching boolean combinations of other queries.
- BoolQueryBuilder - Class in org.elasticsearch.index.query
-
A Query that matches documents matching boolean combinations of other queries.
- BoolQueryBuilder() - Constructor for class org.elasticsearch.index.query.BoolQueryBuilder
-
Build an empty bool query.
- BoolQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.BoolQueryBuilder
-
Read from a stream.
- boolSetting(String, boolean, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- boolSetting(String, Function<Settings, String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- boolSetting(String, Setting<Boolean>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- boost - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- boost - Variable in class org.elasticsearch.index.query.AbstractQueryBuilder
- boost - Variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- boost() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- boost() - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Returns the boost for this query.
- boost() - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Returns the boost for this query.
- boost() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- boost(float) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- boost(float) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Sets the boost for this query.
- boost(float) - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Sets the boost for this query.
- boost(float) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- BOOST_FIELD - Static variable in class org.elasticsearch.index.query.AbstractQueryBuilder
- BOOST_MODE_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- boostingQuery(QueryBuilder, QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
The BoostingQuery class can be used to effectively demote results that match a given query.
- BoostingQueryBuilder - Class in org.elasticsearch.index.query
-
The BoostingQuery class can be used to effectively demote results that match a given query.
- BoostingQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.BoostingQueryBuilder
-
Read from a stream.
- BoostingQueryBuilder(QueryBuilder, QueryBuilder) - Constructor for class org.elasticsearch.index.query.BoostingQueryBuilder
-
Create a new
BoostingQueryBuilder
- boostMode() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Returns the boost mode, meaning how the combined result of score functions will influence the final score together with the sub query score.
- boostMode(CombineFunction) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Boost mode defines how the combined result of score functions will influence the final score together with the sub query score.
- boostTerms() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- boostTerms(float) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the boost factor to use when boosting terms.
- BootstrapCheck - Interface in org.elasticsearch.bootstrap
-
Encapsulates a bootstrap check.
- BootstrapCheck.BootstrapCheckResult - Class in org.elasticsearch.bootstrap
-
Encapsulate the result of a bootstrap check.
- BootstrapContext - Class in org.elasticsearch.bootstrap
-
Context that is passed to every bootstrap check to make decisions on.
- BootstrapContext(Environment, MetaData) - Constructor for class org.elasticsearch.bootstrap.BootstrapContext
- BootstrapInfo - Class in org.elasticsearch.bootstrap
-
Exposes system startup information
- bootstrapNewHistory() - Method in class org.elasticsearch.index.store.Store
-
Marks an existing lucene index with a new history uuid.
- bootstrapNewHistory(long, long) - Method in class org.elasticsearch.index.store.Store
-
Marks an existing lucene index with a new history uuid and sets the given local checkpoint as well as the maximum sequence number.
- BootstrapSettings - Class in org.elasticsearch.bootstrap
- BOTTOM_LEFT - org.elasticsearch.common.geo.GeoUtils.EffectivePoint
- BOTTOM_RIGHT - org.elasticsearch.common.geo.GeoUtils.EffectivePoint
- bottomRight() - Method in class org.elasticsearch.common.geo.builders.EnvelopeBuilder
- bottomRight() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Returns the bottom right corner of the bounding box.
- bottomRight() - Method in interface org.elasticsearch.search.aggregations.metrics.GeoBounds
-
Get the bottom-right location of the bounding box.
- bottomRight() - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- bottomRight() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedGeoBounds
- boundAddress() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- boundAddress() - Method in interface org.elasticsearch.http.HttpServerTransport
- boundAddress() - Method in class org.elasticsearch.transport.TcpTransport
- boundAddress() - Method in interface org.elasticsearch.transport.Transport
-
The address the transport is bound on.
- boundAddress() - Method in class org.elasticsearch.transport.TransportService
- boundAddresses() - Method in class org.elasticsearch.common.transport.BoundTransportAddress
- BOUNDARY_CHARS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- BOUNDARY_MAX_SCAN_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- BOUNDARY_SCANNER_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- BOUNDARY_SCANNER_LOCALE_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryChars - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryChars() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryChars() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- boundaryChars(char[]) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
this setting defines what constitutes a boundary for highlighting. - boundaryMaxScan - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryMaxScan() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryMaxScan() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- boundaryMaxScan(Integer) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
this setting controls how far to look for boundary characters, and defaults to 20. - boundaryScannerLocale - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryScannerLocale() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryScannerLocale() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- boundaryScannerLocale(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
and boundaryScannerTypebreak_iterator
, this setting controls the locale to use by the BreakIterator, defaults to "root". - boundaryScannerType - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryScannerType() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryScannerType() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchContextHighlight.FieldOptions
- boundaryScannerType(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
this setting controls which scanner to use for fragment boundaries, and defaults to "simple". - boundaryScannerType(HighlightBuilder.BoundaryScannerType) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
When using the highlighterType
fvh
this setting controls which scanner to use for fragment boundaries, and defaults to "simple". - BoundedBreakIteratorScanner - Class in org.apache.lucene.search.uhighlight
-
A custom break iterator that is used to find break-delimited passages bounded by a provided maximum length in the
UnifiedHighlighter
context. - BoundTransportAddress - Class in org.elasticsearch.common.transport
-
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. - BoundTransportAddress(StreamInput) - Constructor for class org.elasticsearch.common.transport.BoundTransportAddress
- BoundTransportAddress(TransportAddress[], TransportAddress) - Constructor for class org.elasticsearch.common.transport.BoundTransportAddress
- BREADTH_FIRST - org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
-
Creates buckets for all matching docs and then prunes to top-scoring buckets before a second pass over the data when child aggregators are called but only for docs from the top-scoring buckets
- breaker() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- breaker(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should the node's circuit breaker stats be returned.
- BREAKER_TYPE_KEY - Static variable in class org.elasticsearch.node.Node
- breakerService - Variable in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- breakerService() - Method in class org.elasticsearch.common.util.BigArrays
- BreakerSettings - Class in org.elasticsearch.indices.breaker
-
Settings for a
CircuitBreaker
- BreakerSettings(String, long, double) - Constructor for class org.elasticsearch.indices.breaker.BreakerSettings
- BreakerSettings(String, long, double, CircuitBreaker.Type, CircuitBreaker.Durability) - Constructor for class org.elasticsearch.indices.breaker.BreakerSettings
- breaksFastVectorHighlighter() - Method in interface org.elasticsearch.index.analysis.TokenFilterFactory
-
Does this analyzer mess up the
OffsetAttribute
s in such as way as to break theFastVectorHighlighter
? If this istrue
then the FastVectorHighlighter will attempt to work around the broken offsets. - BroadcastOperationRequestBuilder<Request extends BroadcastRequest<Request>,Response extends BroadcastResponse,RequestBuilder extends BroadcastOperationRequestBuilder<Request,Response,RequestBuilder>> - Class in org.elasticsearch.action.support.broadcast
- BroadcastOperationRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastOperationRequestBuilder
- BroadcastRequest<Request extends BroadcastRequest<Request>> - Class in org.elasticsearch.action.support.broadcast
- BroadcastRequest(String...) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastRequest
- BroadcastRequest(String[], IndicesOptions) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastRequest
- BroadcastRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastRequest
- BroadcastResponse - Class in org.elasticsearch.action.support.broadcast
-
Base class for all broadcast operation based responses.
- BroadcastResponse() - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastResponse
- BroadcastResponse(int, int, int, List<DefaultShardOperationFailedException>) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastResponse
- BroadcastResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastResponse
- BroadcastShardOperationFailedException - Exception in org.elasticsearch.action.support.broadcast
-
An exception indicating that a failure occurred performing an operation on the shard.
- BroadcastShardOperationFailedException(StreamInput) - Constructor for exception org.elasticsearch.action.support.broadcast.BroadcastShardOperationFailedException
- BroadcastShardOperationFailedException(ShardId, String) - Constructor for exception org.elasticsearch.action.support.broadcast.BroadcastShardOperationFailedException
- BroadcastShardOperationFailedException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.action.support.broadcast.BroadcastShardOperationFailedException
- BroadcastShardOperationFailedException(ShardId, Throwable) - Constructor for exception org.elasticsearch.action.support.broadcast.BroadcastShardOperationFailedException
- BroadcastShardRequest - Class in org.elasticsearch.action.support.broadcast
- BroadcastShardRequest() - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- BroadcastShardRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- BroadcastShardRequest(ShardId, OriginalIndices) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- BroadcastShardRequest(ShardId, BroadcastRequest<? extends BroadcastRequest<?>>) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- BroadcastShardResponse - Class in org.elasticsearch.action.support.broadcast
- BroadcastShardResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardResponse
- BroadcastShardResponse(ShardId) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardResponse
- Bucket(double, long, boolean, DocValueFormat, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- Bucket(long, long, boolean, DocValueFormat, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- Bucket(long, long, long, long, InternalAggregations, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
- Bucket(long, long, InternalAggregations, boolean, long, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- Bucket(long, long, InternalAggregations, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms.Bucket
- Bucket(long, long, DocValueFormat, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- Bucket(long, InternalAggregations, boolean, long, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- Bucket(long, InternalAggregations, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- Bucket(String, double, double, long, List<InternalAggregation>, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Bucket
- Bucket(String, double, double, long, InternalAggregations, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Bucket
- Bucket(String, double, double, long, InternalAggregations, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- Bucket(BytesRef, long, long, long, long, InternalAggregations, double, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
- Bucket(BytesRef, long, long, long, long, InternalAggregations, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
- Bucket(BytesRef, long, InternalAggregations, boolean, long, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- Bucket(BytesRef, long, InternalAggregations, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms.Bucket
- Bucket(StreamInput, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
-
Read from a stream.
- Bucket(StreamInput, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
-
Read from a stream.
- Bucket(StreamInput, long, long, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.InternalSignificantTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, long, long, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.SignificantStringTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
-
Read from a stream.
- Bucket(DocValueFormat, boolean, String, BytesRef, BytesRef, long, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- bucketAggregations(long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Required method to build the child aggregations of the given bucket (identified by the bucket ordinal).
- BucketAggregationScript - Class in org.elasticsearch.script
-
A script used in bucket aggregations that returns a
double
value. - BucketAggregationScript(Map<String, Object>) - Constructor for class org.elasticsearch.script.BucketAggregationScript
- BucketAggregationScript.Factory - Interface in org.elasticsearch.script
- BucketAggregationSelectorScript - Class in org.elasticsearch.script
-
A script used in bucket aggregations that returns a
boolean
value. - BucketAggregationSelectorScript(Map<String, Object>) - Constructor for class org.elasticsearch.script.BucketAggregationSelectorScript
- BucketAggregationSelectorScript.Factory - Interface in org.elasticsearch.script
- BucketCollector - Class in org.elasticsearch.search.aggregations
-
A Collector that can collect data in separate buckets.
- BucketCollector() - Constructor for class org.elasticsearch.search.aggregations.BucketCollector
- bucketComparator(AggregationPath, boolean) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
-
Internal Optimization for ordering
InternalTerms.Bucket
s by a sub aggregation. - bucketCountThresholds - Variable in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregator
- bucketCountThresholds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- bucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- bucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- bucketCountThresholds(TermsAggregator.BucketCountThresholds) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTermsAggregationBuilder
- bucketCountThresholds(TermsAggregator.BucketCountThresholds) - Method in class org.elasticsearch.search.aggregations.bucket.significant.SignificantTextAggregationBuilder
- BucketCountThresholds(long, long, int, int) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- BucketCountThresholds(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
-
Read from a stream.
- BucketCountThresholds(TermsAggregator.BucketCountThresholds) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- bucketDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Utility method to return the number of documents that fell in the given bucket (identified by the bucket ordinal)
- bucketDocCount(long) - Method in interface org.elasticsearch.search.aggregations.bucket.SingleBucketAggregator
- bucketEmptyAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Utility method to build empty aggregations of the sub aggregators.
- BucketHelpers - Class in org.elasticsearch.search.aggregations.pipeline
-
A set of static helpers to simplify working with aggregation buckets, in particular providing utilities that help pipeline aggregations.
- BucketHelpers() - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketHelpers
- BucketHelpers.GapPolicy - Enum in org.elasticsearch.search.aggregations.pipeline
-
A gap policy determines how "holes" in a set of buckets should be handled.
- bucketMap - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- bucketMap - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- bucketMap - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- BucketMetricsParser - Class in org.elasticsearch.search.aggregations.pipeline
-
A parser for parsing requests for a
BucketMetricsPipelineAggregator
- BucketMetricsParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketMetricsParser
- BucketMetricsPipelineAggregationBuilder<AF extends BucketMetricsPipelineAggregationBuilder<AF>> - Class in org.elasticsearch.search.aggregations.pipeline
- BucketMetricsPipelineAggregationBuilder(String, String, String[]) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
- BucketMetricsPipelineAggregationBuilder(StreamInput, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
-
Read from a stream.
- BucketMetricsPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
-
A class of sibling pipeline aggregations which calculate metrics across the buckets of a sibling aggregation
- BucketMetricValue - Interface in org.elasticsearch.search.aggregations.pipeline
- BucketOrder - Class in org.elasticsearch.search.aggregations
-
MultiBucketsAggregation.Bucket
Ordering strategy. - BucketOrder() - Constructor for class org.elasticsearch.search.aggregations.BucketOrder
- bucketOrds - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregator
- bucketOrds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- bucketOrds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTermsAggregator
- bucketOrds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.LongTermsAggregator
- bucketOrds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTermsAggregator
- bucketOrds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregator
- BucketPriorityQueue<B extends Terms.Bucket> - Class in org.elasticsearch.search.aggregations.bucket.terms
- BucketPriorityQueue(int, Comparator<? super B>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.BucketPriorityQueue
- buckets - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- buckets - Variable in class org.elasticsearch.search.aggregations.bucket.significant.InternalMappedSignificantTerms
- buckets - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- buckets - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- buckets - Variable in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation
- BUCKETS - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- BUCKETS_PATH - Static variable in interface org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.Parser
- BUCKETS_PATH_FIELD - Static variable in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
-
Field shared by many parsers.
- BucketsAggregator - Class in org.elasticsearch.search.aggregations.bucket
- BucketsAggregator(String, AggregatorFactories, SearchContext, Aggregator, List<PipelineAggregator>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
- bucketsBuilder - Variable in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- bucketScript(String, Map<String, String>, Script) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- bucketScript(String, Script, String...) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- BucketScriptPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- BucketScriptPipelineAggregationBuilder(String, Map<String, String>, Script) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- BucketScriptPipelineAggregationBuilder(String, Script, String...) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- BucketScriptPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
-
Read from a stream.
- BucketScriptPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- BucketScriptPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregator
-
Read from a stream.
- bucketSelector(String, Map<String, String>, Script) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- bucketSelector(String, Script, String...) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- BucketSelectorPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- BucketSelectorPipelineAggregationBuilder(String, Map<String, String>, Script) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- BucketSelectorPipelineAggregationBuilder(String, Script, String...) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- BucketSelectorPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
-
Read from a stream.
- BucketSelectorPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- BucketSelectorPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregator
-
Read from a stream.
- BucketSignificancePriorityQueue<B extends SignificantTerms.Bucket> - Class in org.elasticsearch.search.aggregations.bucket.significant
- BucketSignificancePriorityQueue(int) - Constructor for class org.elasticsearch.search.aggregations.bucket.significant.BucketSignificancePriorityQueue
- bucketSort(String, List<FieldSortBuilder>) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- BucketSortPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
-
Builds a pipeline aggregation that allows sorting the buckets of its parent aggregation.
- BucketSortPipelineAggregationBuilder(String, List<FieldSortBuilder>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- BucketSortPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
-
Read from a stream.
- BucketSortPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- BucketSortPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregator
-
Read from a stream.
- bucketsPaths - Variable in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
- bucketsPaths() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- bucketToXContent(CompositeAggregation.Bucket, XContentBuilder, ToXContent.Params) - Static method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation
- BucketUtils - Class in org.elasticsearch.search.aggregations.bucket
-
Helper functions for common Bucketing functions
- BUFFER_SIZE - Static variable in class org.elasticsearch.common.io.Streams
- BufferedChecksumStreamInput - Class in org.elasticsearch.index.translog
-
Similar to Lucene's BufferedChecksumIndexInput, however this wraps a
StreamInput
so anything read will update the checksum - BufferedChecksumStreamInput(StreamInput, String) - Constructor for class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- BufferedChecksumStreamInput(StreamInput, String, BufferedChecksumStreamInput) - Constructor for class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- BufferedChecksumStreamOutput - Class in org.elasticsearch.index.translog
-
Similar to Lucene's BufferedChecksumIndexOutput, however this wraps a
StreamOutput
so anything written will update the checksum - BufferedChecksumStreamOutput(StreamOutput) - Constructor for class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
- BufferPool(String, long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
- BufferPool(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
- bufferSize - Variable in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- bufferSizeInBytes() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
- build - Variable in class org.elasticsearch.Version
- build() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup.Builder
- build() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats.IndexStatsBuilder
- build() - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Builds a new bulk processor.
- build() - Method in class org.elasticsearch.action.delete.DeleteResponse.Builder
- build() - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- build() - Method in class org.elasticsearch.action.index.IndexResponse.Builder
- build() - Method in class org.elasticsearch.action.update.UpdateResponse.Builder
- build() - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- build() - Method in class org.elasticsearch.cluster.ClusterState.Builder
- build() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetaData.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.AliasMetaData.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetaData.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
- build() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- build() - Method in class org.elasticsearch.cluster.RestoreInProgress.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- build() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- build() - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
Builds the routing table.
- build() - Method in class org.elasticsearch.common.cache.CacheBuilder
- build() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
Builds a new instance of the
- build() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
Builds a new instance of the
- build() - Method in class org.elasticsearch.common.geo.builders.CoordinatesBuilder
- build() - Method in class org.elasticsearch.common.logging.ESJsonLayout.Builder
- build() - Method in interface org.elasticsearch.common.recycler.Recycler.Factory
- build() - Method in class org.elasticsearch.common.Rounding.Builder
- build() - Method in class org.elasticsearch.common.rounding.Rounding.Builder
-
Deprecated.
- build() - Method in class org.elasticsearch.common.settings.Settings.Builder
- build() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Builds an
Ordinals
instance from the builders current state. - build() - Method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo.Builder
- build() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetaData.Builder
- build() - Method in class org.elasticsearch.script.ScriptMetaData.Builder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel.EWMAModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel.HoltLinearModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel.LinearModelBuilder
- build() - Method in interface org.elasticsearch.search.aggregations.pipeline.MovAvgModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel.SimpleModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.ContextBuilder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
- build() - Method in class org.elasticsearch.search.suggest.completion.RegexOptions.Builder
- build() - Method in class org.elasticsearch.snapshots.SnapshotInfo.SnapshotInfoBuilder
- build() - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Creates a new
ConnectionProfile
based on the added connections. - build() - Method in class org.elasticsearch.transport.TransportRequestOptions.Builder
- build(Object) - Static method in class org.elasticsearch.common.unit.Fuzziness
- build(IndexReader, IndexOrdinalsFieldData, IndexSettings, CircuitBreakerService, Logger, Function<SortedSetDocValues, ScriptDocValues<?>>) - Static method in enum org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsBuilder
-
Build global ordinals for the provided
IndexReader
. - build(ClusterState) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult.Builder
- build(ClusterState) - Static method in class org.elasticsearch.cluster.MasterNodeChangePredicate
-
builds a predicate that will accept a cluster state only if it was generated after the current has (re-)joined the master
- build(Priority) - Static method in interface org.elasticsearch.cluster.ClusterStateTaskConfig
-
Build a cluster state update task configuration with the specified
Priority
and no timeout. - build(Priority, TimeValue) - Static method in interface org.elasticsearch.cluster.ClusterStateTaskConfig
-
Build a cluster state update task configuration with the specified
Priority
and timeout. - build(Settings) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
- build(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic
- build(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.significant.heuristics.NXYSignificanceHeuristic.NXYBuilder
- build(TokenizerFactory, Map<String, CharFilterFactory>, Map<String, TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.CustomNormalizerProvider
- build(IndexSettings) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
-
Creates an index-level
IndexAnalyzers
from this registry using the given index settings - build(IndexSettings, Map<String, AnalyzerProvider<?>>, Map<String, AnalyzerProvider<?>>, Map<String, TokenizerFactory>, Map<String, CharFilterFactory>, Map<String, TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointDVIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryDVIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.DocValuesIndexFieldData.Builder
- build(IndexSettings, MappedFieldType, IndexFieldDataCache, CircuitBreakerService, MapperService) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.Builder
- build(FieldMapper.Builder, Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.AllFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper.Builder
- build(Mapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.IndexFieldMapper.Builder
- buil