Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abFromTriangle(byte) - Static method in interface org.elasticsearch.lucene.spatial.TriangleTreeVisitor
- abort() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
-
Create a new instance by aborting this instance.
- abort(String, Exception) - Method in class org.elasticsearch.action.bulk.BulkItemRequest
-
Abort this request, and store a
BulkItemResponse.Failure
response. - ABORTED - Enum constant in enum class org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- ABORTED - Enum constant in enum class org.elasticsearch.cluster.SnapshotsInProgress.State
- ABORTED - Enum constant in enum class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.AbortStatus
-
The shard snapshot stopped before completion, either because the whole snapshot was aborted or because this node is to be removed.
- ABORTED - Enum constant in enum class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Snapshot aborted
- ABORTED_BY_USER_MSG - Static variable in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- ABORTED_FAILURE_TEXT - Static variable in class org.elasticsearch.cluster.SnapshotsInProgress
- AbortedSnapshotException - Exception in org.elasticsearch.snapshots
- AbortedSnapshotException() - Constructor for exception org.elasticsearch.snapshots.AbortedSnapshotException
- abortIfNotCompleted(String, Consumer<ActionListener<Releasable>>) - 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.
- absoluteStartMillis() - Method in record class org.elasticsearch.action.search.TransportSearchAction.SearchTimeProvider
-
Returns the value of the
absoluteStartMillis
record component. - absoluteTimeInMillis() - Method in record class org.elasticsearch.cluster.coordination.stateless.Heartbeat
-
Returns the value of the
absoluteTimeInMillis
record component. - absoluteTimeInMillis() - Method in class org.elasticsearch.cluster.coordination.stateless.StoreHeartbeatService
- 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, Executor, TimeValue, boolean) - Constructor for class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- AbstractBinaryDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation.
- AbstractBinaryDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractBinaryDocValues
- AbstractBindingBuilder<T> - Class in org.elasticsearch.injection.guice.internal
-
Bind a value or constant.
- AbstractBindingBuilder(Binder, List<Element>, Object, Key<T>) - Constructor for class org.elasticsearch.injection.guice.internal.AbstractBindingBuilder
- AbstractBlobContainer - Class in org.elasticsearch.common.blobstore.support
-
A base abstract blob container that adds some methods implementations that are often identical across many subclasses.
- 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) - 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) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequestBuilder
- AbstractBytesReference - Class in org.elasticsearch.common.bytes
- AbstractBytesReference(int) - Constructor for class org.elasticsearch.common.bytes.AbstractBytesReference
- 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(String) - Constructor for class org.elasticsearch.index.analysis.AbstractCharFilterFactory
- AbstractClient - Class in org.elasticsearch.client.internal.support
- AbstractClient(Settings, ThreadPool) - Constructor for class org.elasticsearch.client.internal.support.AbstractClient
- AbstractDistanceScoreFunction(double, double, double, DecayFunction, MultiValueMode) - Constructor for class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- AbstractFieldScript - Class in org.elasticsearch.script
-
Abstract base for scripts to execute to build scripted fields.
- AbstractFieldScript(String, Map<String, Object>, SearchLookup, LeafReaderContext, OnScriptError) - Constructor for class org.elasticsearch.script.AbstractFieldScript
- AbstractFileWatchingService - Class in org.elasticsearch.common.file
-
A skeleton service for watching and reacting to a single file changing on disk
- AbstractFileWatchingService(Path) - Constructor for class org.elasticsearch.common.file.AbstractFileWatchingService
- AbstractGeometryFieldMapper<T> - Class in org.elasticsearch.index.mapper
-
Base field mapper class for all spatial field types
- AbstractGeometryFieldMapper(String, MappedFieldType, FieldMapper.BuilderParams, Explicit<Boolean>, Explicit<Boolean>, AbstractGeometryFieldMapper.Parser<T>) - Constructor for class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- AbstractGeometryFieldMapper.AbstractGeometryFieldType<T> - Class in org.elasticsearch.index.mapper
- AbstractGeometryFieldMapper.DefaultMalformedValueHandler - Record Class in org.elasticsearch.index.mapper
- AbstractGeometryFieldMapper.MalformedValueHandler - Interface in org.elasticsearch.index.mapper
- AbstractGeometryFieldMapper.NoopMalformedValueHandler - Record Class in org.elasticsearch.index.mapper
- AbstractGeometryFieldMapper.Parser<T> - Class in org.elasticsearch.index.mapper
-
Interface representing parser in geometry indexing pipeline.
- AbstractGeometryFieldType(String, boolean, boolean, boolean, AbstractGeometryFieldMapper.Parser<T>, T, Map<String, String>) - 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, Supplier<Geometry>, String) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- 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) - 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
- AbstractHistogramAggregator - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
Base class for functionality shared between aggregators for this
histogram
aggregation. - AbstractHistogramAggregator(String, AggregatorFactories, double, double, BucketOrder, boolean, long, DoubleBounds, DoubleBounds, DocValueFormat, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- AbstractHistogramBucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
A bucket in the histogram where documents fall in
- AbstractHistogramBucket(long, InternalAggregations, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramBucket
- AbstractHttpServerTransport - Class in org.elasticsearch.http
- AbstractHttpServerTransport(Settings, NetworkService, Recycler<BytesRef>, ThreadPool, NamedXContentRegistry, HttpServerTransport.Dispatcher, ClusterSettings, Tracer) - Constructor for class org.elasticsearch.http.AbstractHttpServerTransport
- AbstractHyperLogLog - Class in org.elasticsearch.search.aggregations.metrics
-
Hyperloglog counter, implemented based on pseudo code from http://static.googleusercontent.com/media/research.google.com/fr//pubs/archive/40671.pdf and its appendix https://docs.google.com/document/d/1gyjfMHy43U9OWBXxfaeG-3MjGzejW1dlpyMwEYAAWEI/view?fullscreen Trying to understand what this class does without having read the paper is considered adventurous.
- AbstractHyperLogLog(int) - Constructor for class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLog
- AbstractHyperLogLog.RunLenIterator - Interface in org.elasticsearch.search.aggregations.metrics
-
Iterator over a HyperLogLog register
- AbstractHyperLogLogPlusPlus - Class in org.elasticsearch.search.aggregations.metrics
-
Base class for HLL++ algorithms.
- AbstractHyperLogLogPlusPlus(int) - Constructor for class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
- AbstractIdFieldType() - Constructor for class org.elasticsearch.index.mapper.IdFieldMapper.AbstractIdFieldType
- AbstractIndexAnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer> - Class in org.elasticsearch.index.analysis
- AbstractIndexAnalyzerProvider(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.
- AbstractIndexOrdinalsFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractIndexOrdinalsFieldData(String, ValuesSourceType, IndexFieldDataCache, CircuitBreakerService, ToScriptFieldFactory<SortedSetDocValues>) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- AbstractIndexOrdinalsFieldData.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. - 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
- AbstractInternalTerms<A extends AbstractInternalTerms<A,
B>, B extends AbstractInternalTerms.AbstractTermsBucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms -
Base class for terms and multi_terms aggregation that handles common reduce logic
- AbstractInternalTerms(String, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- AbstractInternalTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- AbstractInternalTerms.AbstractTermsBucket<B extends AbstractInternalTerms.AbstractTermsBucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms
- AbstractLeafOrdinalsFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractLeafOrdinalsFieldData(ToScriptFieldFactory<SortedSetDocValues>) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractLeafOrdinalsFieldData
- AbstractLifecycleComponent - Class in org.elasticsearch.common.component
-
A component with a
Lifecycle
which is used to link its start and stop activities to those of the Elasticsearch node which contains it. - AbstractLifecycleComponent() - Constructor for class org.elasticsearch.common.component.AbstractLifecycleComponent
-
Initialize this component.
- AbstractLinearCounting - Class in org.elasticsearch.search.aggregations.metrics
-
Linear counter, implemented based on pseudo code from http://static.googleusercontent.com/media/research.google.com/fr//pubs/archive/40671.pdf and its appendix https://docs.google.com/document/d/1gyjfMHy43U9OWBXxfaeG-3MjGzejW1dlpyMwEYAAWEI/view?fullscreen Trying to understand what this class does without having read the paper is considered adventurous.
- AbstractLinearCounting(int) - Constructor for class org.elasticsearch.search.aggregations.metrics.AbstractLinearCounting
- AbstractLinearCounting.HashesIterator - Interface in org.elasticsearch.search.aggregations.metrics
-
Iterator over the hash values
- AbstractLongDocValuesField - Class in org.elasticsearch.script.field
- AbstractLongDocValuesField(SortedNumericDocValues, String) - Constructor for class org.elasticsearch.script.field.AbstractLongDocValuesField
- AbstractLongFieldScript - Class in org.elasticsearch.script
-
Common base class for script field scripts that return long values.
- AbstractLongFieldScript(String, Map<String, Object>, SearchLookup, OnScriptError, LeafReaderContext) - Constructor for class org.elasticsearch.script.AbstractLongFieldScript
- AbstractMatcher<T> - Class in org.elasticsearch.injection.guice.matcher
-
Implements
and()
andor()
. - AbstractMatcher() - Constructor for class org.elasticsearch.injection.guice.matcher.AbstractMatcher
- AbstractModule - Class in org.elasticsearch.injection.guice
-
A support class for
Module
s which reduces repetition and results in a more readable configuration. - AbstractModule() - Constructor for class org.elasticsearch.injection.guice.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
- AbstractPagedResultResponse(StreamInput) - Constructor for class org.elasticsearch.action.synonyms.AbstractSynonymsPagedResultAction.AbstractPagedResultResponse
- AbstractPagedResultResponse(PagedResult<T>) - Constructor for class org.elasticsearch.action.synonyms.AbstractSynonymsPagedResultAction.AbstractPagedResultResponse
- AbstractPercentilesAggregationBuilder<T extends AbstractPercentilesAggregationBuilder<T>> - Class in org.elasticsearch.search.aggregations.metrics
-
This provides a base class for aggregations that are building percentiles or percentiles-like functionality (e.g.
- 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.
- AbstractPointFieldType(String, boolean, boolean, boolean, AbstractGeometryFieldMapper.Parser<T>, T, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.AbstractPointFieldType
- AbstractPointGeometryFieldMapper<T> - Class in org.elasticsearch.index.mapper
-
Base class for spatial fields that only support indexing points
- AbstractPointGeometryFieldMapper(String, MappedFieldType, FieldMapper.BuilderParams, Explicit<Boolean>, Explicit<Boolean>, T, AbstractGeometryFieldMapper.Parser<T>) - Constructor for class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper
- AbstractPointGeometryFieldMapper.AbstractPointFieldType<T extends SpatialPoint> - Class in org.elasticsearch.index.mapper
- AbstractPointGeometryFieldMapper.PointParser<T> - Class in org.elasticsearch.index.mapper
-
A base parser implementation for point formats
- AbstractPointIndexFieldData<T extends MultiPointValues<? extends SpatialPoint>> - Class in org.elasticsearch.index.fielddata.plain
- AbstractPointIndexFieldData(String, ValuesSourceType, ToScriptFieldFactory<T>) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractPointIndexFieldData
- AbstractProcessor - Class in org.elasticsearch.ingest
-
An Abstract Processor that holds tag and description information about the processor.
- AbstractProcessor(String, String) - Constructor for class org.elasticsearch.ingest.AbstractProcessor
- AbstractProfileBreakdown<T extends 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, R[], boolean, InternalRange.Factory<?, ?>, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>, RangeAggregatorSupplier) - 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 - 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.
- 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<?>>, Setting.Property) - Constructor for class org.elasticsearch.common.settings.AbstractScopedSettings
- AbstractScopedSettings(Settings, Settings, AbstractScopedSettings, Logger) - Constructor for class org.elasticsearch.common.settings.AbstractScopedSettings
- AbstractScopedSettings.SettingUpdater<T> - Interface in org.elasticsearch.common.settings
-
Transactional interface to update settings.
- AbstractScriptFieldFactory<T> - Class in org.elasticsearch.script.field
-
This class is acting as a placeholder where a
Field
is its ownScriptFieldFactory
as we continue to refactor eachField
for source fallback. - AbstractScriptFieldFactory() - Constructor for class org.elasticsearch.script.field.AbstractScriptFieldFactory
- AbstractScriptFieldQuery<S extends AbstractFieldScript> - Class in org.elasticsearch.search.runtime
-
Abstract base class for building queries based on script fields.
- AbstractScriptFieldQuery(Script, String, Function<LeafReaderContext, S>) - Constructor for class org.elasticsearch.search.runtime.AbstractScriptFieldQuery
- AbstractScriptFieldType<LeafFactory> - Class in org.elasticsearch.index.mapper
-
Abstract base MappedFieldType for runtime fields based on a script.
- AbstractScriptFieldType(String, Function<SearchLookup, LeafFactory>, Script, boolean, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.AbstractScriptFieldType
- AbstractScriptFieldType.Builder<Factory> - Class in org.elasticsearch.index.mapper
- AbstractShapeGeometryFieldMapper<T> - Class in org.elasticsearch.index.mapper
-
Base class for shape field mappers
- AbstractShapeGeometryFieldMapper(String, MappedFieldType, FieldMapper.BuilderParams, Explicit<Boolean>, Explicit<Boolean>, Explicit<Boolean>, Explicit<Orientation>, AbstractGeometryFieldMapper.Parser<T>) - Constructor for class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper
- AbstractShapeGeometryFieldMapper.AbstractShapeGeometryFieldType<T> - Class in org.elasticsearch.index.mapper
- AbstractShapeGeometryFieldType(String, boolean, boolean, boolean, AbstractGeometryFieldMapper.Parser<T>, Orientation, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper.AbstractShapeGeometryFieldType
- 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
- AbstractSortingNumericDocValues(LongConsumer) - Constructor for class org.elasticsearch.index.fielddata.AbstractSortingNumericDocValues
- AbstractStringScriptFieldAutomatonQuery - Class in org.elasticsearch.search.runtime
- AbstractStringScriptFieldAutomatonQuery(Script, StringFieldScript.LeafFactory, String, ByteRunAutomaton) - Constructor for class org.elasticsearch.search.runtime.AbstractStringScriptFieldAutomatonQuery
- AbstractSynonymsPagedResultAction<T extends ActionResponse> - Class in org.elasticsearch.action.synonyms
-
Base class for synonyms retrieval actions, including
GetSynonymsAction
andGetSynonymsSetsAction
. - AbstractSynonymsPagedResultAction(String, Writeable.Reader<T>) - Constructor for class org.elasticsearch.action.synonyms.AbstractSynonymsPagedResultAction
- AbstractSynonymsPagedResultAction.AbstractPagedResultResponse<T extends Writeable> - Class in org.elasticsearch.action.synonyms
-
Response class that (de)serializes a
PagedResult
. - AbstractSynonymsPagedResultAction.Request - Class in org.elasticsearch.action.synonyms
-
Base request class that includes support for pagination parameters
- AbstractTermsBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms.AbstractTermsBucket
- AbstractThreadedActionListener<Response> - Class in org.elasticsearch.action.support
-
Base class for action listeners that wrap another action listener and dispatch its completion to an executor.
- AbstractThreadedActionListener(Executor, boolean, ActionListener<Response>) - Constructor for class org.elasticsearch.action.support.AbstractThreadedActionListener
- AbstractThrottledTaskRunner<T extends ActionListener<Releasable>> - Class in org.elasticsearch.common.util.concurrent
-
AbstractThrottledTaskRunner
runs the enqueued tasks using the given executor, limiting the number of tasks that are submitted to the executor at once. - AbstractThrottledTaskRunner(String, int, Executor, Queue<T>) - Constructor for class org.elasticsearch.common.util.concurrent.AbstractThrottledTaskRunner
- AbstractTokenFilterFactory - Class in org.elasticsearch.index.analysis
- AbstractTokenFilterFactory(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.elasticsearch.lucene.analysis.miscellaneous.DeDuplicatingTokenFilter
- accept(double) - Method in class org.elasticsearch.script.StatsSummary
- 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(B) - Method in class org.elasticsearch.search.aggregations.bucket.BucketReducer
-
Adds a
BucketReducer
for reduction. - accept(B) - Method in class org.elasticsearch.search.aggregations.bucket.DelayedBucketReducer
-
Adds a
DelayedBucketReducer
for reduction. - accept(Runnable) - Method in class org.elasticsearch.action.bulk.WriteAckDelay
- accept(List<B>) - Method in class org.elasticsearch.search.aggregations.bucket.FixedMultiBucketAggregatorsReducer
-
Adds a list of buckets for reduction.
- accept(BytesRef) - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
-
Always accept the term.
- accept(BytesRef) - Method in class org.elasticsearch.index.mapper.SearchAfterTermsEnum
- accept(BytesRef) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.StringFilter
- accept(ReplicationGroup) - Method in class org.elasticsearch.action.support.replication.PendingReplicationActions
- accept(InternalAggregation) - Method in interface org.elasticsearch.search.aggregations.AggregatorReducer
-
Adds an aggregation for reduction.
- accept(InternalAggregations) - Method in class org.elasticsearch.search.aggregations.AggregatorsReducer
-
Adds a
InternalAggregations
for reduction. - accept(LeafBucketCollector, int, long, BytesRef) - Method in interface org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator.CollectConsumer
- accept(T, U) - Method in interface org.elasticsearch.common.CheckedBiConsumer
- ACCEPT_ALL - Static variable in interface org.elasticsearch.plugins.FieldPredicate
-
The default field predicate applied, which doesn't filter anything.
- 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 - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The request has been accepted for processing, but the processing has not been completed.
- acceptedGlobalOrdinals(SortedSetDocValues) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.OrdinalsFilter
- acceptedTerm() - Method in record class org.elasticsearch.cluster.coordination.ClusterFormationFailureHelper.ClusterFormationState
-
Returns the value of the
acceptedTerm
record component. - acceptIncomingRequests() - Method in class org.elasticsearch.transport.TransportService
-
Start accepting incoming requests.
- acceptResponse(RemoteClusterStatsResponse) - Method in record class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse.RemoteClusterStats
- acceptsNull() - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Allows the parameter to accept a
null
value - acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in interface org.elasticsearch.injection.guice.Binding
-
Accepts a target visitor.
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.injection.guice.internal.InstanceBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.injection.guice.internal.LinkedBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.injection.guice.internal.LinkedProviderBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.injection.guice.internal.ProviderInstanceBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.injection.guice.internal.UntargettedBindingImpl
- acceptVisitor(ElementVisitor<T>) - Method in interface org.elasticsearch.injection.guice.spi.Element
-
Accepts an element visitor.
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.injection.guice.spi.Message
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.injection.guice.spi.ProviderLookup
- acceptVisitor(ElementVisitor<V>) - Method in class org.elasticsearch.injection.guice.internal.BindingImpl
- ACCESS_CONTROL_ALLOW_CREDENTIALS - Static variable in class org.elasticsearch.http.CorsHandler
- ACCESS_CONTROL_ALLOW_HEADERS - Static variable in class org.elasticsearch.http.CorsHandler
- ACCESS_CONTROL_ALLOW_METHODS - Static variable in class org.elasticsearch.http.CorsHandler
- ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class org.elasticsearch.http.CorsHandler
- ACCESS_CONTROL_EXPOSE_HEADERS - Static variable in class org.elasticsearch.http.CorsHandler
- ACCESS_CONTROL_MAX_AGE - Static variable in class org.elasticsearch.http.CorsHandler
- ACCESS_CONTROL_REQUEST_METHOD - Static variable in class org.elasticsearch.http.CorsHandler
- 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
- AckedBatchedClusterStateUpdateTask - Class in org.elasticsearch.cluster
-
This class models a cluster state update task that notifies an AcknowledgedResponse listener when all the nodes have acknowledged the cluster state update request.
- AckedBatchedClusterStateUpdateTask(TimeValue, ActionListener<AcknowledgedResponse>) - Constructor for class org.elasticsearch.cluster.AckedBatchedClusterStateUpdateTask
- AckedClusterStateUpdateTask - Class in org.elasticsearch.cluster
-
An extension interface to
ClusterStateUpdateTask
that allows the caller to be notified after the master has computed, published, accepted, committed, and applied the cluster state update AND only after the rest of the nodes (or a specified subset) have also accepted and applied the cluster state update. - AckedClusterStateUpdateTask(AcknowledgedRequest<?>, ActionListener<? extends AcknowledgedResponse>) - Constructor for class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- AckedClusterStateUpdateTask(Priority, AcknowledgedRequest<?>, ActionListener<? extends AcknowledgedResponse>) - Constructor for class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- AckedClusterStateUpdateTask(Priority, TimeValue, TimeValue, ActionListener<? extends AcknowledgedResponse>) - Constructor for class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- AckedClusterStateUpdateTask(TimeValue, TimeValue, ActionListener<? extends AcknowledgedResponse>) - Constructor for class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- acknowledged - Variable in class org.elasticsearch.action.support.master.AcknowledgedResponse
- ACKNOWLEDGED_KEY - Static variable in class org.elasticsearch.action.support.master.AcknowledgedResponse
- ACKNOWLEDGED_NO_ERRORS - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesResponse
- AcknowledgedRequest<Request extends MasterNodeRequest<Request>> - Class in org.elasticsearch.action.support.master
-
Abstract base class for action requests that track acknowledgements of cluster state updates: such a request is acknowledged only once the cluster state update is committed and all relevant nodes have applied it and acknowledged its application to the elected master..
- AcknowledgedRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedRequest
- AcknowledgedRequest(TimeValue, TimeValue) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedRequest
- AcknowledgedRequest.Plain - Class in org.elasticsearch.action.support.master
-
AcknowledgedRequest
that does not have any additional fields. - AcknowledgedRequestBuilder<Request extends AcknowledgedRequest<Request>,
Response extends ActionResponse & IsAcknowledgedSupplier, 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 to an action which updated the cluster state, but needs to report whether any relevant nodes failed to apply the update.
- AcknowledgedResponse(boolean) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
- AcknowledgedResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
- AcknowledgedTransportMasterNodeAction<Request extends MasterNodeRequest<Request>> - Class in org.elasticsearch.action.support.master
-
Base class for the common case of a
TransportMasterNodeAction
that responds with anAcknowledgedResponse
. - AcknowledgedTransportMasterNodeAction(String, boolean, TransportService, ClusterService, ThreadPool, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver, Executor) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedTransportMasterNodeAction
- AcknowledgedTransportMasterNodeAction(String, TransportService, ClusterService, ThreadPool, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver, Executor) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedTransportMasterNodeAction
- ackTimeout() - Method in record class org.elasticsearch.action.admin.indices.alias.IndicesAliasesClusterStateUpdateRequest
-
Returns the value of the
ackTimeout
record component. - ackTimeout() - Method in record class org.elasticsearch.action.admin.indices.close.CloseIndexClusterStateUpdateRequest
-
Returns the value of the
ackTimeout
record component. - ackTimeout() - Method in record class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
-
Returns the value of the
ackTimeout
record component. - ackTimeout() - Method in record class org.elasticsearch.action.admin.indices.open.OpenIndexClusterStateUpdateRequest
-
Returns the value of the
ackTimeout
record component. - ackTimeout() - Method in record class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockClusterStateUpdateRequest
-
Returns the value of the
ackTimeout
record component. - ackTimeout() - Method in record class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
-
Returns the value of the
ackTimeout
record component. - ackTimeout() - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
- ackTimeout() - Method in class org.elasticsearch.cluster.AckedBatchedClusterStateUpdateTask
- ackTimeout() - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
-
Acknowledgement timeout, maximum time interval to wait for acknowledgements
- ackTimeout() - Method in interface org.elasticsearch.cluster.ClusterStateAckListener
- ackTimeout() - Method in record class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService.CreateDataStreamClusterStateUpdateRequest
-
Returns the value of the
ackTimeout
record component. - ackTimeout() - Method in record class org.elasticsearch.cluster.metadata.MetadataMigrateToDataStreamService.MigrateToDataStreamClusterStateUpdateRequest
-
Returns the value of the
ackTimeout
record component. - ackTimeout(TimeValue) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
-
Sets the
AcknowledgedRequest.ackTimeout
, which specifies how long to wait for all relevant nodes to apply a cluster state update and acknowledge this to the elected master. - acquire() - Method in class org.elasticsearch.action.support.RefCountingListener
-
Acquire a reference to this object and return a listener which releases it.
- acquire() - Method in class org.elasticsearch.action.support.RefCountingRunnable
-
Acquire a reference to this object and return an action which releases it.
- acquire() - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
- acquire(CheckedConsumer<Response, Exception>) - Method in class org.elasticsearch.action.support.RefCountingListener
-
Acquire a reference to this object and return a listener which consumes a response and releases the reference.
- 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)
. - acquireEnsureOpenRef() - Method in class org.elasticsearch.index.engine.Engine
- acquireFSLockForPaths(IndexSettings, Path...) - Static method in class org.elasticsearch.env.NodeEnvironment
-
Acquires, then releases, all
write.lock
files in the given shard paths. - acquireHistoryRetentionLock() - 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() - Method in class org.elasticsearch.index.engine.InternalEngine
- acquireHistoryRetentionLock() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- acquireHistoryRetentionLock() - 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
- acquireIndexCommitForSnapshot() - Method in class org.elasticsearch.index.engine.Engine
-
Acquires the index commit that should be included in a snapshot.
- acquireIndexCommitForSnapshot() - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquires the
IndexCommit
which should be included in a snapshot. - acquireIndexCommitForSnapshot(Engine) - Method in interface org.elasticsearch.plugins.IndexStorePlugin.SnapshotCommitSupplier
- 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. - acquireListener() - Method in class org.elasticsearch.action.support.RefCountingRunnable
-
Acquire a reference to this object and return a listener which releases it when notified.
- acquirePrimaryOperationPermit(ActionListener<Releasable>, Executor) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire a primary operation permit whenever the shard is ready for indexing.
- acquirePrimaryOperationPermit(ActionListener<Releasable>, Executor, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
- acquirePrimaryOperationPermit(IndexShard, TransportVerifyShardBeforeCloseAction.ShardRequest, ActionListener<Releasable>) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- acquirePrimaryOperationPermit(IndexShard, TransportVerifyShardIndexBlockAction.ShardRequest, ActionListener<Releasable>) - Method in class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction
- 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>, Executor) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire a replica operation permit whenever the shard is ready for indexing (see
IndexShard.acquirePrimaryOperationPermit(ActionListener, Executor)
). - acquireReplicaOperationPermit(IndexShard, TransportVerifyShardBeforeCloseAction.ShardRequest, ActionListener<Releasable>, long, long, long) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- acquireReplicaOperationPermit(IndexShard, TransportVerifyShardIndexBlockAction.ShardRequest, ActionListener<Releasable>, long, long, long) - Method in class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction
- 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
- acquireSearcher(String) - Method in class org.elasticsearch.index.engine.Engine.SearcherSupplier
- acquireSearcher(String) - Method in class org.elasticsearch.index.shard.IndexShard
- acquireSearcher(String) - Method in class org.elasticsearch.search.internal.LegacyReaderContext
- acquireSearcher(String) - Method in class org.elasticsearch.search.internal.ReaderContext
- acquireSearcher(String, Engine.SearcherScope) - Method in class org.elasticsearch.index.engine.Engine
- acquireSearcher(String, Engine.SearcherScope, Function<Engine.Searcher, Engine.Searcher>) - Method in class org.elasticsearch.index.engine.Engine
- acquireSearcherInternal(String) - Method in class org.elasticsearch.index.engine.Engine.SearcherSupplier
- acquireSearcherSupplier() - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquires a point-in-time reader that can be used to create
Engine.Searcher
s on demand. - acquireSearcherSupplier(Function<Engine.Searcher, Engine.Searcher>) - Method in class org.elasticsearch.index.engine.Engine
-
Acquires a point-in-time reader that can be used to create
Engine.Searcher
s on demand. - acquireSearcherSupplier(Function<Engine.Searcher, Engine.Searcher>, Engine.SearcherScope) - Method in class org.elasticsearch.index.engine.Engine
-
Acquires a point-in-time reader that can be used to create
Engine.Searcher
s on demand. - acquireSearcherSupplier(Function<Engine.Searcher, Engine.Searcher>, Engine.SearcherScope) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- acquireSearcherSupplier(Engine.SearcherScope) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquires a point-in-time reader that can be used to create
Engine.Searcher
s on demand. - acquireThrottle() - Method in class org.elasticsearch.index.engine.Engine.IndexThrottle
- action - Variable in class org.elasticsearch.action.ActionRequestBuilder
- action - Variable in class org.elasticsearch.action.ActionRequestLazyBuilder
- action() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
- action() - Method in record class org.elasticsearch.cluster.metadata.LifecycleExecutionState
-
Returns the value of the
action
record component. - action() - Method in record class org.elasticsearch.health.Diagnosis.Definition
-
Returns the value of the
action
record component. - action() - Method in record class org.elasticsearch.tasks.TaskInfo
-
Returns the value of the
action
record component. - action() - Method in exception org.elasticsearch.transport.ActionNotFoundTransportException
- action() - Method in record class org.elasticsearch.transport.Transport.ResponseContext
-
Returns the value of the
action
record component. - ACTION_ALIASES_FIELD - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesResponse.AliasActionResult
- ACTION_CHECK_ALLOCATION_EXPLAIN_API - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ACTION_ENABLE_CLUSTER_ROUTING_ALLOCATION - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ACTION_ENABLE_INDEX_ROUTING_ALLOCATION - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ACTION_FIELD - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesResponse.AliasActionResult
- ACTION_INCREASE_NODE_CAPACITY - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ACTION_INCREASE_SHARD_LIMIT_CLUSTER_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ACTION_INCREASE_SHARD_LIMIT_INDEX_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ACTION_INCREASE_TIER_CAPACITY_LOOKUP - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ACTION_INDICES_FIELD - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesResponse.AliasActionResult
- ACTION_MIGRATE_TIERS_AWAY_FROM_INCLUDE_DATA - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ACTION_MIGRATE_TIERS_AWAY_FROM_INCLUDE_DATA_LOOKUP - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ACTION_MIGRATE_TIERS_AWAY_FROM_REQUIRE_DATA - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ACTION_MIGRATE_TIERS_AWAY_FROM_REQUIRE_DATA_LOOKUP - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ACTION_NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportPrevalidateShardPathAction
- 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.gateway.LocalAllocateDangledIndices
- 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.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_NODE_NAME - Static variable in class org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesAction
- ACTION_ORIGIN_TRANSIENT_NAME - Static variable in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Name for the
origin
attribute. - ACTION_RESTORE_FROM_SNAPSHOT - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ACTION_SHARD_EXISTS - Static variable in class org.elasticsearch.indices.store.IndicesStore
- ACTION_TYPE_FIELD - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesResponse.AliasActionResult
- 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.PlainActionFuture
- 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.PlainActionFuture
- 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.PlainActionFuture
- ActionHandler(ActionType<Response>, Class<? extends TransportAction<Request, Response>>) - Constructor for class org.elasticsearch.plugins.ActionPlugin.ActionHandler
-
Create a record of an action, the TransportAction that handles it.
- ActionListener<Response> - Interface in org.elasticsearch.action
-
Callbacks are used extensively throughout Elasticsearch because they enable us to write asynchronous and nonblocking code, i.e.
- ActionListenerResponseHandler<Response extends TransportResponse> - Class in org.elasticsearch.action
-
An adapter for handling transport responses using an
ActionListener
. - ActionListenerResponseHandler(ActionListener<? super Response>, Writeable.Reader<Response>, Executor) - 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(Settings, IndexNameExpressionResolver, NamedWriteableRegistry, IndexScopedSettings, ClusterSettings, SettingsFilter, ThreadPool, List<ActionPlugin>, NodeClient, CircuitBreakerService, UsageService, SystemIndices, TelemetryProvider, ClusterService, RerouteService, List<ReservedClusterStateHandler<?>>, RestExtension, IncrementalBulkService) - Constructor for class org.elasticsearch.action.ActionModule
- actionName - Variable in class org.elasticsearch.action.support.TransportAction
- actionName() - Method in interface org.elasticsearch.action.support.MappedActionFilter
-
Return the name of the action for which this filter should be run
- 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
- ActionRequestLazyBuilder<Request extends ActionRequest,
Response extends ActionResponse> - Class in org.elasticsearch.action -
This class is similar to ActionRequestBuilder, except that it does not build the request until the request() method is called.
- ActionRequestLazyBuilder(ElasticsearchClient, ActionType<Response>) - Constructor for class org.elasticsearch.action.ActionRequestLazyBuilder
- 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
- ActionResponse.Empty - Class in org.elasticsearch.action
- actionResult() - Method in class org.elasticsearch.action.support.ListenableActionFuture
- actionResults() - Method in record class org.elasticsearch.action.admin.indices.alias.IndicesAliasesClusterStateUpdateRequest
-
Returns the value of the
actionResults
record component. - 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 record class org.elasticsearch.action.admin.indices.alias.IndicesAliasesClusterStateUpdateRequest
-
Returns the value of the
actions
record component. - Actions() - Constructor for class org.elasticsearch.indices.recovery.PeerRecoverySourceService.Actions
- Actions() - Constructor for class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- actionTime() - Method in record class org.elasticsearch.cluster.metadata.LifecycleExecutionState
-
Returns the value of the
actionTime
record component. - ActionTransportException - Exception in org.elasticsearch.transport
-
An action invocation failure.
- ActionTransportException(String, InetSocketAddress, String, String, Throwable) - Constructor for exception org.elasticsearch.transport.ActionTransportException
- 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
-
An action which can be invoked by
ElasticsearchClient.execute(org.elasticsearch.action.ActionType<Response>, Request)
. - ActionType(String) - Constructor for class org.elasticsearch.action.ActionType
-
Construct an
ActionType
with the given name. - ActionWithReservedState<T> - Interface in org.elasticsearch.reservedstate
- activate() - Method in class org.elasticsearch.index.engine.Engine.IndexThrottle
-
Activate throttling, which switches the lock to be a real lock
- 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
- active() - Method in record class org.elasticsearch.threadpool.ThreadPoolStats.Stats
-
Returns the value of the
active
record component. - 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).
- activePromotableReplicaWithHighestVersion(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns one active and promotable replica shard for the given shard id or
null
if no active replica is found. - ActiveShardCount - Record 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.
- ActiveShardCount(int) - Constructor for record class org.elasticsearch.action.support.ActiveShardCount
-
Creates an instance of a
ActiveShardCount
record class. - ActiveShardCount.EnoughShards - Record Class in org.elasticsearch.action.support
-
Record that captures the decision of
ActiveShardCount.enoughShardsActive(IndexShardRoutingTable)
. - activeShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of active shards - ActiveShardsObserver - Enum Class in org.elasticsearch.action.support
-
This utility class provides a primitive for waiting for a configured number of shards to become active before sending a response on an
ActionListener
. - activityTimeout() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- ActivityTracker() - Constructor for class org.elasticsearch.common.network.ThreadWatchdog.ActivityTracker
- actualized() - Method in class org.elasticsearch.cluster.metadata.DesiredNodes
- actualized() - Method in record class org.elasticsearch.cluster.metadata.DesiredNodeWithStatus
- ACTUALIZED - Enum constant in enum class org.elasticsearch.cluster.metadata.DesiredNodeWithStatus.Status
- actualShardSize() - Method in record class org.elasticsearch.cluster.routing.allocation.allocator.ClusterBalanceStats.NodeBalanceStats
-
Returns the value of the
actualShardSize
record component. - actualShardSize() - Method in record class org.elasticsearch.cluster.routing.allocation.allocator.ClusterBalanceStats.TierBalanceStats
-
Returns the value of the
actualShardSize
record component. - actualSizeToRead() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- adapt(CheckedFunction<AggregatorFactories, FilterByFilterAggregator, IOException>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterByFilterAggregator.AdapterBuilder
-
Subclasses should override this to adapt the
FilterByFilterAggregator
into another sort of aggregator if required. - adapt(InternalAggregation) - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
-
Adapt the result from the collecting Aggregator into the result expected by this Aggregator.
- adapt(InternalAggregation) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregatorFromFilters
- adaptAutoExpandReplicas(ClusterState) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Checks if there are replicas with the auto-expand feature that need to be adapted.
- AdapterBuilder(String, boolean, boolean, String, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FilterByFilterAggregator.AdapterBuilder
- AdaptingAggregator - Class in org.elasticsearch.search.aggregations
-
An Aggregator that delegates collection to another Aggregator and then translates its results into the results you'd expect from another aggregation.
- AdaptingAggregator(Aggregator, AggregatorFactories, CheckedFunction<AggregatorFactories, ? extends Aggregator, IOException>) - Constructor for class org.elasticsearch.search.aggregations.AdaptingAggregator
- adaptIntoFiltersOrNull(String, AggregatorFactories, ValuesSourceConfig, InternalRange.Factory<?, ?>, RangeAggregator.Range[], double, boolean, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- ADAPTIVE_SELECTION - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestParameters.Metric
- 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
- adaptResponse(Response, IndexShard) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- 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, 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(double) - Method in class org.elasticsearch.search.aggregations.metrics.CompensatedSum
-
Increments the Kahan sum by adding a value without a correction term.
- add(double) - Method in class org.elasticsearch.search.aggregations.metrics.EmptyTDigestState
- add(double) - Method in class org.elasticsearch.search.aggregations.metrics.MemoryTrackingTDigestArrays.MemoryTrackingTDigestDoubleArray
- add(double) - Method in class org.elasticsearch.search.aggregations.metrics.TDigestState
- add(double) - Method in interface org.elasticsearch.telemetry.metric.DoubleUpDownCounter
-
Add to the counter
- add(double, double) - Method in class org.elasticsearch.search.aggregations.metrics.CompensatedSum
-
Increments the Kahan sum by adding two sums, and updating the correction term for reducing numeric errors.
- add(double, long) - Method in class org.elasticsearch.search.aggregations.metrics.EmptyTDigestState
- add(double, long) - Method in class org.elasticsearch.search.aggregations.metrics.TDigestState
- add(double, Map<String, Object>) - Method in interface org.elasticsearch.telemetry.metric.DoubleUpDownCounter
-
Add to the counter
- add(int, int, int) - Method in class org.elasticsearch.common.util.Int3Hash
-
Try to add
key
. - 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) - Method in class org.elasticsearch.index.engine.SegmentsStats
- add(long) - Method in interface org.elasticsearch.plugins.internal.DocumentSizeAccumulator
-
Accumulates the reported size of the document
- add(long) - Method in interface org.elasticsearch.telemetry.metric.LongUpDownCounter
-
Add to the counter
- add(long, long) - Method in class org.elasticsearch.common.blobstore.DeleteResult
- add(long, long) - Method in class org.elasticsearch.common.util.LongLongHash
-
Try to add
key
. - add(long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds
-
Add the
owningBucketOrd, value
pair. - add(long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromMany
- add(long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromManySmall
- add(long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromSingle
- add(long, long, long) - Method in class org.elasticsearch.index.warmer.WarmerStats
- add(long, long, long, long) - Method in class org.elasticsearch.index.flush.FlushStats
- add(long, long, long, long, long, long, long, long, long, double) - Method in class org.elasticsearch.index.merge.MergeStats
- add(long, Map<String, Object>) - Method in interface org.elasticsearch.telemetry.metric.LongUpDownCounter
-
Add to the counter
- add(long, BytesRef) - Method in class org.elasticsearch.search.aggregations.bucket.terms.BytesKeyedBucketOrds
-
Add the
owningBucketOrd, value
pair. - add(long, ActionListener<Void>) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.PendingListenersQueue
- 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, Iterable<String>) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
- add(String, Object) - Method in class org.elasticsearch.injection.guice.internal.ToStringBuilder
- add(String, String) - Method in class org.elasticsearch.action.get.MultiGetRequest
- add(String, String) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- add(String, String) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- add(String, String...) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
- add(String, String[], FetchSourceContext, String, XContentParser, boolean) - Method in class org.elasticsearch.action.get.MultiGetRequest
- add(String, Query) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterByFilterAggregator.AdapterBuilder
- add(List<Component2D>, XYGeometry) - Method in class org.elasticsearch.lucene.spatial.CartesianShapeDocValuesQuery
-
Override if special cases, like dateline support, should be considered
- add(List<Component2D>, LatLonGeometry) - Method in class org.elasticsearch.lucene.spatial.LatLonShapeDocValuesQuery
- add(List<IndexableField>, Geometry) - Method in class org.elasticsearch.lucene.spatial.BinaryShapeDocValuesField
- add(IndexableField) - Method in class org.elasticsearch.index.mapper.LuceneDocument
- 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(CCSTelemetrySnapshot) - Method in class org.elasticsearch.action.admin.cluster.stats.CCSTelemetrySnapshot
-
Add the provided stats to the ones held by the current instance, effectively merging the two.
- add(CCSTelemetrySnapshot.PerClusterCCSTelemetry) - Method in class org.elasticsearch.action.admin.cluster.stats.CCSTelemetrySnapshot.PerClusterCCSTelemetry
- add(LongMetric.LongMetricValue) - Method in class org.elasticsearch.action.admin.cluster.stats.LongMetric.LongMetricValue
- add(SearchUsageStats) - Method in class org.elasticsearch.action.admin.cluster.stats.SearchUsageStats
-
Add the provided stats to the ones held by the current instance, effectively merging the two
- add(IndexDiskUsageStats) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- 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.BulkProcessor2
-
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
-
Deprecated.
- 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.BulkProcessor2
-
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
-
Deprecated.use
BulkRequestBuilder.add(IndexRequestBuilder)
instead - 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(SearchResponse) - Method in class org.elasticsearch.action.search.SearchResponseMerger
-
Add a search response to the list of responses to be merged together into one.
- 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
-
Deprecated.use
BulkRequestBuilder.add(UpdateRequestBuilder)
instead - 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.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, FetchSourceContext, String, Boolean, Boolean, Boolean, boolean, XContentType, RestApiVersion) - 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, 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(SchedulerEngine.Job) - Method in class org.elasticsearch.common.scheduler.SchedulerEngine
- add(ByteSizeValue, ByteSizeValue) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
- add(Geometry) - Method in class org.elasticsearch.lucene.spatial.CentroidCalculator
-
Add a geometry to the calculator
- add(BulkStats) - Method in class org.elasticsearch.index.bulk.stats.BulkStats
- 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(FieldMapper.Builder) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- add(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- add(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.PassThroughObjectMapper.Builder
- add(Mapper.Builder) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- add(NodeMappingStats) - Method in class org.elasticsearch.index.mapper.NodeMappingStats
- 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(FieldUsageStats) - Method in class org.elasticsearch.index.search.stats.FieldUsageStats
- 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(DenseVectorStats) - Method in class org.elasticsearch.index.shard.DenseVectorStats
- 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(ShardCountStats) - Method in class org.elasticsearch.index.shard.ShardCountStats
- add(ShardId, long) - Method in class org.elasticsearch.cluster.ClusterInfo.ReservedSpace.Builder
- add(SparseVectorStats) - Method in class org.elasticsearch.index.shard.SparseVectorStats
- 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(Module...) - Method in class org.elasticsearch.injection.guice.ModulesBuilder
- add(FsInfo.Path) - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- add(DelayedBucket<B>) - Method in class org.elasticsearch.search.aggregations.TopBucketBuilder
-
Add a bucket if it is competitive.
- add(TDigestState) - Method in class org.elasticsearch.search.aggregations.metrics.EmptyTDigestState
- add(TDigestState) - Method in class org.elasticsearch.search.aggregations.metrics.TDigestState
- add(ScriptFieldsContext.ScriptField) - Method in class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext
- add(CompletionStats) - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- add(TransportResponseHandler<? extends TransportResponse>, Transport.Connection, String) - Method in class org.elasticsearch.transport.Transport.ResponseHandlers
-
Adds a new response context and associates it with a new request ID.
- add(DoubleHistogram) - Method in class org.elasticsearch.search.aggregations.metrics.EmptyDoubleHdrHistogram
- 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(T) - Method in class org.elasticsearch.common.util.ObjectArrayPriorityQueue
-
Adds an Object to a PriorityQueue in log(size) time.
- 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, Boolean) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction.Add
-
Build the operation.
- ADD - Enum constant in enum class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
- ADD - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions
- ADD_BACKING_INDEX - Enum constant in enum class org.elasticsearch.cluster.metadata.DataStreamAction.Type
- ADD_COMPATIBILITY_VERSIONS_TO_NODE_INFO - Static variable in class org.elasticsearch.TransportVersions
- ADD_COMPATIBILITY_VERSIONS_TO_NODE_INFO_BACKPORT_8_16 - Static variable in class org.elasticsearch.TransportVersions
- ADD_DATA_STREAM_OPTIONS - Static variable in class org.elasticsearch.TransportVersions
- ADD_MANAGE_ROLES_PRIVILEGE - Static variable in class org.elasticsearch.TransportVersions
- ADD_ROLE_MAPPING_CLEANUP_MIGRATION - Static variable in class org.elasticsearch.index.IndexVersions
- ADD_SECURITY_MIGRATION - Static variable in class org.elasticsearch.index.IndexVersions
- addAbortListener(ActionListener<IndexShardSnapshotStatus.AbortStatus>) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- 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) - Method in class org.elasticsearch.index.query.TermsQueryBuilder.BinaryValues
- 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. - addAll(Collection<T>) - Method in class org.elasticsearch.common.util.ObjectArrayPriorityQueue
-
Adds all elements of the collection into the queue.
- addAll(List<? extends IndexableField>) - Method in class org.elasticsearch.index.mapper.LuceneDocument
- addAllocFailuresResetListenerTo(ClusterService) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Creates a cluster state listener that resets allocation failures.
- 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, Set<Integer>) - 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
- addBackingIndex(String, String) - Static method in class org.elasticsearch.cluster.metadata.DataStreamAction
- addBackingIndex(Metadata, Index) - Method in class org.elasticsearch.cluster.metadata.DataStream
-
Adds the specified index as a backing index and returns a new
DataStream
instance with the new combination of backing indices. - addBinding() - Method in class org.elasticsearch.injection.guice.multibindings.Multibinder.RealMultibinder
- addBinding(K) - Method in class org.elasticsearch.injection.guice.multibindings.MapBinder
-
Returns a binding builder used to add a new entry in the map.
- addBinding(K) - Method in class org.elasticsearch.injection.guice.multibindings.MapBinder.RealMapBinder
-
This creates two bindings.
- addBitsetMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addBlock(AddIndexBlockRequest, ActionListener<AddIndexBlockResponse>) - Method in class org.elasticsearch.client.internal.IndicesAdminClient
- AddBlockResult(Index) - Constructor for class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockResult
- AddBlockResult(Index, Exception) - Constructor for class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockResult
- AddBlockResult(Index, AddIndexBlockResponse.AddBlockShardResult[]) - Constructor for class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockResult
- addBlocks(IndexMetadata) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- AddBlockShardResult(int, AddIndexBlockResponse.AddBlockShardResult.Failure[]) - Constructor for class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult
- addBoolean(String, boolean) - Method in interface org.elasticsearch.index.mapper.RoutingFields
- addBoolean(String, boolean) - Method in enum class org.elasticsearch.index.mapper.RoutingFields.Noop
- addBoolean(String, boolean) - Method in class org.elasticsearch.index.mapper.RoutingPathFields
- 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
- addBoundAddressListener(ReadinessService.BoundAddressListener) - Method in class org.elasticsearch.readiness.ReadinessService
-
Add a listener for bound readiness service address.
- addBucketPathValidationError(String) - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder.ValidationContext
-
Add a validation error about the
buckets_path
. - addBuiltInJoinValidators(Collection<BiConsumer<DiscoveryNode, ClusterState>>) - Static method in class org.elasticsearch.cluster.coordination.NodeJoinExecutor
- addByte(byte) - Method in class org.elasticsearch.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.
- addChild(RetrieverBuilder) - Method in class org.elasticsearch.search.retriever.CompoundRetrieverBuilder
- addClass(Class<?>) - Method in class org.elasticsearch.injection.Injector
-
Instructs the injector to instantiate
classToProcess
in accordance with whatever annotations may be present on that class. - addClasses(Collection<Class<?>>) - Method in class org.elasticsearch.injection.Injector
-
Equivalent to multiple chained calls to
Injector.addClass(java.lang.Class<?>)
. - 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
- addCleanFilesDependency() - Method in class org.elasticsearch.index.shard.IndexShard
-
Creates a
Runnable
that must be executed before the clean files step in peer recovery can complete. - addClosedListener(ESCacheHelper.ClosedListener) - Method in interface org.elasticsearch.indices.ESCacheHelper
-
Adds a listener which will be called when the resource guarded by
ESCacheHelper.getKey()
is closed. - addClosedListener(ESCacheHelper.ClosedListener) - Method in class org.elasticsearch.indices.ESCacheHelper.Wrapper
- 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. - addCommaSeparatedNodesWithoutAttributes(Iterator<DiscoveryNode>, StringBuilder) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes
- addComponentTemplate(ClusterState, boolean, String, ComponentTemplate) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
- addConflict(String, String) - Method in class org.elasticsearch.index.mapper.FieldMapper.Conflicts
- 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.settings.ClusterUpdateSettingsResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesResponse
- 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.readonly.AddIndexBlockResponse
- 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.analyze.ReloadAnalyzersResponse
-
Override in subclass to add custom fields following the common `_shards` field
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.diskusage.AnalyzeIndexDiskUsageResponse
- 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.datastreams.DataStreamsStatsAction.Response
- 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
- AddDataStreamAlias(String, String, Boolean, String) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction.AddDataStreamAlias
- addDebugInfo(String, Object) - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfileBreakdown
-
Add extra debugging information about the aggregation.
- addDeprecatedName(String) - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Adds a deprecated parameter name.
- addDfsResult() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- addDfsResult() - Method in class org.elasticsearch.search.internal.SearchContext
-
Indicates that the caller will be using, and thus owning, a
DfsSearchResult
object. - addDfsResult() - Method in class org.elasticsearch.search.rank.RankSearchContext
- addDirectoryPath(Permissions, String, Path, String, boolean) - Static method in class org.elasticsearch.bootstrap.FilePermissionUtils
-
Add access to path with direct and/or recursive access.
- addDoc(int) - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Associates the given document id with the current ordinal.
- addDoc(LuceneDocument) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- addDocumentFields(Map<String, DocumentField>, Map<String, DocumentField>) - Method in class org.elasticsearch.search.SearchHit
- 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.
- addDocValues(String, long) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- addDynamic(String, String, Mapper, DocumentParserContext) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
-
Adds a dynamically created
Mapper
to this builder. - addDynamicMapper(Mapper) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Add a new mapper dynamically created while parsing.
- addDynamicMappingsUpdate(Mapping) - Method in class org.elasticsearch.index.mapper.ParsedDocument
- added() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- ADDED_AUTO_SHARDING_EVENT_VERSION - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- ADDED_ENABLED_FLAG_VERSION - Static variable in class org.elasticsearch.cluster.metadata.DataStreamLifecycle
- ADDED_FAILURE_STORE_TRANSPORT_VERSION - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- addedClusterAliases() - Method in record class org.elasticsearch.transport.RemoteClusterCredentialsManager.UpdateRemoteClusterCredentialsResult
-
Returns the value of the
addedClusterAliases
record component. - addedNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- addEffectiveRetentionParams(ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.DataStreamLifecycle
-
Adds a retention param to signal that this serialisation should include the effective retention metadata.
- addEncoded(long, int) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractLinearCounting
-
Add encoded value to the linear counting.
- adder - Variable in class org.elasticsearch.script.TimeSeriesCounter
- addError(String, Object...) - Method in interface org.elasticsearch.injection.guice.Binder
-
Records an error message which will be presented to the user at a later time.
- addError(Message) - Method in interface org.elasticsearch.injection.guice.Binder
-
Records an error message to be presented to the user at a later time.
- addError(Traceable, Throwable) - Method in interface org.elasticsearch.telemetry.tracing.Tracer
-
If an exception occurs during a span, you can add data about the exception to the span where the exception occurred.
- 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 trip if the that puts breaker over the limit.
- addEstimateBytesAndMaybeBreak(long, String) - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- addEvent(Traceable, String) - Method in interface org.elasticsearch.telemetry.tracing.Tracer
-
Some tracing implementations support the concept of "events" within a span, marking a point in time during the span when something interesting happened.
- addExtraXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.BaseTermQueryBuilder
- addExtraXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.TermQueryBuilder
- addFailureStoreIndex(String, String) - Static method in class org.elasticsearch.cluster.metadata.DataStreamAction
- addFailureStoreIndex(Metadata, Index) - Method in class org.elasticsearch.cluster.metadata.DataStream
-
Adds the specified index as a failure store index and returns a new
DataStream
instance with the new combination of failure store indices. - 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
- addFetchField(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a field to load and return.
- addFetchField(String) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Adds a field to load and return as part of the search request.
- addFetchField(String, String) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Adds a field to load and return as part of the search request.
- addFetchField(String, String, Boolean) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Adds a field to load and return as part of the search request.
- addFetchField(FieldAndFormat) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a field to load and return.
- addFetchResult() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- addFetchResult() - Method in class org.elasticsearch.search.internal.SearchContext
-
Indicates that the caller will be using, and thus owning, a
FetchSearchResult
object. - addFetchResult() - Method in class org.elasticsearch.search.rank.RankSearchContext
- addField(FieldInfo) - Method in class org.elasticsearch.index.codec.vectors.ES813Int8FlatVectorFormat.ES813FlatVectorWriter
- addField(FieldInfo) - Method in class org.elasticsearch.index.codec.vectors.ES816BinaryQuantizedVectorsWriter
- addField(LuceneDocument, 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. - addFieldNames(DocumentParserContext, String) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- addFields(LuceneDocument) - Method in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SequenceIDFields
- addFields(LuceneDocument, String, Number, boolean, boolean, boolean) - Method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
-
Maps the given
value
to one or more Lucene field values ands them to the givendocument
under the givenname
. - addFieldStringsFromParameter(TermVectorsRequest, String) - Static method in class org.elasticsearch.rest.action.document.RestTermVectorsAction
- addFileChangedListener(FileChangedListener) - Method in class org.elasticsearch.common.file.AbstractFileWatchingService
- addFileDetail(String, long, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addFileDetails(String, long, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- addFiles(Map<String, SegmentsStats.FileStats>) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addFilterQueries(List<QueryBuilder>) - Method in class org.elasticsearch.search.vectors.KnnSearchBuilder
- addFilterQueries(List<QueryBuilder>) - Method in class org.elasticsearch.search.vectors.KnnSearchBuilder.Builder
- addFilterQueries(List<QueryBuilder>) - Method in class org.elasticsearch.search.vectors.KnnVectorQueryBuilder
- addFilterQuery(QueryBuilder) - Method in class org.elasticsearch.search.vectors.KnnSearchBuilder
- addFilterQuery(QueryBuilder) - Method in class org.elasticsearch.search.vectors.KnnVectorQueryBuilder
- addFilterSettingParams(RestRequest) - Method in class org.elasticsearch.common.settings.SettingsFilter
- addFlushListener(Translog.Location, ActionListener<Long>) - Method in class org.elasticsearch.index.engine.Engine
- addFlushListener(Translog.Location, ActionListener<Long>) - Method in class org.elasticsearch.index.engine.InternalEngine
- 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
- addHandlingTime(long) - Method in class org.elasticsearch.common.network.HandlingTimeTracker
- 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.
- addIds(String, Iterable<String>) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- addIds(String, String...) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- addIgnoredField(String) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Add the given
field
to the set of ignored fields. - addIgnoredField(IgnoredSourceFieldMapper.NameValue) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Add the given ignored values to the corresponding list.
- addIgnoredFieldFromContext(IgnoredSourceFieldMapper.NameValue) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Adds an ignored field from the parser context, capturing an object or an array.
- addIgnoreShardForNode(ShardId, String) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- addIndexBlock(String, ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- addIndexBlock(AddIndexBlockClusterStateUpdateRequest, ActionListener<AddIndexBlockResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexStateService
-
Adds an index block based on the given request, and notifies the listener upon completion.
- AddIndexBlockClusterStateUpdateRequest - Record Class in org.elasticsearch.action.admin.indices.readonly
-
Cluster state update request that allows to add a block to one or more indices
- AddIndexBlockClusterStateUpdateRequest(TimeValue, TimeValue, IndexMetadata.APIBlock, long, Index[]) - Constructor for record class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockClusterStateUpdateRequest
-
Creates an instance of a
AddIndexBlockClusterStateUpdateRequest
record class. - AddIndexBlockRequest - Class in org.elasticsearch.action.admin.indices.readonly
-
A request to add a block to an index.
- AddIndexBlockRequest(IndexMetadata.APIBlock, String...) - Constructor for class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockRequest
-
Constructs a new request for the specified block and indices
- AddIndexBlockRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockRequest
- AddIndexBlockRequestBuilder - Class in org.elasticsearch.action.admin.indices.readonly
-
Builder for add index block request
- AddIndexBlockRequestBuilder(ElasticsearchClient, IndexMetadata.APIBlock, String...) - Constructor for class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockRequestBuilder
- AddIndexBlockResponse - Class in org.elasticsearch.action.admin.indices.readonly
- AddIndexBlockResponse(boolean, boolean, List<AddIndexBlockResponse.AddBlockResult>) - Constructor for class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse
- AddIndexBlockResponse.AddBlockResult - Class in org.elasticsearch.action.admin.indices.readonly
- AddIndexBlockResponse.AddBlockShardResult - Class in org.elasticsearch.action.admin.indices.readonly
- AddIndexBlockResponse.AddBlockShardResult.Failure - Exception in org.elasticsearch.action.admin.indices.readonly
- 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.Builder) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- addIndexShardCount(ClusterStatsIndices.ShardStats) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
- addIndexTemplateV2(ClusterState, boolean, String, ComposableIndexTemplate) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
- addIndexTemplateV2(ClusterState, boolean, String, ComposableIndexTemplate, boolean) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
- 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
- addInstance(Class<? super T>, T) - Method in class org.elasticsearch.injection.Injector
-
Indicates that
object
is to be injected for parameters of typetype
. - addInstance(Object) - Method in class org.elasticsearch.injection.Injector
-
Equivalent to
addInstance(object.getClass(), object)
. - addInstances(Collection<?>) - Method in class org.elasticsearch.injection.Injector
-
Equivalent to multiple calls to
Injector.addInstance(Object)
. - addInvertedIndex(String, long) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- addIp(String, InetAddress) - Method in interface org.elasticsearch.index.mapper.RoutingFields
- addIp(String, InetAddress) - Method in enum class org.elasticsearch.index.mapper.RoutingFields.Noop
- addIp(String, InetAddress) - Method in class org.elasticsearch.index.mapper.RoutingPathFields
- addItems(List<DocWriteRequest<?>>, Releasable, Runnable) - Method in class org.elasticsearch.action.bulk.IncrementalBulkService.Handler
- additionalSettings() - Method in class org.elasticsearch.plugins.Plugin
-
Additional node settings loaded by the plugin.
- AdditionalStats() - Constructor for class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction.AdditionalStats
- addJoinVote(Join) - Method in class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- addJsonNoBrackets(StringBuilder) - Method in class org.elasticsearch.common.logging.ESLogMessage
-
This method is used in order to support ESJsonLayout which replaces %CustomMapFields from a pattern with JSON fields It is a modified version of
MapMessage.asJson(StringBuilder)
where the curly brackets are not added - addKnnVectors(String, long) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- 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(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<RecoveryResponse>) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
- addListener(ActionListener<T>) - Method in class org.elasticsearch.action.support.SubscribableListener
-
Add a listener to this listener's collection of subscribers.
- addListener(ActionListener<T>, Executor, ThreadContext) - Method in class org.elasticsearch.action.support.SubscribableListener
-
Add a listener to this listener's collection of subscribers.
- 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(CancellableTask.CancellationListener) - Method in class org.elasticsearch.tasks.CancellableTask
-
This method adds a listener that needs to be notified if this task is cancelled.
- addListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.ClusterConnectionManager
- addListener(TransportConnectionListener) - Method in interface org.elasticsearch.transport.ConnectionManager
- addListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.ConnectionManager.DelegatingNodeConnectionListener
- addListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.RemoteConnectionManager
- 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
- addLong(String, long) - Method in interface org.elasticsearch.index.mapper.RoutingFields
- addLong(String, long) - Method in enum class org.elasticsearch.index.mapper.RoutingFields.Noop
- addLong(String, long) - Method in class org.elasticsearch.index.mapper.RoutingPathFields
- 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.
- 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.
- addMatching(String, BytesRef) - Method in class org.elasticsearch.cluster.routing.IndexRouting.ExtractFromSource.Builder
- addMaxIndexAgeCondition(String, String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Parses and adds max index age condition (can be automatic)
- addMaxIndexAgeCondition(TimeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConditions.Builder
-
Adds condition to check if the index is at least
age
old - addMaxIndexDocsCondition(Long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConditions.Builder
-
Adds condition to check if the index has at least
numDocs
- addMaxIndexDocsCondition(Long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Adds max index docs condition
- addMaxIndexDocsCondition(String, String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Parses and adds max index docs condition
- addMaxIndexSizeCondition(String, String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Parses and adds max index size
- addMaxIndexSizeCondition(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConditions.Builder
-
Adds a size-based condition to check if the index size is at least
size
. - addMaxPrimaryShardDocsCondition(Long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConditions.Builder
-
Adds a size-based condition to check if the docs of the largest primary shard has at least
numDocs
- addMaxPrimaryShardDocsCondition(Long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Adds max primary shard doc count
- addMaxPrimaryShardDocsCondition(String, String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Parses and adds max primary shard doc count
- addMaxPrimaryShardSizeCondition(String, String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Parses and adds max index primary shard size
- addMaxPrimaryShardSizeCondition(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConditions.Builder
-
Adds a size-based condition to check if the size of the largest primary shard is at least
size
. - addMessage(String, Object...) - Method in class org.elasticsearch.injection.guice.internal.Errors
- addMessage(Message) - Method in class org.elasticsearch.injection.guice.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.
- addMetadataListener(Consumer<IndexMetadata>) - Method in class org.elasticsearch.index.IndexService
- addMetric(String) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Add metric
- addMetric(NodesStatsRequestParameters.Metric) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Add metric
- addMetrics(String...) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Add multiple metrics
- addMetrics(List<NodesStatsRequestParameters.Metric>) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- addMetrics(Set<String>) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Add multiple metrics
- addMetrics(NodesStatsRequestParameters.Metric...) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Add an array of metric names
- addMinIndexAgeCondition(String, String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Parses and adds min index age condition
- addMinIndexAgeCondition(TimeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConditions.Builder
-
Adds required condition to check if the index is at least
age
old - addMinIndexDocsCondition(Long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConditions.Builder
-
Adds required condition to check if the index has at least
numDocs
- addMinIndexDocsCondition(Long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Adds the min index docs count condition
- addMinIndexDocsCondition(String, String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Parses and adds the min index docs count condition
- addMinIndexSizeCondition(String, String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Parses and adds min index size
- addMinIndexSizeCondition(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConditions.Builder
-
Adds a size-based required condition to check if the index size is at least
size
. - addMinPrimaryShardDocsCondition(Long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConditions.Builder
-
Adds a size-based required condition to check if the docs of the largest primary shard has at least
numDocs
- addMinPrimaryShardDocsCondition(Long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Adds the max primary shard doc count
- addMinPrimaryShardDocsCondition(String, String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Parses and adds the max primary shard doc count
- addMinPrimaryShardSizeCondition(String, String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
-
Parses and adds min index primary shard size
- addMinPrimaryShardSizeCondition(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConditions.Builder
-
Adds a size-based required condition to check if the size of the largest primary shard is at least
size
. - addMultiField(FieldMapper.Builder) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- addNamedQuery(String, Query) - Method in class org.elasticsearch.index.query.FilteredSearchExecutionContext
- addNamedQuery(String, Query) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- addNewHistoryCommit(Directory, Terminal, boolean) - Static method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- addNodeStatistics(String, int, long, long) - Method in class org.elasticsearch.node.ResponseCollectorService
- addNorms(String, long) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- addOnClose(Releasable) - Method in class org.elasticsearch.search.internal.ReaderContext
- addOne(long) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- addOneCandidate(DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.CandidateSet
- addOptimalShardCountCondition(AutoShardingResult) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConditions.Builder
-
Adds an optimal shard count condition if the autosharding result is of type INCREASE or DECREASE_SHARDS, ignores it otherwise.
- 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(long, boolean, ActionListener<Void>) - Method in class org.elasticsearch.index.shard.RefreshListeners
-
Add a listener for refreshes, calling it immediately if the location is already visible.
- 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.
- addOrNotify(Translog.Location, ActionListener<Long>) - Method in class org.elasticsearch.index.engine.FlushListeners
- addPeerFinderListener(Coordinator.PeerFinderListener) - Method in class org.elasticsearch.cluster.coordination.Coordinator
- 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
- addPendingAction(String, RetryableAction<?>) - Method in class org.elasticsearch.action.support.replication.PendingReplicationActions
- 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.
- addPipeline(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Adds the pipeline to the list of executed pipelines, if listExecutedPipelines is true
- addPipelineAggregator(PipelineAggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- addPoints(String, long) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- addPreRestoreVersionCheck() - Method in interface org.elasticsearch.plugins.RepositoryPlugin
-
Returns a check that is run on restore.
- addPrimaryTermAndGenerationListener(long, long, ActionListener<Long>) - Method in class org.elasticsearch.index.engine.Engine
-
Allows registering a listener for when the index shard is on a primary term >= minPrimaryTerm and a segment generation >= minGeneration.
- addProcessedFile(long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Increments number of processed files
- addProcessedFiles(int, long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- addQueryCancellation(Runnable) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
-
Add a
Runnable
that will be run on a regular basis while accessing documents in the DirectoryReader but also while collecting them and check for query cancellation or timeout. - addQueryProfiler() - Method in class org.elasticsearch.search.profile.dfs.DfsProfiler
- addQueryResult() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- addQueryResult() - Method in class org.elasticsearch.search.internal.SearchContext
-
Indicates that the caller will be using, and thus owning, a
QuerySearchResult
object. - addQueryResult() - Method in class org.elasticsearch.search.rank.RankSearchContext
- addRamBytesUsed(long) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- 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
- addRankFeatureResult() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- addRankFeatureResult() - Method in class org.elasticsearch.search.internal.SearchContext
- addRankFeatureResult() - Method in class org.elasticsearch.search.rank.RankSearchContext
- 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
- addRecoveredBytesToFile(String, long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- addRecoveredFromSnapshotBytesToFile(String, long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addRecoveredFromSnapshotBytesToFile(String, long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- addRectangle(int, int, int, int) - Method in class org.elasticsearch.lucene.spatial.Extent
-
Adds the extent of two points representing a bounding box's bottom-left and top-right points.
- addRefreshListener(long, boolean, ActionListener<Void>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Add a listener for refreshes.
- addRefreshListener(Translog.Location, Consumer<Boolean>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Add a listener for refreshes.
- addReleasable(Releasable) - Method in class org.elasticsearch.search.internal.SearchContext
-
Adds a releasable that will be freed when this context is closed.
- addReleasable(Releasable) - Method in class org.elasticsearch.search.query.QuerySearchResult
- addReleasable(Aggregator) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Cause this aggregation to be released when the search is finished.
- addReleasable(Aggregator) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- addRemovedListener(ActionListener<Void>) - Method in class org.elasticsearch.transport.CloseableConnection
- addRemovedListener(ActionListener<Void>) - Method in interface org.elasticsearch.transport.Transport.Connection
-
Similar to
Transport.Connection.addCloseListener(org.elasticsearch.action.ActionListener<java.lang.Void>)
except that these listeners are notified once the connection is removed from the transport service. - addReplica(ShardRouting.Role) - 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
. - addRequestStats(int) - Method in class org.elasticsearch.http.HttpRouteStatsTracker
- addRequestStats(int) - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- addRequestStats(int) - Method in class org.elasticsearch.transport.TransportActionStatsTracker
- 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.rank.RankSearchContext
- 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
. - 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. - addResponseStats(int) - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- addResponseStats(int) - Method in interface org.elasticsearch.transport.ResponseStatsConsumer
- addResponseStats(int) - Method in class org.elasticsearch.transport.TransportActionStatsTracker
- addResponseStats(long) - Method in class org.elasticsearch.http.HttpRouteStatsTracker
- addResponseTime(long) - Method in class org.elasticsearch.http.HttpRouteStatsTracker
- address - Variable in class org.elasticsearch.script.field.IPAddress
- address() - Method in class org.elasticsearch.common.transport.TransportAddress
-
Returns the enclosed
InetSocketAddress
- address() - Method in class org.elasticsearch.http.HttpInfo
- address() - Method in class org.elasticsearch.transport.TransportInfo
- addressBound(BoundTransportAddress) - Method in interface org.elasticsearch.readiness.ReadinessService.BoundAddressListener
-
This method is going to be called only the first time the address is bound.
- 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.
- addRunLen(long, int, int) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLog
-
Add a new runLen to the register.
- addRunLen(long, int, int) - Method in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- addRuntimeField(RuntimeField) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- addRuntimeFields(Map<String, RuntimeField>) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- 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
- addScriptValidation(FieldMapper.Parameter<Script>, FieldMapper.Parameter<Boolean>, FieldMapper.Parameter<Boolean>) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- addScrollId(String) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- addScrollId(String) - Method in class org.elasticsearch.action.search.ClearScrollRequestBuilder
- addSearchOperationListener(SearchOperationListener) - Method in class org.elasticsearch.index.IndexModule
-
Adds an
SearchOperationListener
for this index. - addSegmentGenerationListener(long, ActionListener<Long>) - Method in class org.elasticsearch.index.engine.Engine
-
Deprecated.
- addServerExportsService(Map<String, List<ModuleQualifiedExportsService>>) - Method in class org.elasticsearch.plugins.PluginsService
- 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(Consumer<Settings>, List<? extends Setting<?>>, Consumer<Settings>) - 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, IndexVersion, 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, RepositoryData.SnapshotDetails, ShardGenerations, Map<IndexId, String>, Map<String, String>) - 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
-
Deprecated.Specifying a sort field for reindex is deprecated. If using this in combination with maxDocs, consider using a query filter instead.
- 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.
- addStoredField(String, long) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- addString(String, String) - Method in interface org.elasticsearch.index.mapper.RoutingFields
- addString(String, String) - Method in enum class org.elasticsearch.index.mapper.RoutingFields.Noop
- addString(String, BytesRef) - Method in interface org.elasticsearch.index.mapper.RoutingFields
-
This overloaded method tries to take advantage of the fact that the UTF-8 value is already computed in some cases when we want to collect routing fields, so we can save re-computing the UTF-8 encoding.
- addString(String, BytesRef) - Method in enum class org.elasticsearch.index.mapper.RoutingFields.Noop
- addString(String, BytesRef) - Method in class org.elasticsearch.index.mapper.RoutingPathFields
- 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
- addTermVectors(String, long) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- addThrottleTime(long) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- addTimeout(TimeValue, ThreadPool, Executor) - Method in class org.elasticsearch.action.support.SubscribableListener
-
Adds a timeout to this listener, such that if the timeout elapses before the listener is completed then it will be completed with an
ElasticsearchTimeoutException
. - 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.
- addToBuffer(ByteBuffer) - Method in record class org.elasticsearch.search.vectors.VectorData
- addToCopy(Set<E>, E...) - Static method in class org.elasticsearch.common.util.set.Sets
-
Creates a copy of the given set and adds extra elements.
- addToFieldNames(String) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Add the given
field
to the _field_names field Use this if an exists query run against the field cannot use docvalues or norms. - 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.
- addToRequestBuilder(UpdateHealthInfoCacheAction.Request.Builder) - Method in class org.elasticsearch.health.node.tracker.HealthTracker
-
Add the last reported health to the request builder.
- addToRequestBuilder(UpdateHealthInfoCacheAction.Request.Builder, DiskHealthInfo) - Method in class org.elasticsearch.health.node.tracker.DiskHealthTracker
- addToRequestBuilder(UpdateHealthInfoCacheAction.Request.Builder, RepositoriesHealthInfo) - Method in class org.elasticsearch.health.node.tracker.RepositoriesHealthTracker
- addToRequestBuilder(UpdateHealthInfoCacheAction.Request.Builder, T) - Method in class org.elasticsearch.health.node.tracker.HealthTracker
-
Add the health info to the request builder.
- addToSliceStatuses(BulkByScrollTask.StatusOrException) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- addTotals(BulkStats) - Method in class org.elasticsearch.index.bulk.stats.BulkStats
- 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
- addTracingHandler(HttpBody.ChunkHandler) - Method in interface org.elasticsearch.http.HttpBody.Stream
-
Adds tracing chunk handler.
- 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.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.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. - addUnsignedLong(String, long) - Method in interface org.elasticsearch.index.mapper.RoutingFields
- addUnsignedLong(String, long) - Method in enum class org.elasticsearch.index.mapper.RoutingFields.Noop
- addUnsignedLong(String, long) - Method in class org.elasticsearch.index.mapper.RoutingPathFields
- addValidationError(String) - Method in exception org.elasticsearch.common.ValidationException
-
Add a new validation error to the accumulating validation errors
- addValidationError(String) - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder.ValidationContext
-
Add a validation error to this context.
- 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
. - addValidator(Consumer<T>) - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Adds validation to a parameter, called after parsing and merging.
- 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
- 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(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
- AddVotingConfigExclusionsRequest(TimeValue, 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 node names, and wait for a default 30 seconds for these exclusions to take effect, removing the nodes from the voting configuration.
- AddVotingConfigExclusionsRequest(TimeValue, String[], 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.
- addWarning(String, Object...) - Static method in class org.elasticsearch.common.logging.HeaderWarning
- addWarningHeaderIfDataRetentionNotEffective(DataStreamGlobalRetention, boolean) - Method in class org.elasticsearch.cluster.metadata.DataStreamLifecycle
-
This method checks if the effective retention is matching what the user has configured; if the effective retention does not match then it adds a warning informing the user about the effective retention and the source.
- addWhileCorrectingForCoordinatedOmission(DoubleHistogram, double) - Method in class org.elasticsearch.search.aggregations.metrics.EmptyDoubleHdrHistogram
- addWithBackpressure(IndexRequest, Supplier<Boolean>) - Method in class org.elasticsearch.action.bulk.BulkProcessor2
-
This method is similar to
add()
, except that if adding the approximate size in bytes of the request to totalBytesInFlight would exceed maxBytesInFlight then this method will block until the request can be added without exceeding maxBytesInFlight (or until shouldAbort returns false). - addWithKey(Object, IndexableField) - Method in class org.elasticsearch.index.mapper.LuceneDocument
-
Add fields so that they can later be fetched using
LuceneDocument.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
-
Add bytes to the circuit breaker without tripping.
- addWithoutBreaking(long) - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- ADJUST_PURE_NEGATIVE_DEFAULT - Static variable in class org.elasticsearch.index.query.BoolQueryBuilder
- AdjustableSemaphore - Class in org.elasticsearch.common.util.concurrent
- AdjustableSemaphore(int, boolean) - Constructor for class org.elasticsearch.common.util.concurrent.AdjustableSemaphore
- adjustBreaker(long) - Method in class org.elasticsearch.search.aggregations.metrics.MemoryTrackingTDigestArrays
- adjustBucketCountThresholds(TermsAggregator.BucketCountThresholds, BucketOrder) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
- 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.internal.Client
-
The admin client that can be used to perform administrative operations.
- admin() - Method in class org.elasticsearch.client.internal.support.AbstractClient
- AdminClient - Class in org.elasticsearch.client.internal
-
Administrative actions/operations against the cluster or the indices.
- AdminClient(ElasticsearchClient) - Constructor for class org.elasticsearch.client.internal.AdminClient
- advance(int) - Method in class org.elasticsearch.index.codec.vectors.ES816BinaryQuantizedVectorsReader.BinarizedVectorValues
- advance(int) - Method in class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues.DenseOffHeapVectorValues
- 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(int) - Method in class org.elasticsearch.index.fielddata.SourceValueFetcherSortedNumericIndexFieldData.SourceValueFetcherSortedNumericDocValues
- advance(int) - Method in class org.elasticsearch.index.mapper.vectors.DenormalizedCosineFloatVectorValues
- advance(int) - Method in interface org.elasticsearch.search.LeafNestedDocuments
-
Advance to a specific doc, and return its NestedIdentity, or
null
if not a child - advance(GeoPoint) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource.CellSingleValue
-
Sets the appropriate long-encoded value for
target
invalue
. - ADVANCE - Enum constant in enum class org.elasticsearch.search.profile.query.QueryTimingType
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.AbstractNumericDocValues
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.BooleanScriptDocValues
- 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.DoubleScriptDocValues
- advanceExact(int) - Method in interface org.elasticsearch.index.fielddata.FormattedDocValues
-
Advance the doc values reader to the provided doc.
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.GeoPointScriptDocValues
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.HistogramValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.IpScriptDocValues
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.LongScriptDocValues
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.MultiPointValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.plain.FormattedSortedNumericDocValues
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.PointValues
-
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.index.fielddata.SourceValueFetcherMultiGeoPointIndexFieldData.SourceValueFetcherMultiGeoPointDocValues
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.SourceValueFetcherSortedBinaryIndexFieldData.SourceValueFetcherSortedBinaryDocValues
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.SourceValueFetcherSortedNumericIndexFieldData.SourceValueFetcherSortedNumericDocValues
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.StringScriptDocValues
- advanceExact(int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource.CellMultiValues
- advanceExact(int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource.CellSingleValue
- 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
- advanceExact(int) - Method in class org.elasticsearch.search.sort.BucketedSort.Leaf
-
Read the sort value from
doc
and returntrue
if there is a value for that document. - 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.
- advanceMaxSeqNoOfDeletesOnPrimary(long) - Method in class org.elasticsearch.index.engine.InternalEngine
- advanceMaxSeqNoOfUpdatesOnPrimary(long) - Method in class org.elasticsearch.index.engine.InternalEngine
- 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.
- advanceShallow(int) - Method in class org.elasticsearch.common.lucene.search.function.MinScoreScorer
- advanceTo(int) - Method in interface org.elasticsearch.index.fieldvisitor.LeafStoredFieldLoader
-
Advance the reader to a document.
- advanceTo(int) - Method in class org.elasticsearch.index.mapper.BlockLoaderStoredFieldsFromLeafLoader
- advanceToDoc(int) - Method in interface org.elasticsearch.index.mapper.SourceLoader.SyntheticFieldLoader.DocValuesLoader
-
Load the doc values for this field.
- advanceValue(GeoPoint, int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource.CellMultiValues
-
Sets the appropriate long-encoded value for
target
invalues
. - affectedResources() - Method in record class org.elasticsearch.health.Diagnosis
-
Returns the value of the
affectedResources
record component. - affixKeySetting(String, String, BiFunction<String, String, Setting<T>>, Setting.AffixSettingDependency...) - Static method in class org.elasticsearch.common.settings.Setting
- affixKeySetting(String, String, Function<String, Setting<T>>, Setting.AffixSettingDependency...) - 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>, BiFunction<String, String, Setting<T>>, Setting.AffixSettingDependency...) - Constructor for class org.elasticsearch.common.settings.Setting.AffixSetting
- after() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- after() - Method in record class org.elasticsearch.cluster.metadata.DataStreamLifecycle.Downsampling.Round
-
Returns the value of the
after
record component. - after(SnapshotSortKey.After) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- after(Priority) - Method in enum class org.elasticsearch.common.Priority
- after(T) - Method in interface org.elasticsearch.common.VersionId
- After(String, String, String) - Constructor for record class org.elasticsearch.action.admin.cluster.snapshots.get.SnapshotSortKey.After
-
Creates an instance of a
After
record class. - AFTER_FIELD - Static variable in record class org.elasticsearch.cluster.metadata.DataStreamLifecycle.Downsampling.Round
- AFTER_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- afterBatchExecution(ClusterState, boolean) - Method in class org.elasticsearch.cluster.SimpleBatchedAckListenerTaskExecutor
-
Called once all tasks in the batch have finished execution.
- afterBatchExecution(ClusterState, boolean) - Method in class org.elasticsearch.cluster.SimpleBatchedExecutor
-
Called once all tasks in the batch have finished execution.
- afterBulk(long, long) - Method in interface org.elasticsearch.index.bulk.stats.BulkOperationListener
-
Called after the bulk operation occurred.
- afterBulk(long, long) - Method in class org.elasticsearch.index.bulk.stats.ShardBulkStats
- afterBulk(long, BulkRequest, Exception) - Method in interface org.elasticsearch.action.bulk.BulkProcessor2.Listener
-
Callback after a failed execution of bulk request.
- 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.
- afterBulk(long, BulkRequest, BulkResponse) - Method in interface org.elasticsearch.action.bulk.BulkProcessor2.Listener
-
Callback after a successful execution of bulk request.
- afterCleanFiles(Runnable) - Method in class org.elasticsearch.index.shard.IndexShard
-
Execute a
Runnable
on the generic pool once all dependencies added viaIndexShard.addCleanFilesDependency()
have finished. - 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.TaskExecutionTimeTrackingEsThreadPoolExecutor
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.threadpool.Scheduler.SafeScheduledThreadPoolExecutor
- afterFilesRestoredFromRepository(IndexShard) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the raw files have been restored from the repository but any other recovery processing has happened
- afterFlush(long) - Method in class org.elasticsearch.index.engine.InternalEngine
- afterFlush(long, Translog.Location) - Method in class org.elasticsearch.index.engine.FlushListeners
- 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.
- afterIndexShardClosing(ShardId, IndexShard, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been marked 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.
- afterIndexShardRecovery(IndexShard, ActionListener<Void>) - Method in interface org.elasticsearch.index.shard.IndexEventListener
- afterIndexShardStarted(IndexShard) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been started.
- 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
- afterLoad(TermsEnum, long) - Method in interface org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData.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.
- afterMerge(OnGoingMerge) - Method in class org.elasticsearch.index.engine.ElasticsearchConcurrentMergeScheduler
-
A callback allowing for custom logic before an actual merge starts.
- afterPrimariesBeforeReplicas(RoutingAllocation, Predicate<ShardRouting>) - Method in interface org.elasticsearch.cluster.routing.allocation.ExistingShardsAllocator
-
Called during a round of allocation after attempting to allocate all the primaries but before any replicas, allowing the allocator to prepare for replica allocation.
- afterPrimariesBeforeReplicas(RoutingAllocation, Predicate<ShardRouting>) - Method in class org.elasticsearch.gateway.GatewayAllocator
- afterRefresh(boolean) - Method in class org.elasticsearch.index.engine.CompletionStatsCache
- afterRefresh(boolean) - Method in class org.elasticsearch.index.engine.LiveVersionMap
- afterRefresh(boolean) - Method in class org.elasticsearch.index.shard.RefreshListeners
- afterRefresh(LiveVersionMap.VersionLookup) - Method in interface org.elasticsearch.index.engine.LiveVersionMapArchive
-
Archive the old map evacuated due to a refresh
- 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
- afterValue - Variable in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSource
- 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.
- age() - Method in record class org.elasticsearch.cluster.coordination.JoinStatus
-
Returns the value of the
age
record component. - agent() - Method in record class org.elasticsearch.http.HttpStats.ClientStats
-
Returns the value of the
agent
record component. - aggReduceContextBuilder(Supplier<Boolean>, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.SearchService
-
Returns a builder for
AggregationReduceContext
. - aggregate(ReleasableBytesReference) - Method in class org.elasticsearch.transport.InboundAggregator
- 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(Map<Term, TermStatistics>, Map<String, CollectionStatistics>, long) - Constructor for class org.elasticsearch.search.dfs.AggregatedDfs
- AggregatedDfs(StreamInput) - Constructor for class org.elasticsearch.search.dfs.AggregatedDfs
- aggregateDfs(Collection<DfsSearchResult>) - Static method in class org.elasticsearch.action.search.SearchPhaseController
- aggregation() - Method in class org.elasticsearch.search.aggregations.metrics.InternalScriptedMetric
- 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.BucketCardinality - Enum Class in org.elasticsearch.search.aggregations
-
A rough count of the number of buckets that
Aggregator
s built by this builder will contain per parent bucket used to validate sorts and pipeline aggregations. - 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.
- AggregationContext - Class in org.elasticsearch.search.aggregations.support
-
Everything used to build and execute aggregations and the
data sources
that power them. - AggregationContext() - Constructor for class org.elasticsearch.search.aggregations.support.AggregationContext
- AggregationContext.ProductionAggregationContext - Class in org.elasticsearch.search.aggregations.support
-
Implementation of AggregationContext for production usage that wraps our ubiquitous
SearchExecutionContext
and anything else specific to aggregations. - AggregationErrors - Class in org.elasticsearch.search.aggregations
-
Collection of helper methods for what to throw in common aggregation error scenarios.
- AggregationExecutionContext - Class in org.elasticsearch.search.aggregations
-
Used to preserve contextual information during aggregation execution.
- AggregationExecutionContext(LeafReaderContext, Supplier<BytesRef>, LongSupplier, IntSupplier) - Constructor for class org.elasticsearch.search.aggregations.AggregationExecutionContext
- 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
- AggregationExecutionException.InvalidPath - Exception in org.elasticsearch.search.aggregations
- AggregationInfo - Class in org.elasticsearch.search.aggregations.support
- AggregationInfo(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.support.AggregationInfo
-
Read from a stream.
- AggregationInitializationException - Exception in org.elasticsearch.search.aggregations
-
Thrown when failing to execute an aggregation
- 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 - Record Class in org.elasticsearch.search.aggregations.support
- AggregationPhase - Class in org.elasticsearch.search.aggregations
-
Aggregation phase of a search request, used to collect aggregations
- AggregationProfileBreakdown - Class in org.elasticsearch.search.profile.aggregation
-
AbstractProfileBreakdown customized to work with aggregations.
- 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.
- AggregationReduceContext - Class in org.elasticsearch.search.aggregations
-
Dependencies used to reduce aggs.
- AggregationReduceContext.Builder - Interface in org.elasticsearch.search.aggregations
-
Builds
AggregationReduceContext
s. - AggregationReduceContext.ForFinal - Class in org.elasticsearch.search.aggregations
-
A AggregationReduceContext to perform the final reduction.
- AggregationReduceContext.ForPartial - Class in org.elasticsearch.search.aggregations
-
A AggregationReduceContext to perform a partial reduction.
- aggregations - Variable in class org.elasticsearch.action.search.SearchResponseSections
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramBucket
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- aggregations() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
-
Should the node rest actions usage statistics be returned.
- aggregations() - Method in record class org.elasticsearch.action.search.SearchPhaseController.ReducedQueryPhase
-
Returns the value of the
aggregations
record component. - 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() - Method in class org.elasticsearch.search.query.QuerySearchResult
- aggregations() - Method in class org.elasticsearch.search.rank.RankSearchContext
-
Aggregations are run as a separate query.
- aggregations(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
-
Should the node rest actions usage statistics be returned.
- 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(SearchContextAggregations) - Method in class org.elasticsearch.search.rank.RankSearchContext
- AGGREGATIONS - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoMetrics.Metric
- AGGREGATIONS - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- AGGREGATIONS - Static variable in class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- AGGREGATIONS_FIELD - Static variable in class org.elasticsearch.search.aggregations.InternalAggregations
- AGGREGATIONS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- aggregationsBuilder(AggregatorFactories.Builder) - Method 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
-
Deprecated.Use the ctor that takes a
ContextParser
instead - AggregationSpec(String, Writeable.Reader<T>, ContextParser<String, T>) - 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
-
Deprecated.Use the ctor that takes a
ContextParser
instead - AggregationSpec(ParseField, Writeable.Reader<T>, ContextParser<String, T>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Specification for an
Aggregation
. - AggregationTimingType - Enum Class in org.elasticsearch.search.profile.aggregation
- AggregationUsageService - Class in org.elasticsearch.search.aggregations.support
- AggregationUsageService.Builder - Class in org.elasticsearch.search.aggregations.support
- Aggregator - Class in org.elasticsearch.search.aggregations
-
An Aggregator.
- Aggregator() - Constructor for class org.elasticsearch.search.aggregations.Aggregator
- Aggregator.BucketComparator - Interface in org.elasticsearch.search.aggregations
-
Compare two buckets by their ordinal.
- Aggregator.Parser - Interface in org.elasticsearch.search.aggregations
-
Parses the aggregation request and creates the appropriate aggregator factory for it.
- Aggregator.SubAggCollectionMode - Enum Class 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, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.AggregatorBase
-
Constructs a new Aggregator.
- AggregatorCollector - Class in org.elasticsearch.search.aggregations
-
Collector that controls the life cycle of an aggregation document collection.
- AggregatorCollector(Aggregator[], BucketCollector) - Constructor for class org.elasticsearch.search.aggregations.AggregatorCollector
- AggregatorCollectorManager - Class in org.elasticsearch.search.aggregations
-
Collector manager that produces
AggregatorCollector
and merges them during the reduce phase. - AggregatorCollectorManager(Supplier<AggregatorCollector>, Consumer<InternalAggregations>, Supplier<AggregationReduceContext>) - Constructor for class org.elasticsearch.search.aggregations.AggregatorCollectorManager
- AggregatorFactories - Class in org.elasticsearch.search.aggregations
-
An immutable collection of
AggregatorFactories
. - AggregatorFactories.Builder - Class in org.elasticsearch.search.aggregations
-
A mutable collection of
AggregationBuilder
s andPipelineAggregationBuilder
s. - AggregatorFactory - Class in org.elasticsearch.search.aggregations
- AggregatorFactory(String, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.AggregatorFactory
-
Constructs a new aggregator factory.
- AggregatorReducer - Interface in org.elasticsearch.search.aggregations
-
Interface for reducing aggregations to a single one.
- aggregators() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.PipelineTree
-
The
PipelineAggregator
s for the aggregation at this position in the tree. - AggregatorsReducer - Class in org.elasticsearch.search.aggregations
-
Interface for reducing
InternalAggregations
to a single one in a streaming fashion. - AggregatorsReducer(InternalAggregations, AggregationReduceContext, int) - Constructor for class org.elasticsearch.search.aggregations.AggregatorsReducer
-
Solo constructor
- AGGS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- aggsUsedForSorting - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- aggsUsedForSorting(Aggregator, BucketOrder) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
-
Walks through bucket order and extracts all aggregations used for sorting
- 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, List<IndexMetadata>) - Constructor for class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- Alias(DataStreamAlias, List<Index>, Index) - Constructor for class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- Alias(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.alias.Alias
- ALIAS - Enum constant in enum class org.elasticsearch.cluster.metadata.IndexAbstraction.Type
-
An index abstraction that refers to an 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.AddDataStreamAlias - Class in org.elasticsearch.cluster.metadata
- 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.RemoveDataStreamAlias - Class in org.elasticsearch.cluster.metadata
- 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.
- aliasedIndices() - Method in class org.elasticsearch.cluster.metadata.Metadata
- aliasedIndices(String) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Returns all the indices that the alias with the provided alias name refers to.
- 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() - Method in class org.elasticsearch.cluster.metadata.Template
- 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(Map<String, AliasMetadata>) - Method in class org.elasticsearch.cluster.metadata.Template.Builder
- 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 class org.elasticsearch.client.internal.IndicesAdminClient
- aliases(IndicesAliasesRequest, ActionListener<IndicesAliasesResponse>) - Method in class org.elasticsearch.client.internal.IndicesAdminClient
- 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 - Enum constant in enum class org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
- ALIASES - Static variable in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- 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(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- aliasFilter() - Method in class org.elasticsearch.action.search.SearchContextId
- AliasFilter - Class in org.elasticsearch.search.internal
-
Represents a
QueryBuilder
and a list of alias names that filters the builder is composed of. - 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
- aliasName() - Method in record class org.elasticsearch.cluster.metadata.MetadataMigrateToDataStreamService.MigrateToDataStreamClusterStateUpdateRequest
-
Returns the value of the
aliasName
record component. - 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
- alignesWithSearchIndex() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
Do
ValuesSource
s built by this config line up with the search index of the underlying field? This'll only return true if the fields is searchable and there aren't missing values or a script to confuse the ordering. - 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() - Method in class org.elasticsearch.action.support.IndicesOptions.WildcardOptions.Builder
-
Maximises the resolution of indices, we will match open, closed and hidden targets.
- ALL - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
- ALL - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
- ALL - Enum constant in enum class org.elasticsearch.index.analysis.AnalysisMode
-
AnalysisMode representing analysis components that can be used both at index and search time
- ALL - Enum constant in enum class org.elasticsearch.index.mapper.Mapper.SourceKeepMode
- ALL - Enum constant in enum class org.elasticsearch.index.query.RegexpFlag
-
Enables all available option flags
- ALL - Enum constant in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- ALL - Enum constant in enum class org.elasticsearch.index.query.ZeroTermsQueryOption
- ALL - Enum constant in enum class org.elasticsearch.indices.SystemIndices.SystemIndexAccessLevel
-
Access level that skips system resource access checks.
- ALL - Enum constant in enum class org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
- ALL - Static variable in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestParameters.Metric
- ALL - Static variable in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- ALL - Static variable in record class org.elasticsearch.action.support.ActiveShardCount
- ALL - Static variable in enum class 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_APPLICABLE - Enum constant in enum class org.elasticsearch.action.support.IndexComponentSelector
- ALL_APPLICABLE - Static variable in record class org.elasticsearch.action.support.IndicesOptions.SelectorOptions
- 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_COPIES_INVALID - Static variable in class org.elasticsearch.cluster.routing.allocation.Explanations.Allocation
- ALL_CORE - Static variable in enum class org.elasticsearch.search.aggregations.support.CoreValuesSourceType
-
List containing all members of the enumeration.
- ALL_DATA_TIERS - Static variable in class org.elasticsearch.cluster.routing.allocation.DataTier
- ALL_NAMES - Static variable in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestParameters.Metric
- ALL_NODES - Static variable in class org.elasticsearch.action.admin.cluster.remote.RemoteClusterNodesAction.Request
- ALL_NODES - Static variable in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- ALL_NODES_FORBIDDEN - Static variable in class org.elasticsearch.cluster.routing.allocation.Explanations.Allocation
- ALL_PATTERN - Static variable in record class org.elasticsearch.repositories.ResolvedRepositories
- ALL_REPOS_HEALTHY - Static variable in class org.elasticsearch.snapshots.RepositoryIntegrityHealthIndicatorService
- allActiveShards(String[]) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- 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
- allMetrics() - Static method in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoMetrics.Metric
- allNodeFeatures() - Method in class org.elasticsearch.cluster.ClusterFeatures
-
The features in all nodes in the cluster.
- allNodeValues() - Method in class org.elasticsearch.common.path.PathTrie
- allocate(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- allocate(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceShardsAllocator
- allocate(RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocator
-
Allocates shards to nodes in the cluster.
- allocate(RoutingAllocation, ActionListener<Void>) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceShardsAllocator
- allocate(RoutingAllocation, ActionListener<Void>) - 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
- allocatedNodes() - Method in class org.elasticsearch.action.search.SearchShardsGroup
-
The list of node ids that shard copies on this group are allocated on.
- 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 Class in org.elasticsearch.persistent
- allocatedProcessors(Settings) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
-
Returns the number of allocated processors.
- 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(ShardRouting, RoutingAllocation, ExistingShardsAllocator.UnassignedAllocationHandler) - Method in interface org.elasticsearch.cluster.routing.allocation.ExistingShardsAllocator
-
Allocate any unassigned shards in the given
RoutingAllocation
for which thisExistingShardsAllocator
is responsible. - allocateUnassigned(ShardRouting, RoutingAllocation, ExistingShardsAllocator.UnassignedAllocationHandler) - Method in class org.elasticsearch.gateway.BaseGatewayShardAllocator
-
Allocate an unassigned shard to nodes (if any) where valid copies of the shard already exist.
- allocateUnassigned(ShardRouting, RoutingAllocation, ExistingShardsAllocator.UnassignedAllocationHandler) - 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() - Constructor for class org.elasticsearch.cluster.routing.allocation.Explanations.Allocation
- ALLOCATION_DELAY_FIELD - Static variable in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- ALLOCATION_DELAYED - Enum constant in enum class 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_EXPLAIN_API - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- ALLOCATION_EXPLAIN_MAX_RETRY - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- ALLOCATION_FAILED - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of a failed allocation of the shard.
- ALLOCATION_NONE_EXPLANATION - Static variable in class org.elasticsearch.persistent.decider.EnableAssignmentDecider
- AllocationActionListener<T> - Class in org.elasticsearch.cluster.routing.allocation.allocator
- AllocationActionListener(ActionListener<T>, ThreadContext) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.AllocationActionListener
- AllocationActionMultiListener<T> - Class in org.elasticsearch.cluster.routing.allocation.allocator
-
This event listener might be needed to delay execution of multiple distinct tasks until followup reroute is complete.
- AllocationActionMultiListener(ThreadContext) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.AllocationActionMultiListener
- 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
-
Combines the decision of multiple
AllocationDecider
implementations into a single allocation decision. - AllocationDeciders(Collection<? extends AllocationDecider>) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- AllocationDecision - Enum Class 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.
- allocationId - Variable in class org.elasticsearch.index.shard.ShardStateMetadata
- allocationId() - Method in record class org.elasticsearch.cluster.routing.allocation.StaleShard
-
Returns the value of the
allocationId
record component. - 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.
- AllocationId(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.AllocationId
- ALLOCATIONS - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestParameters.Metric
- allocationService() - Method in record class org.elasticsearch.node.PluginServiceInstances
-
Returns the value of the
allocationService
record component. - allocationService() - Method in interface org.elasticsearch.plugins.Plugin.PluginServices
-
A service to manage shard allocation in the cluster
- AllocationService - Class in org.elasticsearch.cluster.routing.allocation
-
This service manages the node allocation of a cluster.
- AllocationService(AllocationDeciders, ShardsAllocator, ClusterInfoService, SnapshotsInfoService, ShardRoutingRoleStrategy) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
- AllocationService(AllocationDeciders, GatewayAllocator, ShardsAllocator, ClusterInfoService, SnapshotsInfoService, ShardRoutingRoleStrategy) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
- AllocationService.CommandsResult - Record Class in org.elasticsearch.cluster.routing.allocation
-
this class is used to describe results of applying a set of
AllocationCommand
- AllocationService.RerouteStrategy - Interface in org.elasticsearch.cluster.routing.allocation
- AllocationStatsFeatures - Class in org.elasticsearch.action.admin.cluster.allocation
- AllocationStatsFeatures() - Constructor for class org.elasticsearch.action.admin.cluster.allocation.AllocationStatsFeatures
- AllocationStatsService - Class in org.elasticsearch.cluster.routing.allocation
- AllocationStatsService(ClusterService, ClusterInfoService, ShardsAllocator, WriteLoadForecaster) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationStatsService
- ALLOCATOR_NAME - Static variable in class org.elasticsearch.gateway.GatewayAllocator
- ALLOW_ALL - Static variable in record class org.elasticsearch.script.Metadata.FieldProperty
- ALLOW_CUSTOM_ROUTING - Static variable in class org.elasticsearch.action.datastreams.GetDataStreamAction.Response.DataStreamInfo
- ALLOW_CUSTOM_ROUTING - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- ALLOW_EXPENSIVE_QUERIES - Static variable in class org.elasticsearch.search.SearchService
- ALLOW_NO_INDICES - Static variable in record class org.elasticsearch.action.support.IndicesOptions.WildcardOptions
- ALLOW_NONE - Static variable in class org.elasticsearch.script.ScriptService
- ALLOW_PARTIAL_SEARCH_RESULTS_IN_PIT - Static variable in class org.elasticsearch.TransportVersions
- ALLOW_UNAVAILABLE_TARGETS - Static variable in record class org.elasticsearch.action.support.IndicesOptions.ConcreteTargetOptions
- ALLOW_UNMAPPED - Static variable in class org.elasticsearch.index.IndexSettings
- allowAliasesToMultipleIndices() - Method in record class org.elasticsearch.action.support.IndicesOptions
- allowAliasToMultipleIndices() - Method in record class org.elasticsearch.action.support.IndicesOptions.GatekeeperOptions
-
Returns the value of the
allowAliasToMultipleIndices
record component. - allowAliasToMultipleIndices(boolean) - Method in class org.elasticsearch.action.support.IndicesOptions.GatekeeperOptions.Builder
-
Aliases that resolve to multiple indices are accepted when true, otherwise the resolution will throw an error.
- allowAll() - Static method in interface org.elasticsearch.plugins.internal.RestExtension
-
Returns a rest extension which allows all rest endpoints through.
- allowAutoCreate(Boolean) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.Builder
- allowClosedIndices() - Method in record class org.elasticsearch.action.support.IndicesOptions.GatekeeperOptions
-
Returns the value of the
allowClosedIndices
record component. - allowClosedIndices(boolean) - Method in class org.elasticsearch.action.support.IndicesOptions.GatekeeperOptions.Builder
-
Closed indices are accepted when true, otherwise the resolution will throw an error.
- ALLOWED_CONTENT_FIELD_NAMES - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper
- allowedFields - Variable in class org.elasticsearch.index.query.QueryRewriteContext
- allowedRequestHeaders() - Method in class org.elasticsearch.http.CorsHandler.Config
- allowedRequestMethods() - Method in class org.elasticsearch.http.CorsHandler.Config
- allowEmptyExpressions() - Method in record class org.elasticsearch.action.support.IndicesOptions.WildcardOptions
-
Returns the value of the
allowEmptyExpressions
record component. - allowEmptyExpressions(boolean) - Method in class org.elasticsearch.action.support.IndicesOptions.WildcardOptions.Builder
-
If true, when any of the expressions does not match any indices, we consider the result of this expression empty; if all the expressions are empty then we have a successful but empty response.
- allowExpensiveQueries - Variable in class org.elasticsearch.index.query.QueryRewriteContext
- allowExpensiveQueries() - Method in class org.elasticsearch.index.query.FilteredSearchExecutionContext
- allowExpensiveQueries() - Method in class org.elasticsearch.index.query.QueryRewriteContext
- allowFailureIndices() - Method in record class org.elasticsearch.action.support.IndicesOptions
- allowFailureIndices() - Method in record class org.elasticsearch.action.support.IndicesOptions.GatekeeperOptions
-
Returns the value of the
allowFailureIndices
record component. - allowFailureIndices(boolean) - Method in class org.elasticsearch.action.support.IndicesOptions.GatekeeperOptions.Builder
-
Failure indices are accepted when true, otherwise the resolution will throw an error.
- 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.
- allowMultipleValues(boolean) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- allowNoIndices() - Method in record class org.elasticsearch.action.support.IndicesOptions
- allowPartialSearchResults() - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- allowPartialSearchResults() - Method in class org.elasticsearch.action.search.SearchRequest
- allowPartialSearchResults() - Method in class org.elasticsearch.action.search.SearchShardsRequest
- allowPartialSearchResults() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- allowPartialSearchResults(boolean) - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- 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
- allowSearchIdleOptimization() - Method in class org.elasticsearch.index.engine.Engine
-
Whether search idleness may be allowed to be considered for skipping a scheduled refresh.
- allowsNull(Annotation[]) - Static method in class org.elasticsearch.injection.guice.internal.Nullability
- allowsRemoteIndices() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveClusterActionRequest
- allowsRemoteIndices() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Request
- allowsRemoteIndices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- allowsRemoteIndices() - Method in interface org.elasticsearch.action.IndicesRequest.Replaceable
-
Determines whether the request can contain indices on a remote cluster.
- allowsRemoteIndices() - Method in interface org.elasticsearch.action.IndicesRequest.SingleIndexNoWildcards
- allowsRemoteIndices() - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- allowsRemoteIndices() - Method in class org.elasticsearch.action.search.SearchRequest
- allowsTemplates() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- allowStoredScript - Variable in class org.elasticsearch.script.ScriptContext
-
Determines if the script can be stored as part of the cluster state.
- allowsUnsafeBuffers() - Method in class org.elasticsearch.rest.action.document.RestBulkAction
- allowsUnsafeBuffers() - Method in class org.elasticsearch.rest.action.search.RestSearchAction
- allowsUnsafeBuffers() - Method in class org.elasticsearch.rest.FilterRestHandler
- allowsUnsafeBuffers() - Method in interface org.elasticsearch.rest.RestHandler
-
Indicates if the RestHandler supports working with pooled buffers.
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterAllocationExplainAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterHealthAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterRerouteAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStateAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetFeatureUpgradeStatusAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.admin.cluster.RestPostFeatureUpgradeAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.admin.cluster.RestResetFeatureStateAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesShardStoresAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesStatsAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.admin.indices.RestRecoveryAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.cat.RestAliasAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.cat.RestHealthAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.cat.RestIndicesAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.cat.RestSegmentsAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.action.cat.RestShardsAction
- allowSystemIndexAccessByDefault() - Method in class org.elasticsearch.rest.FilterRestHandler
- allowSystemIndexAccessByDefault() - Method in interface org.elasticsearch.rest.RestHandler
-
Controls whether requests handled by this class are allowed to to access system indices by default.
- allowUnavailableTargets() - Method in record class org.elasticsearch.action.support.IndicesOptions.ConcreteTargetOptions
-
Returns the value of the
allowUnavailableTargets
record component. - allowUnmappedFields - Variable in class org.elasticsearch.index.query.QueryRewriteContext
- allPendingAsyncStatesWritten() - Method in class org.elasticsearch.gateway.GatewayMetaState
- allPendingDanglingIndicesWritten() - Method in class org.elasticsearch.indices.IndicesService
- 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. - 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.IndexRoutingTable
- allShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- 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
- allShardsActive() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- allShardsActive(ShardId, Metadata) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns
true
iff all replicas are active for the given shard routing. - allShardsIncludingRelocationTargets(String[]) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- allShardsIterator() - 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
- allSuccessful(int) - Static method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- allSupportedParameters() - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteSnapshotAction
- allSupportedParameters() - Method in interface org.elasticsearch.rest.RestHandler
-
The set of path and query parameters that could be present on this handler.
- allUrls - Variable in class org.elasticsearch.plugins.PluginBundle
- ALPHA - Static variable in class org.elasticsearch.node.ResponseCollectorService
-
The weight parameter used for all moving averages of parameters.
- ALREADY_BALANCED - Static variable in class org.elasticsearch.cluster.routing.allocation.Explanations.Rebalance
- alsoRefreshState(ClusterState) - Method in record class org.elasticsearch.cluster.coordination.JoinTask
- ALTERNATIVE_NAME - Static variable in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- ALWAYS - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
-
Re-balancing is allowed once a shard replication group is active
- ALWAYS - Enum constant in enum class org.elasticsearch.index.cache.query.TrivialQueryCachingPolicy
- ALWAYS - Enum constant in enum class 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
- ALWAYS_REFRESH_SETTING - Static variable in class org.elasticsearch.monitor.fs.FsService
- alwaysEnforce() - Method in interface org.elasticsearch.bootstrap.BootstrapCheck
- alwaysOne() - Method in class org.elasticsearch.search.aggregations.bucket.DocCountProvider
- alwaysSerialize() - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Always serialize this parameter, no matter its value
- ambiguousTypeConversion(String, Object, TypeLiteral<?>, MatcherAndConverter, MatcherAndConverter) - Method in class org.elasticsearch.injection.guice.internal.Errors
- Analysis - Class in org.elasticsearch.index.analysis
- Analysis() - Constructor for class org.elasticsearch.index.analysis.Analysis
- ANALYSIS - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- analysisMode() - Method in class org.elasticsearch.index.analysis.AnalyzerComponents
- AnalysisMode - Enum Class 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>, StablePluginsRegistry) - 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(AnalysisRegistry) - Method in class org.elasticsearch.indices.IndicesServiceBuilder
- 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
- AnalysisStats - Class in org.elasticsearch.action.admin.cluster.stats
-
Statistics about analysis usage.
- AnalysisStats(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
- 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 class org.elasticsearch.client.internal.IndicesAdminClient
- analyze(AnalyzeAction.Request, ActionListener<AnalyzeAction.Response>) - Method in class org.elasticsearch.client.internal.IndicesAdminClient
- 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.Fields - 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
- AnalyzeIndexDiskUsageRequest - Class in org.elasticsearch.action.admin.indices.diskusage
- AnalyzeIndexDiskUsageRequest(String[], IndicesOptions, boolean) - Constructor for class org.elasticsearch.action.admin.indices.diskusage.AnalyzeIndexDiskUsageRequest
- AnalyzeIndexDiskUsageRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.diskusage.AnalyzeIndexDiskUsageRequest
- AnalyzeIndexDiskUsageResponse - Class in org.elasticsearch.action.admin.indices.diskusage
- analyzer - Variable in class org.elasticsearch.index.search.MatchQueryParser
- 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.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.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 - Enum constant in enum class org.elasticsearch.index.analysis.IndexAnalyzers.AnalyzerType
- ANALYZER - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.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) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
- AnalyzeRequestBuilder(ElasticsearchClient, String, String...) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
- analyzerParam(String, boolean, Function<FieldMapper, NamedAnalyzer>, Supplier<NamedAnalyzer>) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Defines a parameter that takes an analyzer name
- analyzerParam(String, boolean, Function<FieldMapper, NamedAnalyzer>, Supplier<NamedAnalyzer>, IndexVersion) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Defines a parameter that takes an analyzer name
- AnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer> - Interface in org.elasticsearch.index.analysis
- Analyzers(IndexAnalyzers, Function<FieldMapper, NamedAnalyzer>, Function<FieldMapper, Integer>, IndexVersion) - Constructor for class org.elasticsearch.index.mapper.TextParams.Analyzers
- AnalyzerScope - Enum Class 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(FieldPredicate, FieldPredicate) - Constructor for class org.elasticsearch.plugins.FieldPredicate.And
- AND - Enum constant in enum class org.elasticsearch.cluster.node.DiscoveryNodeFilters.OpType
- AND - Enum constant in enum class org.elasticsearch.index.query.Operator
- AND - Enum constant in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- andThen(Executor, ThreadContext, CheckedBiConsumer<ActionListener<U>, T, ? extends Exception>) - Method in class org.elasticsearch.action.support.SubscribableListener
-
Creates and returns a new
SubscribableListener
L
and subscribesnextStep
to this listener such that if this listener is completed successfully with resultR
thennextStep
is invoked with argumentsL
andR
. - andThen(CheckedBiConsumer<ActionListener<U>, T, ? extends Exception>) - Method in class org.elasticsearch.action.support.SubscribableListener
-
Creates and returns a new
SubscribableListener
L
and subscribesnextStep
to this listener such that if this listener is completed successfully with resultR
thennextStep
is invoked with argumentsL
andR
. - andThen(CheckedConsumer<ActionListener<U>, ? extends Exception>) - Method in class org.elasticsearch.action.support.SubscribableListener
-
Creates and returns a new
SubscribableListener
L
and subscribesnextStep
to this listener such that if this listener is completed successfully then the result is discarded andnextStep
is invoked with argumentL
. - andThenAccept(CheckedConsumer<T, Exception>) - Method in class org.elasticsearch.action.support.SubscribableListener
-
Creates and returns a new
SubscribableListener
L
such that if this listener is completed successfully with resultR
thenconsumer
is applied to argumentR
, andL
is completed withnull
whenconsumer
returns. - andThenApply(CheckedFunction<T, U, Exception>) - Method in class org.elasticsearch.action.support.SubscribableListener
-
Creates and returns a new
SubscribableListener
L
such that if this listener is completed successfully with resultR
thenfn
is invoked with argumentR
, andL
is completed with the result of that invocation. - AnnotatedBindingBuilder<T> - Interface in org.elasticsearch.injection.guice.binder
-
See the EDSL examples at
Binder
. - Annotations - Class in org.elasticsearch.injection.guice.internal
-
Annotation utilities.
- Annotations() - Constructor for class org.elasticsearch.injection.guice.internal.Annotations
- ansiEnabled() - Method in record class org.elasticsearch.bootstrap.ConsoleLoader.Console
-
Returns the value of the
ansiEnabled
record component. - ANY - Enum constant in enum class org.elasticsearch.inference.TaskType
- ANY - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- ANY_DESCRIPTION - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
- ANY_ORIGIN - Static variable in class org.elasticsearch.http.CorsHandler
- anyMoveBackToPreviousDay() - Method in class org.elasticsearch.common.LocalTimeOffset
-
Does this transition or any previous transitions move back to the previous day? See
LocalTimeOffset.Lookup.anyMoveBackToPreviousDay()
for rules. - anyMoveBackToPreviousDay() - Method in class org.elasticsearch.common.LocalTimeOffset.Gap
- anyMoveBackToPreviousDay() - Method in class org.elasticsearch.common.LocalTimeOffset.Lookup
-
Do any of the transitions move back to the previous day?
- anyMoveBackToPreviousDay() - Method in class org.elasticsearch.common.LocalTimeOffset.Overlap
- anySet() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- ANYSTRING - Enum constant in enum class org.elasticsearch.index.query.RegexpFlag
-
Enables any string expression:
@
- API - Enum constant in enum class org.elasticsearch.cluster.metadata.Metadata.XContentContext
- API - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- 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
- ApiNotAvailableException - Exception in org.elasticsearch.rest
-
Thrown when an API is not available in the current environment.
- ApiNotAvailableException(String, Object...) - Constructor for exception org.elasticsearch.rest.ApiNotAvailableException
- ApiNotAvailableException(StreamInput) - Constructor for exception org.elasticsearch.rest.ApiNotAvailableException
- APM_TRACE_CONTEXT - Static variable in class org.elasticsearch.tasks.Task
-
Used internally to pass the apm trace context between the nodes
- append(Object) - Method in class org.elasticsearch.script.field.WriteField
-
Appends a value to this path.
- 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.
- append(Iterator<? extends ToXContent>) - Method in class org.elasticsearch.common.xcontent.ChunkedToXContentBuilder
- append(LogEvent) - Method in class org.elasticsearch.common.logging.HeaderWarningAppender
- append(BytesRef) - Method in class org.elasticsearch.common.util.BytesRefArray
- append(ChunkedToXContent) - Method in class org.elasticsearch.common.xcontent.ChunkedToXContentBuilder
- append(BlockLoader.Builder, Object) - Method in class org.elasticsearch.index.mapper.BlockSourceReader
- append(ToXContent) - Method in class org.elasticsearch.common.xcontent.ChunkedToXContentBuilder
- append(T[], T) - Static method in class org.elasticsearch.common.util.ArrayUtils
-
Copy the given array and the added element into a new array of size
array.length + 1
. - APPEND_PREFIX_LENGTH_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.prefix.IpPrefixAggregationBuilder
- appendBoolean(boolean) - Method in interface org.elasticsearch.index.mapper.BlockLoader.BooleanBuilder
-
Appends a boolean to the current entry.
- appendBytesRef(BytesRef) - Method in interface org.elasticsearch.index.mapper.BlockLoader.BytesRefBuilder
-
Appends a BytesRef to the current entry.
- appendDescription(StringBuilder) - Method in record class org.elasticsearch.cluster.coordination.JoinTask.NodeJoinTask
- appendDescriptionWithoutAttributes(StringBuilder) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- appendDouble(double) - Method in interface org.elasticsearch.index.mapper.BlockLoader.DoubleBuilder
-
Appends a double to the current entry.
- appendFieldValue(String, Object) - Method in class org.elasticsearch.ingest.IngestDocument
-
Appends the provided value to the provided path in the document.
- appendFieldValue(String, Object, boolean) - Method in class org.elasticsearch.ingest.IngestDocument
-
Appends the provided value to the provided path in the document.
- appendFieldValue(String, ValueSource, boolean) - Method in class org.elasticsearch.ingest.IngestDocument
-
Appends the provided value to the provided path in the document.
- appendFloat(float) - Method in interface org.elasticsearch.index.mapper.BlockLoader.FloatBuilder
-
Appends a float to the current entry.
- appendIfPresent(ChunkedToXContent) - Method in class org.elasticsearch.common.xcontent.ChunkedToXContentBuilder
- appendIfPresent(ToXContent) - Method in class org.elasticsearch.common.xcontent.ChunkedToXContentBuilder
- appendInt(int) - Method in interface org.elasticsearch.index.mapper.BlockLoader.IntBuilder
-
Appends an int to the current entry.
- appendLong(long) - Method in interface org.elasticsearch.index.mapper.BlockLoader.LongBuilder
-
Appends a long to the current entry.
- appendNull() - Method in interface org.elasticsearch.index.mapper.BlockLoader.Builder
-
Insert a null value.
- appendOrd(int) - Method in interface org.elasticsearch.index.mapper.BlockLoader.SingletonOrdinalsBuilder
-
Appends an ordinal to the builder.
- appendPrefixLength() - Method in class org.elasticsearch.search.aggregations.bucket.prefix.InternalIpPrefix.Bucket
- appendPrefixLength(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.prefix.IpPrefixAggregationBuilder
-
Set the appendPrefixLength on this builder, and return the builder so that calls can be chained.
- appendRoleAbbreviations(StringBuilder, String) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- 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.TaskExecutionTimeTrackingEsThreadPoolExecutor
- appendToCopy(Collection<E>, E) - Static method in class org.elasticsearch.common.util.CollectionUtils
-
Creates a copy of the given collection with the given element appended.
- appendToCopyNoNullElements(Collection<E>, E) - Static method in class org.elasticsearch.common.util.CollectionUtils
-
Same as
CollectionUtils.appendToCopy(Collection, Object)
but faster by assuming that all elements in the collection and the given element are non-null. - appendToCopyNoNullElements(Collection<E>, E...) - Static method in class org.elasticsearch.common.util.CollectionUtils
-
Same as
CollectionUtils.appendToCopyNoNullElements(Collection, Object)
but for multiple elements to append. - applicationMayFail() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- apply(double) - Method in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- apply(int) - Method in interface org.elasticsearch.common.CheckedIntFunction
- 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(M) - Method in class org.elasticsearch.cluster.DiffableUtils.MapDiff
- apply(ClusterState, AllocationService.RerouteStrategy) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceShardsAllocator.DesiredBalanceReconcilerAction
- apply(DiffableStringMap) - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap.DiffableStringMapDiff
- apply(Metadata.Custom) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.IndexGraveyardDiff
- apply(Metadata.Custom) - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata.NodeShutdownMetadataDiff
- apply(Metadata.Custom) - Method in class org.elasticsearch.snapshots.RegisteredPolicySnapshots.RegisteredSnapshotsDiff
- apply(Metadata.Custom) - Method in class org.elasticsearch.upgrades.FeatureMigrationResults.ResultsDiff
- apply(Orientation, Geometry) - Static method in class org.elasticsearch.common.geo.GeometryNormalizer
-
Transforms the provided
Geometry
into a lucene friendly format. - apply(Settings, Settings) - Method in interface org.elasticsearch.common.settings.AbstractScopedSettings.SettingUpdater
-
Updates this updaters value if it has changed.
- apply(DeleteByQueryRequest) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequestBuilder
- apply(UpdateByQueryRequest) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequestBuilder
- apply(ValuesSourceConfig, double, String, boolean, String, boolean, MissingOrder, SortOrder) - Method in interface org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder.HistogramCompositeSupplier
- apply(ValuesSourceConfig, int, GeoBoundingBox, String, boolean, String, boolean, MissingOrder, SortOrder) - Method in interface org.elasticsearch.search.aggregations.bucket.composite.GeoTileGridValuesSourceBuilder.GeoTileCompositeSuppier
- apply(ValuesSourceConfig, String, boolean, String, boolean, MissingOrder, SortOrder) - Method in interface org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder.TermsCompositeSupplier
- apply(ValuesSourceConfig, Rounding, String, boolean, String, boolean, MissingOrder, SortOrder) - Method in interface org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder.DateHistogramCompositeSupplier
- 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(Task, String, Request, ActionListener<Response>, ActionFilterChain<Request, Response>) - Method in interface org.elasticsearch.action.support.MappedActionFilter
-
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.MappedActionFilters
- apply(Request) - Method in class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
- apply(Request) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequestBuilder
- apply(Request) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
- apply(Request) - Method in class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequestBuilder
- 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) - Method in class org.elasticsearch.cluster.SimpleDiffable.CompleteDiff
- apply(T) - Method in interface org.elasticsearch.monitor.jvm.HotThreads.SleepFunction
- 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
- applyAliasActions(ClusterState, Iterable<AliasAction>) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexAliasesService
-
Handles the cluster state transition to a version that reflects the provided
AliasAction
s. - 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.ResizeSourceIndexSettingsUpdater
- applyChanges(Metadata, RoutingTable, TransportVersion) - 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.indices.TimestampFieldMapperService
- 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. - applyCreateIndexRequest(ClusterState, CreateIndexClusterStateUpdateRequest, boolean, BiConsumer<Metadata.Builder, IndexMetadata>, ActionListener<Void>) - Method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
-
Handles the cluster state transition to a version that reflects the
CreateIndexClusterStateUpdateRequest
. - applyCreateIndexRequest(ClusterState, CreateIndexClusterStateUpdateRequest, boolean, ActionListener<Void>) - Method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
- applyDeleteOperationOnPrimary(long, String, VersionType, long, long) - Method in class org.elasticsearch.index.shard.IndexShard
- applyDeleteOperationOnReplica(long, long, long, String) - Method in class org.elasticsearch.index.shard.IndexShard
- applyFailedShards(List<FailedShard>, RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.ExistingShardsAllocator
-
Called when the given shards have failed, so that implementations can invalidate caches and clean up any in-flight activity for those shards.
- applyFailedShards(List<FailedShard>, RoutingAllocation) - Method in class org.elasticsearch.gateway.GatewayAllocator
- applyFailedShards(ClusterState, List<FailedShard>, List<StaleShard>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Applies the failed shards.
- applyFailureStoreSettings(Settings, Settings.Builder) - Static method in class org.elasticsearch.cluster.metadata.DataStreamFailureStoreDefinition
-
Modifies an existing index's settings so that it can be added to a data stream's failure store.
- applyFilters(BytesReference, XContentType) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- applyHardSizeLimit(Settings, String) - Static 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, long, boolean, SourceToParse) - Method in class org.elasticsearch.index.shard.IndexShard
- applyMinimumShouldMatch(BooleanQuery, String) - Static method in class org.elasticsearch.common.lucene.search.Queries
- applyScriptContext(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.AbstractScriptFieldType
- 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(List<ShardRouting>, RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.ExistingShardsAllocator
-
Called when the given shards have started, so that implementations can invalidate caches and clean up any in-flight activity for those shards.
- applyStartedShards(List<ShardRouting>, RoutingAllocation) - Method in class org.elasticsearch.gateway.GatewayAllocator
- applyStartedShards(ClusterState, List<ShardRouting>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Applies the started shards.
- applyTranslogOperation(Translog.Operation, Engine.Operation.Origin) - Method in class org.elasticsearch.index.shard.IndexShard
- approximateCardinality() - Method in class org.elasticsearch.lucene.util.CombinedBitSet
- approximateCardinality() - Method in class org.elasticsearch.lucene.util.MatchAllBitSet
- ARC - Enum constant in enum class 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
- ARCHIVE_INDICES - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- 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.
- are(int) - Static method in class org.elasticsearch.health.node.HealthIndicatorDisplayValues
-
Provides the correct form (singular or plural) of the verb to be depending on the given count.
- areAllAvailable() - Method in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService.ShardAllocationCounts
- 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. - areConditionsMet(Map<String, Boolean>) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConditions
-
Given the results of evaluating each individual condition, determine whether the rollover request should proceed -- that is, whether the conditions are met.
- areConditionsMet(Map<String, Boolean>) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Given the results of evaluating each individual condition, determine whether the rollover request should proceed -- that is, whether the conditions are met.
- areDefined() - Method in class org.elasticsearch.cluster.metadata.DataStreamGlobalRetentionSettings
- areFileSettingsApplied(ClusterState) - Method in class org.elasticsearch.readiness.ReadinessService
- areIntegrityAssertionsEnabled() - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
- areTimingsEmpty() - Method in class org.elasticsearch.script.TimeSeries
- areValuesSourcesEmpty() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSource
- argAndField(String, Object) - Method in class org.elasticsearch.common.logging.ESLogMessage
- array() - Method in class org.elasticsearch.common.bytes.BytesArray
- array() - Method in interface org.elasticsearch.common.bytes.BytesReference
- array() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- array() - Method in interface org.elasticsearch.common.util.ByteArray
-
Get backing byte array analogous to
ByteBuffer.array()
. - array() - Method in class org.elasticsearch.common.util.ReleasableByteArray
- array(String, String[]) - Method in class org.elasticsearch.common.xcontent.ChunkedToXContentBuilder
- array(String, Iterator<? extends ToXContent>) - Method in class org.elasticsearch.common.xcontent.ChunkedToXContentBuilder
-
Creates an array named
name
, with the contents set by appending together the contents ofitems
- array(String, Iterator<T>, BiConsumer<ChunkedToXContentBuilder, ? super T>) - Method in class org.elasticsearch.common.xcontent.ChunkedToXContentBuilder
-
Creates an array named
name
, with the contents set by callingcreate
on each item returned byitems
- array(String, Iterator<T>, Function<? super T, ToXContent>) - Method in class org.elasticsearch.common.xcontent.ChunkedToXContentBuilder
-
Creates an array named
name
, with the contents set by appending together the return values ofcreate
called on each item returned byitems
- array(Iterator<? extends ToXContent>) - Method in class org.elasticsearch.common.xcontent.ChunkedToXContentBuilder
-
Creates an array with the contents set by appending together the contents of
items
- array(Iterator<T>, BiConsumer<ChunkedToXContentBuilder, ? super T>) - Method in class org.elasticsearch.common.xcontent.ChunkedToXContentBuilder
-
Creates an array, with the contents set by calling
create
on each item returned byitems
- array(Iterator<T>, Function<? super T, ToXContent>) - Method in class org.elasticsearch.common.xcontent.ChunkedToXContentBuilder
-
Creates an array, with the contents set by appending together the return values of
create
called on each item returned byitems
- arrayAsArrayList(E...) - Static method in class org.elasticsearch.common.util.CollectionUtils
- arrayOf(Type) - Static method in class org.elasticsearch.injection.guice.util.Types
-
Returns an array type whose elements are all instances of
componentType
. - arrayOffset() - Method in class org.elasticsearch.common.bytes.BytesArray
- arrayOffset() - Method in interface org.elasticsearch.common.bytes.BytesReference
- arrayOffset() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- ARRAYS - Enum constant in enum class org.elasticsearch.index.mapper.Mapper.SourceKeepMode
- ArraySourceValueFetcher - Class in org.elasticsearch.index.mapper
-
An implementation of
ValueFetcher
that knows how to extract values from the document source. - ArraySourceValueFetcher(String, SearchExecutionContext) - Constructor for class org.elasticsearch.index.mapper.ArraySourceValueFetcher
- ArraySourceValueFetcher(String, SearchExecutionContext, Object) - Constructor for class org.elasticsearch.index.mapper.ArraySourceValueFetcher
- ArraySourceValueFetcher(Set<String>, Object) - Constructor for class org.elasticsearch.index.mapper.ArraySourceValueFetcher
- arraySupplier() - Method in class org.elasticsearch.action.synonyms.AbstractSynonymsPagedResultAction.AbstractPagedResultResponse
- arraySupplier() - Method in class org.elasticsearch.action.synonyms.GetSynonymsAction.Response
- arraySupplier() - Method in class org.elasticsearch.action.synonyms.GetSynonymsSetsAction.Response
- 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
- asByteVector() - Method in record class org.elasticsearch.search.vectors.VectorData
- ASC - Enum constant in enum class org.elasticsearch.search.sort.SortOrder
-
Ascending order.
- asClone(String, long, long) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Creates a new instance has a different name and zero incremental file counts but is identical to this instance in terms of the files it references.
- asCollector() - Method in class org.elasticsearch.search.aggregations.BucketCollector
-
Return this BucketCollector wrapped as a
Collector
- 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
- asDouble(double) - Method in class org.elasticsearch.script.field.HalfFloatDocValuesField
-
Returns the 0th index value as a
double
if it exists, otherwisedefaultValue
. - asDouble(int, double) - Method in class org.elasticsearch.script.field.HalfFloatDocValuesField
-
Returns the value at
index
as adouble
if it exists, otherwisedefaultValue
. - asDoubles() - Method in class org.elasticsearch.script.field.HalfFloatDocValuesField
-
Converts all the values to
Double
and returns them as aList
. - asEagerSingleton() - Method in interface org.elasticsearch.injection.guice.binder.ScopedBindingBuilder
-
Instructs the
Injector
to eagerly initialize this singleton-scoped binding upon creation. - asEagerSingleton() - Method in class org.elasticsearch.injection.guice.internal.AbstractBindingBuilder
- asFloat() - Method in class org.elasticsearch.common.unit.Fuzziness
- asFloatVector() - Method in record class org.elasticsearch.search.vectors.VectorData
- asFull() - Method in interface org.elasticsearch.http.HttpBody
-
Assumes that HTTP body is a full content.
- 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.common.util.PlainIterator
- asList() - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
The list of
InternalAggregation
s. - asMap() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- asMap() - Method in record class org.elasticsearch.cluster.metadata.LifecycleExecutionState
-
Converts this object to an immutable map representation for use with
IndexMetadata.Builder.putCustom(String, Map)
. - asMap() - Method in interface org.elasticsearch.inference.InferenceResults
-
Convert to a map
- asMap() - Method in interface org.elasticsearch.inference.InferenceServiceResults
-
Convert the result to a map to aid with test assertions
- asMap() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
- asMap(String) - Method in interface org.elasticsearch.inference.InferenceResults
-
Convert to a map placing the inference result in
outputField
- asMappedFieldTypes() - Method in class org.elasticsearch.index.mapper.CompositeRuntimeField
- asMappedFieldTypes() - Method in class org.elasticsearch.index.mapper.LeafRuntimeField
- asMappedFieldTypes() - Method in interface org.elasticsearch.index.mapper.RuntimeField
-
Exposes the
MappedFieldType
s backing this runtime field, used to execute queries, run aggs etc. - asQuery() - Method in enum class org.elasticsearch.index.query.ZeroTermsQueryOption
- asRemoteStats() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequest
- 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. - asSerialized(Writeable.Reader<T>, NamedWriteableRegistry) - Method in class org.elasticsearch.common.io.stream.DelayableWriteable
-
Returns a DelayableWriteable that stores its contents in serialized form.
- asSerialized(Writeable.Reader<T>, NamedWriteableRegistry) - Method in class org.elasticsearch.common.io.stream.DelayableWriteable.Serialized
- assertAllListenersResolved() - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Assert that no in-memory state for any running snapshot-create or -delete operation exists in this instance.
- assertAtLeastOnce(ActionListener<Response>) - Static method in interface org.elasticsearch.action.ActionListener
- assertCancellableTaskConsistency() - Method in class org.elasticsearch.tasks.TaskManager
- 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
- assertCurrentThreadPool(String...) - Static method in class org.elasticsearch.threadpool.ThreadPool
- assertDefaultThreadContext(ThreadContext) - Static method in enum class org.elasticsearch.transport.Transports
- 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)
- assertInSystemContext(ThreadPool) - Static method in class org.elasticsearch.threadpool.ThreadPool
- assertInvariant() - Method in class org.elasticsearch.common.io.stream.CountingFilterInputStream
- assertMasterUpdateOrTestThread() - 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
- assertNotApplyingClusterState() - Static method in class org.elasticsearch.cluster.service.ClusterApplierService
- 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 class org.elasticsearch.transport.Transports
- assertOnce(ActionListener<Response>) - Static method in interface org.elasticsearch.action.ActionListener
- assertOnSuccess() - Method in class org.elasticsearch.indices.recovery.MultiChunkTransfer
- assertPrimaryCanOptimizeAddDocument(Engine.Index) - Method in class org.elasticsearch.index.engine.InternalEngine
- assertPrimaryIncomingSequenceNumber(Engine.Operation.Origin, long) - Method in class org.elasticsearch.index.engine.InternalEngine
- assertPurposeConsistency(OperationPurpose, String) - Static method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Verify that the
OperationPurpose
is (somewhat) suitable for the name of the blob to which it applies:OperationPurpose.SNAPSHOT_DATA
is not used for blobs that look like metadata blobs.OperationPurpose.SNAPSHOT_METADATA
is not used for blobs that look like data blobs. - 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. - assertSnapshotMetaThread() - Static method in interface org.elasticsearch.repositories.Repository
- assertTransportThread() - Static method in enum class org.elasticsearch.transport.Transports
- assertZValue(boolean, double) - Method in class org.elasticsearch.common.geo.GenericPointParser
- assertZValue(boolean, double) - Static method in class org.elasticsearch.common.geo.GeoPoint
- assigned() - Method in record class org.elasticsearch.cluster.routing.allocation.allocator.ShardAssignment
- 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 Class in org.elasticsearch.persistent.decider
- assignments() - Method in record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalance
-
Returns the value of the
assignments
record component. - assignRescoreDocIds(RescoreDocIds) - Method in class org.elasticsearch.search.internal.SearchContext
- AssociatedIndexDescriptor - Class in org.elasticsearch.indices
-
Describes an index that is part of the state of a
SystemIndices.Feature
, but is not protected or managed by the system. - AssociatedIndexDescriptor(String, String) - Constructor for class org.elasticsearch.indices.AssociatedIndexDescriptor
-
Create a descriptor for an index associated with a feature
- associateIndexWithNewTranslog(String) - Method in class org.elasticsearch.index.store.Store
-
Force bakes the given translog generation as recovery information in the lucene index.
- asStream() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- asStream() - Method in interface org.elasticsearch.http.HttpBody
-
Assumes that HTTP body is a lazy-stream.
- asString() - Method in class org.elasticsearch.common.unit.Fuzziness
- asString(int, String) - Method in class org.elasticsearch.script.field.IpDocValuesField
- asString(String) - Method in class org.elasticsearch.script.field.IpDocValuesField
- asStrings() - Method in class org.elasticsearch.script.field.IpDocValuesField
- asTuple() - Method in class org.elasticsearch.script.ScriptCache.CompilationRate
- asUnpooled() - Method in class org.elasticsearch.search.SearchHit
- asUnpooled() - Method in class org.elasticsearch.search.SearchHits
- ASYNC - Enum constant in enum class org.elasticsearch.index.translog.Translog.Durability
-
Async durability - translogs are synced based on a time interval.
- ASYNC_FEATURE - Static variable in class org.elasticsearch.action.admin.cluster.stats.CCSUsageTelemetry
- 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
- asyncEnsureGlobalCheckpointSynced(long, Consumer<Exception>) - Method in class org.elasticsearch.index.engine.Engine
-
Ensures that the global checkpoint has been persisted to the underlying storage.
- asyncEnsureGlobalCheckpointSynced(long, Consumer<Exception>) - Method in class org.elasticsearch.index.engine.InternalEngine
- asyncEnsureGlobalCheckpointSynced(long, Consumer<Exception>) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- asyncEnsureTranslogSynced(Translog.Location, Consumer<Exception>) - Method in class org.elasticsearch.index.engine.Engine
-
Ensures that the location has been written to the underlying storage.
- asyncEnsureTranslogSynced(Translog.Location, Consumer<Exception>) - Method in class org.elasticsearch.index.engine.InternalEngine
- asyncEnsureTranslogSynced(Translog.Location, Consumer<Exception>) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- 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, String, int) - Constructor for class org.elasticsearch.gateway.AsyncShardFetch
- AsyncShardFetch.FetchResult<T extends BaseNodeResponse> - Class in org.elasticsearch.gateway
-
The result of a fetch operation.
- 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
- asyncShardOperation(RetentionLeaseActions.RemoveRequest, ShardId, ActionListener<ActionResponse.Empty>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.TransportRemoveAction
- 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
- AtomicRegisterPreVoteCollector - Class in org.elasticsearch.cluster.coordination.stateless
- AtomicRegisterPreVoteCollector(StoreHeartbeatService, Runnable) - Constructor for class org.elasticsearch.cluster.coordination.stateless.AtomicRegisterPreVoteCollector
- AttemptAfterSuccess - Enum constant in enum class org.elasticsearch.action.support.replication.TransportReplicationAction.SyncGlobalCheckpointAfterOperation
-
Attempt to sync the global checkpoint to the replica(s) after success
- 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() - Method in record class org.elasticsearch.telemetry.metric.DoubleWithAttributes
-
Returns the value of the
attributes
record component. - attributes() - Method in record class org.elasticsearch.telemetry.metric.LongWithAttributes
-
Returns the value of the
attributes
record component. - 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.action.admin.indices.analyze.AnalyzeAction.Fields
- augmentExplanationsWithStoreInfo(List<NodeAllocationResult>, Map<String, NodeAllocationResult>) - Static method in class org.elasticsearch.gateway.ReplicaShardAllocator
-
Takes the store info for nodes that have a shard store and adds them to the node decisions, leaving the node explanations untouched for those nodes that do not have any store information.
- AUTO - Enum constant in enum class org.elasticsearch.index.mapper.ObjectMapper.Subobjects
- AUTO - Static variable in class org.elasticsearch.common.unit.Fuzziness
- AUTO_COMPLETE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- AUTO_CREATE_INDEX_SETTING - Static variable in class org.elasticsearch.action.support.AutoCreateIndex
- AUTO_SHARDING_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- AUTO_SHARDING_METRIC_NAMES - Static variable in class org.elasticsearch.action.admin.indices.rollover.MetadataRolloverService
- 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
- AutoCreateAction - Class in org.elasticsearch.action.admin.indices.create
-
Api that auto creates an index or data stream that originate from requests that write into an index that doesn't yet exist.
- AutoCreateAction.TransportAction - Class in org.elasticsearch.action.admin.indices.create
- 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, SystemIndices) - Constructor for class org.elasticsearch.action.support.AutoCreateIndex
- AutoExpandReplicas - Record Class in org.elasticsearch.cluster.metadata
-
This class acts as a functional wrapper around the
index.auto_expand_replicas
setting. - AutoExpandReplicas(int, int, boolean) - Constructor for record class org.elasticsearch.cluster.metadata.AutoExpandReplicas
-
Creates an instance of a
AutoExpandReplicas
record class. - autoGenerateId() - Method in class org.elasticsearch.action.index.IndexRequest
-
Set the
#id()
to an automatically generated one and make this request compatible with the append-only optimization. - autoGenerateSynonymsPhraseQuery - Variable in class org.elasticsearch.index.search.MatchQueryParser
- autoGenerateSynonymsPhraseQuery() - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
-
Whether phrase queries should be automatically generated for multi terms synonyms.
- 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.CombinedFieldsQueryBuilder
- 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
- autoGenerateTimeBasedId() - Method in class org.elasticsearch.action.index.IndexRequest
- AutoIdHandler() - Constructor for class org.elasticsearch.rest.action.document.RestIndexAction.AutoIdHandler
- AUTOMATIC - Enum constant in enum class org.elasticsearch.action.admin.indices.rollover.Condition.Type
- AUTOMATION_DISABLED_IMPACT_ID - Static variable in class org.elasticsearch.cluster.coordination.StableMasterHealthIndicatorService
- AutomatonQueries - Class in org.elasticsearch.common.lucene.search
-
Helper functions for creating various forms of
AutomatonQuery
- AutomatonQueries() - Constructor for class org.elasticsearch.common.lucene.search.AutomatonQueries
- AutoscalingMissedIndicesUpdateException - Exception in org.elasticsearch.indices
- AutoscalingMissedIndicesUpdateException(String) - Constructor for exception org.elasticsearch.indices.AutoscalingMissedIndicesUpdateException
- AutoscalingMissedIndicesUpdateException(StreamInput) - Constructor for exception org.elasticsearch.indices.AutoscalingMissedIndicesUpdateException
- AutoShardingResult - Record Class in org.elasticsearch.action.datastreams.autosharding
-
Represents an auto sharding recommendation.
- AutoShardingResult(AutoShardingType, int, int, TimeValue, Double) - Constructor for record class org.elasticsearch.action.datastreams.autosharding.AutoShardingResult
-
Creates an instance of a
AutoShardingResult
record class. - AutoShardingType - Enum Class in org.elasticsearch.action.datastreams.autosharding
-
Represents the type of recommendation the auto sharding service provided.
- autoUpdate() - Method in record class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
-
Returns the value of the
autoUpdate
record component. - available() - Method in class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- 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 interface org.elasticsearch.index.codec.CodecProvider
-
Returns all registered available codec names.
- 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}/indices folder
- availableIndexFolders(Predicate<String>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns folder names in ${data.paths}/indices folder that don't match the given predicate.
- availableIndexFoldersForPath(NodeEnvironment.DataPath) - Method in class org.elasticsearch.env.NodeEnvironment
-
Return all directory names in the indices directory for the given node path.
- availableIndexFoldersForPath(NodeEnvironment.DataPath, Predicate<String>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Return directory names in the 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
- average() - Method in record class org.elasticsearch.cluster.routing.allocation.allocator.ClusterBalanceStats.MetricStats
-
Returns the value of the
average
record component. - AVERAGE_SIZE_FIELD - Static variable in record class org.elasticsearch.cluster.metadata.IndexMetadataStats
- averageShardSize() - Method in record class org.elasticsearch.cluster.metadata.IndexMetadataStats
-
Returns the value of the
averageShardSize
record component. - AverageShardSize(long, int) - Constructor for record class org.elasticsearch.cluster.metadata.IndexMetadataStats.AverageShardSize
-
Creates an instance of a
AverageShardSize
record class. - avg() - Method in class org.elasticsearch.action.admin.cluster.stats.LongMetric.LongMetricValue
- avg(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Avg
aggregation with the given name. - Avg - Enum constant in enum class 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 - Enum constant in enum class org.elasticsearch.common.lucene.search.function.CombineFunction
- AVG - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- AVG - Enum constant in enum class org.elasticsearch.search.MultiValueMode
-
Pick the average of all the values.
- AVG - Enum constant in enum class 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
- avgDiskUsageInBytesPerNode() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
- 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
- avgWriteLoadPerNode() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
- AVL_TREE - Enum constant in enum class org.elasticsearch.search.aggregations.metrics.TDigestState.Type
- awaitClose(long, TimeUnit) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Closes the processor.
- awaitClose(long, TimeUnit) - Method in class org.elasticsearch.action.bulk.BulkProcessor2
-
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.
- awaitIdle() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- awaitIdle() - Method in class org.elasticsearch.repositories.FilterRepository
- awaitIdle() - Method in class org.elasticsearch.repositories.InvalidRepository
- awaitIdle() - Method in interface org.elasticsearch.repositories.Repository
-
Block until all in-flight operations for this repository have completed.
- awaitIdle() - Method in class org.elasticsearch.repositories.UnknownTypeRepository
- AWAITING_INFO - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
Waiting on getting shard data from all nodes before making a decision about where to allocate the shard.
- AWAITING_INFO - Static variable in class org.elasticsearch.cluster.routing.allocation.Explanations.Allocation
- AWAITING_INFO - Static variable in class org.elasticsearch.cluster.routing.allocation.Explanations.Rebalance
- 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
- B_QUERY - Static variable in class org.elasticsearch.index.codec.vectors.BQSpaceUtils
- BACKGROUND_IS_SUPERSET - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
- backgroundFilter(QueryBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- backgroundFilter(QueryBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- backgroundIsSuperset - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
- backgroundIsSuperset - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.NXYBuilder
- backgroundSync(ShardId, String, long, RetentionLeases) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncer
- backgroundSync(ShardId, String, long, RetentionLeases) - Method in interface org.elasticsearch.index.seqno.RetentionLeaseSyncer.BackgroundSyncAction
- BACKING_INDEX_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- backingIndicesBuilder(List<Index>) - Static method in class org.elasticsearch.cluster.metadata.DataStream.DataStreamIndices
- 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
- BACKUP - Enum constant in enum class org.elasticsearch.health.ImpactArea
- BACKUP_DISABLED_IMPACT_ID - Static variable in class org.elasticsearch.cluster.coordination.StableMasterHealthIndicatorService
- BACKWARDS_COMPATIBLE_ONLY - Enum constant in enum class org.elasticsearch.indices.SystemIndices.SystemIndexAccessLevel
-
This value exists because there was a desire for "net-new" system indices to opt in to the post-8.0 behavior of having access blocked in most cases, but this caused problems with certain APIs (see issue #74687), so this access level was added as a workaround.
- BAD_GATEWAY - Enum constant in enum class 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_KEY - Static variable in class org.elasticsearch.script.Metadata
- BAD_REQUEST - Enum constant in enum class 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
allocates and balances shards on the cluster nodes usingBalancedShardsAllocator.WeightFunction
. - BalancedShardsAllocator() - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- BalancedShardsAllocator(ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- BalancedShardsAllocator(ClusterSettings, WriteLoadForecaster) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- BalancedShardsAllocator(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- BalancedShardsAllocator.Balancer - Class in org.elasticsearch.cluster.routing.allocation.allocator
- BAN_PARENT_ACTION_NAME - Static variable in class org.elasticsearch.tasks.TaskCancellationService
- base64TimeBasedKOrderedUUID() - Static method in class org.elasticsearch.common.UUIDs
- base64TimeBasedUUID() - Static method in class org.elasticsearch.common.UUIDs
- 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
- BaseBroadcastResponse - Class in org.elasticsearch.action.support.broadcast
-
Base class for all broadcast operation based responses.
- BaseBroadcastResponse(int, int, int, List<DefaultShardOperationFailedException>) - Constructor for class org.elasticsearch.action.support.broadcast.BaseBroadcastResponse
- BaseBroadcastResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.broadcast.BaseBroadcastResponse
- 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
- BaseGeometry(ScriptDocValues.Supplier<V>) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.BaseGeometry
- BaseKeywordDocValuesField - Class in org.elasticsearch.script.field
- BaseKeywordDocValuesField(SortedBinaryDocValues, String) - Constructor for class org.elasticsearch.script.field.BaseKeywordDocValuesField
- 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
-
Read a response from the given stream, with no
DiscoveryNode
object re-use. - BaseNodeResponse(StreamInput, DiscoveryNode) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodeResponse
-
Read a response from the given stream, re-using the given
DiscoveryNode
object if non-null. - 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
- 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
- BaseNodesXContentResponse<TNodeResponse extends BaseNodeResponse> - Class in org.elasticsearch.action.support.nodes
- BaseNodesXContentResponse(ClusterName, List<TNodeResponse>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodesXContentResponse
- basePath() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Returns base path of the repository Public for testing.
- 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.RequestBodyChunkConsumer - Interface in org.elasticsearch.rest
- 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_DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_DATE - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- BASIC_DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- BASIC_DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- BASIC_ORDINAL_DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_ORDINAL_DATE - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- BASIC_ORDINAL_DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_ORDINAL_DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- BASIC_ORDINAL_DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_ORDINAL_DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- BASIC_T_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_T_TIME - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- BASIC_T_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_T_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- BASIC_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_TIME - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- BASIC_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- BASIC_WEEK_DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_WEEK_DATE - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- BASIC_WEEK_DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_WEEK_DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- BASIC_WEEK_DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_WEEK_DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- BasicHit(String, String, long) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- 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
- BatchedRerouteService - Class in org.elasticsearch.cluster.routing
-
A
BatchedRerouteService
is aRerouteService
that batches together reroute requests to avoid unnecessary extra reroutes. - BatchedRerouteService(ClusterService, BatchedRerouteService.RerouteAction) - Constructor for class org.elasticsearch.cluster.routing.BatchedRerouteService
- BatchedRerouteService.RerouteAction - Interface in org.elasticsearch.cluster.routing
- BATCHES_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- BatchExecutionContext(ClusterState, List<? extends ClusterStateTaskExecutor.TaskContext<T>>, Supplier<Releasable>) - Constructor for record class org.elasticsearch.cluster.ClusterStateTaskExecutor.BatchExecutionContext
-
Creates an instance of a
BatchExecutionContext
record class. - BatchSummary - Class in org.elasticsearch.cluster.service
- BatchSummary(Supplier<String>) - Constructor for class org.elasticsearch.cluster.service.BatchSummary
- BBQ_FORMAT - Static variable in class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper
- bcFromTriangle(byte) - Static method in interface org.elasticsearch.lucene.spatial.TriangleTreeVisitor
- bdd - Variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- becomeMasterAndTrimConflictingNodes(ClusterState, List<? extends ClusterStateTaskExecutor.TaskContext<JoinTask>>, long) - Method in class org.elasticsearch.cluster.coordination.NodeJoinExecutor
- before(T) - Method in interface org.elasticsearch.common.VersionId
- beforeAllocation(RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.ExistingShardsAllocator
-
Called before starting a round of allocation, allowing the allocator to invalidate some caches if appropriate.
- beforeAllocation(RoutingAllocation) - Method in class org.elasticsearch.gateway.GatewayAllocator
- beforeBulk(long, BulkRequest) - Method in interface org.elasticsearch.action.bulk.BulkProcessor.Listener
-
Callback before the bulk is executed.
- beforeBulk(long, BulkRequest) - Method in interface org.elasticsearch.action.bulk.BulkProcessor2.Listener
-
Callback before the bulk is executed.
- beforeClose() - Method in class org.elasticsearch.common.component.LifecycleListener
- beforeClose() - Method in class org.elasticsearch.index.store.Store
- beforeCommit(long, long, ActionListener<Void>) - Method in class org.elasticsearch.cluster.coordination.ElectionStrategy
- beforeExecute(Thread, Runnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- beforeExecute(Thread, Runnable) - Method in class org.elasticsearch.common.util.concurrent.TaskExecutionTimeTrackingEsThreadPoolExecutor
- beforeGap(long, LocalTimeOffset.Gap) - Method in interface org.elasticsearch.common.LocalTimeOffset.Strategy
-
Handle a local time that happened before the start of a gap.
- 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.
- beforeIndexFoldersDeleted(Index, IndexSettings, Path[]) - Method in class org.elasticsearch.indices.store.CompositeIndexFoldersDeletionListener
- beforeIndexFoldersDeleted(Index, IndexSettings, Path[]) - Method in interface org.elasticsearch.plugins.IndexStorePlugin.IndexFoldersDeletionListener
-
Invoked before the folders of an index are deleted from disk.
- 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(ShardRouting, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index shard gets created, before obtaining the shard lock.
- beforeIndexShardCreated(ShardRouting, Settings) - Method in class org.elasticsearch.search.SearchService
- 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.
- beforeIndexShardRecovery(IndexShard, IndexSettings, ActionListener<Void>) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called before the index shard starts to recover.
- beforeLoad(Terms) - Method in interface org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData.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.
- beforeMerge(OnGoingMerge) - Method in class org.elasticsearch.index.engine.ElasticsearchConcurrentMergeScheduler
-
A callback allowing for custom logic before an actual merge starts.
- beforeOverlap(long, LocalTimeOffset.Overlap) - Method in interface org.elasticsearch.common.LocalTimeOffset.Strategy
-
Handle a local time that happened before the start of an overlap.
- beforeRefresh() - Method in class org.elasticsearch.index.engine.CompletionStatsCache
- beforeRefresh() - Method in class org.elasticsearch.index.engine.LiveVersionMap
- 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.
- beforeShardFoldersDeleted(ShardId, IndexSettings, Path[]) - Method in class org.elasticsearch.indices.store.CompositeIndexFoldersDeletionListener
- beforeShardFoldersDeleted(ShardId, IndexSettings, Path[]) - Method in interface org.elasticsearch.plugins.IndexStorePlugin.IndexFoldersDeletionListener
-
Invoked before the folders of a shard are deleted from disk.
- beforeStart() - Method in class org.elasticsearch.common.component.LifecycleListener
- beforeStop() - Method in class org.elasticsearch.common.component.LifecycleListener
- beginPositionEntry() - Method in interface org.elasticsearch.index.mapper.BlockLoader.Builder
-
Start a multivalued field.
- BEST_COMPRESSION - Enum constant in enum class org.elasticsearch.index.codec.zstd.Zstd814StoredFieldsFormat.Mode
- BEST_COMPRESSION_CODEC - Static variable in class org.elasticsearch.index.codec.CodecService
- BEST_FIELDS - Enum constant in enum class 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
- BEST_SPEED - Enum constant in enum class org.elasticsearch.index.codec.zstd.Zstd814StoredFieldsFormat.Mode
- 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(Query, IndexSearcher, 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. - betterThan(long, long) - Method in class org.elasticsearch.search.sort.BucketedSort
-
true
if the entry at indexlhs
is "better" than the entry atrhs
. - betterThan(long, long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForDoubles
- betterThan(long, long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForFloats
- betterThan(long, long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForLongs
- between(T, T) - Method in interface org.elasticsearch.common.VersionId
- BFI - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- BFM - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- BG_COUNT - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- BIG_ENDIAN_LONG - Static variable in enum class org.elasticsearch.common.util.ByteUtils
- 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.repositories.blobstore.BlobStoreRepository
- bigArrays - Variable in class org.elasticsearch.search.sort.BucketedSort
- bigArrays() - Method in class org.elasticsearch.search.aggregations.AggregationReduceContext
- bigArrays() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Utilities for sharing large primitive arrays and tracking their usage.
- bigArrays() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Utility to share and track large arrays.
- bigArrays() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- bigArrays(BigArrays) - Method in class org.elasticsearch.indices.IndicesServiceBuilder
- 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
- BigArrays.DoubleBinarySearcher - Class in org.elasticsearch.common.util
- bigArraysRamBytesUsed() - Method in class org.elasticsearch.common.util.BytesRefArray
-
Memory used by the
BigArrays
portion of thisBytesRefArray
. - BIGINTEGER_2_64_MINUS_ONE - Static variable in interface org.elasticsearch.search.DocValueFormat
- bigQuery() - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- bigQuery() - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- BINARIZED_VECTOR_COMPONENT - Static variable in class org.elasticsearch.index.codec.vectors.ES816BinaryQuantizedVectorsFormat
- BinarizedByteVectorValues - Class in org.elasticsearch.index.codec.vectors
-
Copied from Lucene, replace with Lucene's implementation sometime after Lucene 10
- BinarizedByteVectorValues() - Constructor for class org.elasticsearch.index.codec.vectors.BinarizedByteVectorValues
- BinarizedRandomVectorScorer(ES816BinaryFlatVectorsScorer.BinaryQueryVector, RandomAccessBinarizedByteVectorValues, VectorSimilarityFunction) - Constructor for class org.elasticsearch.index.codec.vectors.ES816BinaryFlatVectorsScorer.BinarizedRandomVectorScorer
- BINARY - Enum constant in enum class org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- BINARY - Static variable in interface org.elasticsearch.search.DocValueFormat
- BinaryDenseVector - Class in org.elasticsearch.script.field.vectors
- BinaryDenseVector(float[], BytesRef, int, IndexVersion) - Constructor for class org.elasticsearch.script.field.vectors.BinaryDenseVector
- BinaryDenseVectorDocValuesField - Class in org.elasticsearch.script.field.vectors
- BinaryDenseVectorDocValuesField(BinaryDocValues, String, DenseVectorFieldMapper.ElementType, int, IndexVersion) - Constructor for class org.elasticsearch.script.field.vectors.BinaryDenseVectorDocValuesField
- BinaryDocValuesField - Class in org.elasticsearch.script.field
- BinaryDocValuesField(SortedBinaryDocValues, String) - Constructor for class org.elasticsearch.script.field.BinaryDocValuesField
- BinaryDocValuesRangeQuery - Class in org.elasticsearch.lucene.queries
- BinaryDocValuesRangeQuery(String, BinaryDocValuesRangeQuery.QueryType, RangeType.LengthType, BytesRef, BytesRef, Object, Object) - Constructor for class org.elasticsearch.lucene.queries.BinaryDocValuesRangeQuery
- BinaryDocValuesRangeQuery.QueryType - Enum Class in org.elasticsearch.lucene.queries
- BinaryDocValuesSyntheticFieldLoader - Class in org.elasticsearch.index.mapper
- BinaryDocValuesSyntheticFieldLoader(String) - Constructor for class org.elasticsearch.index.mapper.BinaryDocValuesSyntheticFieldLoader
- BinaryDVLeafFieldData - Class in org.elasticsearch.index.fielddata.plain
-
LeafFieldData
impl on top of Lucene's binary doc values. - BinaryDVLeafFieldData(LeafReader, String) - Constructor for class org.elasticsearch.index.fielddata.plain.BinaryDVLeafFieldData
- binaryField(FieldInfo, byte[]) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- binaryField(FieldInfo, byte[]) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- binaryField(FieldInfo, byte[]) - Method in class org.elasticsearch.search.internal.FilterFieldNamesProvidingStoredFieldsVisitor
- binaryField(FieldInfo, byte[]) - Method in class org.elasticsearch.search.internal.FilterStoredFieldVisitor
- BinaryFieldMapper - Class in org.elasticsearch.index.mapper
- BinaryFieldMapper(String, MappedFieldType, FieldMapper.BuilderParams, BinaryFieldMapper.Builder) - Constructor for class org.elasticsearch.index.mapper.BinaryFieldMapper
- BinaryFieldMapper.BinaryFieldType - Class in org.elasticsearch.index.mapper
- BinaryFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- BinaryFieldMapper.CustomBinaryDocValuesField - Class in org.elasticsearch.index.mapper
- BinaryFieldType(String) - Constructor for class org.elasticsearch.index.mapper.BinaryFieldMapper.BinaryFieldType
- BinaryIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- BinaryIndexFieldData(String, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData
- BinaryIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
- binaryQuantizer - Variable in class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues
- BinaryQuantizer - Class in org.elasticsearch.index.codec.vectors
-
Copied from Lucene, replace with Lucene's implementation sometime after Lucene 10 Quantized that quantizes raw vector values to binary.
- BinaryQuantizer(int, int, VectorSimilarityFunction) - Constructor for class org.elasticsearch.index.codec.vectors.BinaryQuantizer
- BinaryQuantizer.QueryAndIndexResults - Record Class in org.elasticsearch.index.codec.vectors
-
Results of quantizing a vector for both querying and indexing
- BinaryQuantizer.QueryFactors - Record Class in org.elasticsearch.index.codec.vectors
-
Factors for quantizing query
- BinaryQueryVector(byte[], BinaryQuantizer.QueryFactors) - Constructor for record class org.elasticsearch.index.codec.vectors.ES816BinaryFlatVectorsScorer.BinaryQueryVector
-
Creates an instance of a
BinaryQueryVector
record class. - 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, DocValueFormat, List<BinaryRangeAggregator.Range>, boolean, AggregationContext, Aggregator, CardinalityUpperBound, 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, List<BinaryRangeAggregator.Range>, boolean, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>, IpRangeAggregatorSupplier) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregatorFactory
- BinaryScriptFieldData - Class in org.elasticsearch.index.fielddata
- BinaryScriptFieldData(String) - Constructor for class org.elasticsearch.index.fielddata.BinaryScriptFieldData
- BinaryScriptFieldData.BinaryScriptLeafFieldData - Class in org.elasticsearch.index.fielddata
- BinaryScriptLeafFieldData() - Constructor for class org.elasticsearch.index.fielddata.BinaryScriptFieldData.BinaryScriptLeafFieldData
- 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. - BinarySearcher - Class in org.elasticsearch.common.util
-
Performs binary search on an arbitrary data structure.
- BinarySearcher() - Constructor for class org.elasticsearch.common.util.BinarySearcher
- BinaryShapeDocValuesField - Class in org.elasticsearch.lucene.spatial
- BinaryShapeDocValuesField(String, CoordinateEncoder) - Constructor for class org.elasticsearch.lucene.spatial.BinaryShapeDocValuesField
- binaryValue - Variable in class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues
- binaryValue() - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.CustomBinaryDocValuesField
- binaryValue() - Method in class org.elasticsearch.lucene.spatial.BinaryShapeDocValuesField
- bind(Class<T>) - Method in class org.elasticsearch.injection.guice.AbstractModule
- bind(Class<T>) - Method in interface org.elasticsearch.injection.guice.Binder
-
See the EDSL examples at
Binder
. - 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 interface org.elasticsearch.injection.guice.Binder
-
See the EDSL examples at
Binder
. - bind(TypeLiteral<T>) - Method in class org.elasticsearch.injection.guice.AbstractModule
- bind(TypeLiteral<T>) - Method in interface org.elasticsearch.injection.guice.Binder
-
See the EDSL examples at
Binder
. - BIND_HOST - Static variable in class org.elasticsearch.transport.RemoteClusterPortSettings
- BIND_HOST - Static variable in class org.elasticsearch.transport.TransportSettings
- BIND_HOST_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- binder - Variable in class org.elasticsearch.injection.guice.internal.AbstractBindingBuilder
- binder() - Method in class org.elasticsearch.injection.guice.AbstractModule
-
Gets direct access to the underlying
Binder
. - Binder - Interface in org.elasticsearch.injection.guice
-
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.injection.guice
-
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.injection.guice.internal.AbstractBindingBuilder
- bindingAlreadySet(Key<?>, Object) - Method in class org.elasticsearch.injection.guice.internal.Errors
- BindingAnnotation - Annotation Interface in org.elasticsearch.injection.guice
-
Annotates annotations which are used for binding.
- BindingBuilder<T> - Class in org.elasticsearch.injection.guice.internal
-
Bind a non-constant key.
- BindingBuilder(Binder, List<Element>, Object, Key<T>) - Constructor for class org.elasticsearch.injection.guice.internal.BindingBuilder
- BindingImpl<T> - Class in org.elasticsearch.injection.guice.internal
- BindingImpl(Object, Key<T>, Scoping) - Constructor for class org.elasticsearch.injection.guice.internal.BindingImpl
- BindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping) - Constructor for class org.elasticsearch.injection.guice.internal.BindingImpl
- BindingTargetVisitor<T,
V> - Interface in org.elasticsearch.injection.guice.spi -
Visits each of the strategies used to find an instance to satisfy an injection.
- bindingToProvider() - Method in class org.elasticsearch.injection.guice.internal.Errors
- bindServer() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- bindServer(TcpTransport.ProfileSettings) - Method in class org.elasticsearch.transport.TcpTransport
- bindToInstance(Class<T>, T) - Method in class org.elasticsearch.injection.guice.ModulesBuilder
- 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
- BIT - Enum constant in enum class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.ElementType
- BIT_VECTORS - Static variable in class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper
- BitArray - Class in org.elasticsearch.common.util
- BitArray(long, BigArrays) - Constructor for class org.elasticsearch.common.util.BitArray
-
Create the BitArray.
- BitArray(BigArrays, boolean, StreamInput) - Constructor for class org.elasticsearch.common.util.BitArray
-
Create a
BitArray
usingBigArrays
with bytes are written byBitArray.writeTo(org.elasticsearch.common.io.stream.StreamOutput)
- BitBinaryDenseVector - Class in org.elasticsearch.script.field.vectors
- BitBinaryDenseVector(byte[], BytesRef, int) - Constructor for class org.elasticsearch.script.field.vectors.BitBinaryDenseVector
- BitBinaryDenseVectorDocValuesField - Class in org.elasticsearch.script.field.vectors
- BitBinaryDenseVectorDocValuesField(BinaryDocValues, String, DenseVectorFieldMapper.ElementType, int) - Constructor for class org.elasticsearch.script.field.vectors.BitBinaryDenseVectorDocValuesField
- BitDotProduct(ScoreScript, DenseVectorDocValuesField, byte[]) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.BitDotProduct
- BitDotProduct(ScoreScript, DenseVectorDocValuesField, List<Number>) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.BitDotProduct
- BitKnnDenseVector - Class in org.elasticsearch.script.field.vectors
- BitKnnDenseVector(byte[]) - Constructor for class org.elasticsearch.script.field.vectors.BitKnnDenseVector
- BitKnnDenseVectorDocValuesField - Class in org.elasticsearch.script.field.vectors
- BitKnnDenseVectorDocValuesField(ByteVectorValues, String, int) - Constructor for class org.elasticsearch.script.field.vectors.BitKnnDenseVectorDocValuesField
- BitMultiDenseVector - Class in org.elasticsearch.script.field.vectors
- BitMultiDenseVector(Iterator<byte[]>, BytesRef, int, int) - Constructor for class org.elasticsearch.script.field.vectors.BitMultiDenseVector
- BitMultiDenseVectorDocValuesField - Class in org.elasticsearch.script.field.vectors
- BitMultiDenseVectorDocValuesField(BinaryDocValues, BinaryDocValues, String, DenseVectorFieldMapper.ElementType, int) - Constructor for class org.elasticsearch.script.field.vectors.BitMultiDenseVectorDocValuesField
- bitsetFilter(Query) - Method in class org.elasticsearch.index.query.FilteredSearchExecutionContext
- bitsetFilter(Query) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- bitsetFilterCache() - Method in class org.elasticsearch.index.cache.IndexCache
-
Return the
BitsetFilterCache
for this index. - bitsetFilterCache() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Get the filter cache.
- bitsetFilterCache() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- bitsetFilterCache() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- bitsetFilterCache() - Method in class org.elasticsearch.search.internal.SearchContext
- bitsetFilterCache() - Method in class org.elasticsearch.search.rank.RankSearchContext
- 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
- bitsetProducer() - Method in class org.elasticsearch.index.mapper.NestedObjectMapper
- bitSetProducer(Query) - Method in class org.elasticsearch.index.mapper.MappingParserContext
- BitSets - Class in org.elasticsearch.lucene.util
- blend(TermStates[], int, IndexReader) - Method in class org.elasticsearch.lucene.queries.BlendedTermQuery
- BlendedTermQuery - Class in org.elasticsearch.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.elasticsearch.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.
- BlobContainerUtils - Class in org.elasticsearch.common.blobstore.support
- blobExists(OperationPurpose, String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Tests whether a blob with the given blob name exists in the container.
- blobExists(OperationPurpose, String) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- blobExists(OperationPurpose, String) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- BlobMetadata - Record Class in org.elasticsearch.common.blobstore.support
-
Blob name and size.
- BlobMetadata(String, long) - Constructor for record class org.elasticsearch.common.blobstore.support.BlobMetadata
-
Creates an instance of a
BlobMetadata
record class. - 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.
- 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, 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
- BlobStoreRepository - Class in org.elasticsearch.repositories.blobstore
-
BlobStore - based implementation of Snapshot Repository
- BlobStoreRepository(RepositoryMetadata, NamedXContentRegistry, ClusterService, BigArrays, RecoverySettings, BlobPath) - Constructor for class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Constructs new BlobStoreRepository
- block() - Method in record class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockClusterStateUpdateRequest
-
Returns the value of the
block
record component. - BLOCK - Enum constant in enum class org.elasticsearch.monitor.jvm.HotThreads.ReportType
- BLOCK_SIZE - Static variable in class org.elasticsearch.index.codec.ForUtil
- BLOCK_SIZE - Static variable in class org.elasticsearch.index.codec.postings.ES812PostingsFormat
-
Size of blocks.
- BlockDocValuesReader - Class in org.elasticsearch.index.mapper
-
A reader that supports reading doc-values from a Lucene segment in Block fashion.
- BlockDocValuesReader() - Constructor for class org.elasticsearch.index.mapper.BlockDocValuesReader
- BlockDocValuesReader.BooleansBlockLoader - Class in org.elasticsearch.index.mapper
- BlockDocValuesReader.BytesRefsFromBinaryBlockLoader - Class in org.elasticsearch.index.mapper
- BlockDocValuesReader.BytesRefsFromOrdsBlockLoader - Class in org.elasticsearch.index.mapper
- BlockDocValuesReader.DocValuesBlockLoader - Class in org.elasticsearch.index.mapper
- BlockDocValuesReader.DoublesBlockLoader - Class in org.elasticsearch.index.mapper
- BlockDocValuesReader.IntsBlockLoader - Class in org.elasticsearch.index.mapper
- BlockDocValuesReader.LongsBlockLoader - Class in org.elasticsearch.index.mapper
- BlockDocValuesReader.ToDouble - Interface in org.elasticsearch.index.mapper
-
Convert from the stored
long
into thedouble
to load. - blockingAllowed() - Method in class org.elasticsearch.action.support.PlainActionFuture
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.AbstractPointFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.BooleanScriptFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.DateScriptFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.DoubleScriptFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.IdFieldMapper.AbstractIdFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper.IgnoredFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper.LegacyIgnoredFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.IpScriptFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns a loader for ESQL or
null
if the field doesn't support ESQL. - blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- blockLoader(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- BlockLoader - Interface in org.elasticsearch.index.mapper
-
Interface for loading data in a block shape.
- BlockLoader.AllReader - Interface in org.elasticsearch.index.mapper
- BlockLoader.Block - Interface in org.elasticsearch.index.mapper
-
Marker interface for block results.
- BlockLoader.BlockFactory - Interface in org.elasticsearch.index.mapper
-
Builds block "builders" for loading data into blocks for the compute engine.
- BlockLoader.BooleanBuilder - Interface in org.elasticsearch.index.mapper
- BlockLoader.Builder - Interface in org.elasticsearch.index.mapper
-
A builder for typed values.
- BlockLoader.BytesRefBuilder - Interface in org.elasticsearch.index.mapper
- BlockLoader.ColumnAtATimeReader - Interface in org.elasticsearch.index.mapper
- BlockLoader.ConstantNullsReader - Class in org.elasticsearch.index.mapper
-
Implementation of
BlockLoader.ColumnAtATimeReader
andBlockLoader.RowStrideReader
that always loadsnull
. - BlockLoader.Delegating - Class in org.elasticsearch.index.mapper
- BlockLoader.Docs - Interface in org.elasticsearch.index.mapper
-
A list of documents to load.
- BlockLoader.DoubleBuilder - Interface in org.elasticsearch.index.mapper
- BlockLoader.FloatBuilder - Interface in org.elasticsearch.index.mapper
- BlockLoader.IntBuilder - Interface in org.elasticsearch.index.mapper
- BlockLoader.LongBuilder - Interface in org.elasticsearch.index.mapper
- BlockLoader.Reader - Interface in org.elasticsearch.index.mapper
- BlockLoader.RowStrideReader - Interface in org.elasticsearch.index.mapper
- BlockLoader.SingletonOrdinalsBuilder - Interface in org.elasticsearch.index.mapper
- BlockLoader.StoredFields - Interface in org.elasticsearch.index.mapper
- blockLoaderFromSource(MappedFieldType.BlockLoaderContext) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
- BlockLoaderStoredFieldsFromLeafLoader - Class in org.elasticsearch.index.mapper
- BlockLoaderStoredFieldsFromLeafLoader(LeafStoredFieldLoader, SourceLoader.Leaf) - Constructor for class org.elasticsearch.index.mapper.BlockLoaderStoredFieldsFromLeafLoader
- 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 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 - Enum constant in enum class 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. - BlockSourceReader - Class in org.elasticsearch.index.mapper
-
Loads values from
_source
. - BlockSourceReader.BooleansBlockLoader - Class in org.elasticsearch.index.mapper
-
Load
boolean
s from_source
. - BlockSourceReader.BytesRefsBlockLoader - Class in org.elasticsearch.index.mapper
-
Load
BytesRef
s from_source
. - BlockSourceReader.DoublesBlockLoader - Class in org.elasticsearch.index.mapper
-
Load
double
s from_source
. - BlockSourceReader.GeometriesBlockLoader - Class in org.elasticsearch.index.mapper
- BlockSourceReader.IntsBlockLoader - Class in org.elasticsearch.index.mapper
-
Load
int
s from_source
. - BlockSourceReader.LeafIteratorLookup - Interface in org.elasticsearch.index.mapper
- BlockSourceReader.LongsBlockLoader - Class in org.elasticsearch.index.mapper
-
Load
long
s from_source
. - BlockStoredFieldsReader - Class in org.elasticsearch.index.mapper
-
Loads values from
IndexReader.storedFields()
. - BlockStoredFieldsReader() - Constructor for class org.elasticsearch.index.mapper.BlockStoredFieldsReader
- BlockStoredFieldsReader.BytesFromBytesRefsBlockLoader - Class in org.elasticsearch.index.mapper
-
Load
BytesRef
blocks from storedBytesRef
s. - BlockStoredFieldsReader.BytesFromStringsBlockLoader - Class in org.elasticsearch.index.mapper
-
Load
BytesRef
blocks from storedString
s. - BlockStoredFieldsReader.IdBlockLoader - Class in org.elasticsearch.index.mapper
-
Load
BytesRef
blocks from storedString
s. - BLOOM_FILTER_ID_FIELD_ENABLED_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
This index setting is intentionally undocumented and should be used as an escape hatch to disable BloomFilter of the _id field of non-data-stream indices, which is enabled by default.
- body() - Method in interface org.elasticsearch.http.HttpRequest
- BOOL_PREFIX - Enum constant in enum class org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Uses the sum of the matching boolean fields to score the query
- BOOLEAN - Enum constant in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- BOOLEAN - Enum constant in enum class org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- BOOLEAN - Enum constant in enum class org.elasticsearch.index.search.MatchQueryParser.Type
-
The text is analyzed and terms are added to a boolean query.
- BOOLEAN - Enum constant in enum class org.elasticsearch.inference.configuration.SettingsConfigurationFieldType
- BOOLEAN - Enum constant in enum class org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- BOOLEAN - Enum constant in enum class org.elasticsearch.search.aggregations.support.ValueType
-
Deprecated.
- BOOLEAN - Static variable in interface org.elasticsearch.search.DocValueFormat
- BOOLEAN_PREFIX - Enum constant in enum class org.elasticsearch.index.search.MatchQueryParser.Type
-
The text is analyzed, terms are added to a boolean query with the last term acting as a prefix.
- BooleanDocValuesField - Class in org.elasticsearch.script.field
- BooleanDocValuesField(SortedNumericDocValues, String) - Constructor for class org.elasticsearch.script.field.BooleanDocValuesField
- BooleanFieldMapper - Class in org.elasticsearch.index.mapper
-
A field mapper for boolean fields.
- BooleanFieldMapper(String, MappedFieldType, FieldMapper.BuilderParams, boolean, BooleanFieldMapper.Builder) - 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.Values - Class in org.elasticsearch.index.mapper
- BooleanFieldScript - Class in org.elasticsearch.script
- BooleanFieldScript(String, Map<String, Object>, SearchLookup, OnScriptError, LeafReaderContext) - Constructor for class org.elasticsearch.script.BooleanFieldScript
- BooleanFieldScript.Emit - Class in org.elasticsearch.script
- BooleanFieldScript.Factory - Interface in org.elasticsearch.script
- BooleanFieldScript.LeafFactory - Interface in org.elasticsearch.script
- BooleanFieldType(String) - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- BooleanFieldType(String, boolean) - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- BooleanFieldType(String, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- BooleanFieldType(String, boolean, boolean, boolean, Boolean, FieldValues<Boolean>, Map<String, String>, boolean) - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- booleans(int) - Method in interface org.elasticsearch.index.mapper.BlockLoader.BlockFactory
-
Build a builder to load booleans without any loading constraints.
- Booleans(ScriptDocValues.Supplier<Boolean>) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- BooleansBlockLoader(String) - Constructor for class org.elasticsearch.index.mapper.BlockDocValuesReader.BooleansBlockLoader
- BooleansBlockLoader(ValueFetcher, BlockSourceReader.LeafIteratorLookup) - Constructor for class org.elasticsearch.index.mapper.BlockSourceReader.BooleansBlockLoader
- BooleanScriptBlockDocValuesReader - Class in org.elasticsearch.index.mapper
-
BlockDocValuesReader
implementation forboolean
scripts. - BooleanScriptDocValues - Class in org.elasticsearch.index.fielddata
- BooleanScriptFieldData - Class in org.elasticsearch.index.fielddata
- BooleanScriptFieldData.BooleanScriptLeafFieldData - Class in org.elasticsearch.index.fielddata
- BooleanScriptFieldData.Builder - Class in org.elasticsearch.index.fielddata
- BooleanScriptFieldExistsQuery - Class in org.elasticsearch.search.runtime
- BooleanScriptFieldExistsQuery(Script, BooleanFieldScript.LeafFactory, String) - Constructor for class org.elasticsearch.search.runtime.BooleanScriptFieldExistsQuery
- BooleanScriptFieldTermQuery - Class in org.elasticsearch.search.runtime
- BooleanScriptFieldTermQuery(Script, BooleanFieldScript.LeafFactory, String, boolean) - Constructor for class org.elasticsearch.search.runtime.BooleanScriptFieldTermQuery
- BooleanScriptFieldType - Class in org.elasticsearch.index.mapper
- booleansFromDocValues(int) - Method in interface org.elasticsearch.index.mapper.BlockLoader.BlockFactory
-
Build a builder to load booleans as loaded from doc values.
- boolParam(String, boolean, Function<FieldMapper, Boolean>, boolean) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Defines a parameter that takes the values
true
orfalse
- boolParam(String, boolean, Function<FieldMapper, Boolean>, Supplier<Boolean>) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- 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, boolean, Setting.Validator<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() - 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() - Method in record class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
-
Returns the value of the
boost
record component. - boost() - Method in class org.elasticsearch.search.vectors.KnnSearchBuilder
- 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(float) - Method in class org.elasticsearch.search.vectors.KnnSearchBuilder
-
Set a boost to apply to the kNN search scores.
- boost(float) - Method in class org.elasticsearch.search.vectors.KnnSearchBuilder.Builder
- BOOST_FIELD - Static variable in class org.elasticsearch.index.query.AbstractQueryBuilder
- BOOST_FIELD - Static variable in class org.elasticsearch.search.vectors.KnnSearchBuilder
- BOOST_MODE_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- boostAndQueryNameToXContent(XContentBuilder) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Add
boost
andquery_name
to the builder. - 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.
- bootstrap(Path, CheckedSupplier<SecureString, Exception>) - Static method in class org.elasticsearch.common.settings.KeyStoreWrapper
- bootstrap(IndexShard, Store) - Static method in class org.elasticsearch.index.shard.StoreRecovery
- BOOTSTRAP_CHECK_ALL_PERMISSION - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_CLIENT_JVM - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_DISCOVERY_CONFIGURATION - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_EARLY_ACCESS - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_ENCRYPT_SENSITIVE_DATA - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_FILE_DESCRIPTOR - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_HEAP_SIZE - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_MAX_FILE_SIZE - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_MAX_NUMBER_THREADS - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_MAX_SIZE_VIRTUAL_MEMORY - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_MAXIMUM_MAP_COUNT - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_MEMORY_LOCK - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_ONERROR_AND_ONOUTOFMEMORYERROR - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_PKI_REALM - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_ROLE_MAPPINGS - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_SECURITY_MINIMAL_SETUP - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_SYSTEM_CALL_FILTER - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_TLS - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_TOKEN_SSL - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECK_USE_SERIAL_COLLECTOR - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BOOTSTRAP_CHECKS - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- BootstrapCheck - Interface in org.elasticsearch.bootstrap
-
Encapsulates a bootstrap check.
- BootstrapCheck.BootstrapCheckResult - Record Class in org.elasticsearch.bootstrap
-
Encapsulate the result of a bootstrap check.
- BootstrapCheckResult(String) - Constructor for record class org.elasticsearch.bootstrap.BootstrapCheck.BootstrapCheckResult
-
Creates an instance of a
BootstrapCheckResult
record class. - BootstrapContext - Record Class in org.elasticsearch.bootstrap
-
Context that is passed to every bootstrap check to make decisions on.
- BootstrapContext(Environment, Metadata) - Constructor for record class org.elasticsearch.bootstrap.BootstrapContext
-
Creates an instance of a
BootstrapContext
record class. - 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
- BootstrapUtil - Class in org.elasticsearch.bootstrap
-
Utilities for use during bootstrap.
- bottom - Variable in class org.elasticsearch.common.geo.BoundingBox.BoundsParser
- bottom - Variable in class org.elasticsearch.lucene.spatial.Extent
- bottom - Variable in class org.elasticsearch.search.aggregations.metrics.InternalBounds
- bottom() - Method in class org.elasticsearch.common.geo.BoundingBox
- BOTTOM_LEFT - Enum constant in enum class org.elasticsearch.common.geo.GeoUtils.EffectivePoint
- BOTTOM_RIGHT - Enum constant in enum class org.elasticsearch.common.geo.GeoUtils.EffectivePoint
- BOTTOM_RIGHT_FIELD - Static variable in class org.elasticsearch.common.geo.BoundingBox
- bottomRight - Variable in class org.elasticsearch.common.geo.BoundingBox
- bottomRight() - Method in class org.elasticsearch.common.geo.BoundingBox
- bottomRight() - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- bottomRight() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Returns the bottom right corner of the bounding box.
- bottomRight() - Method in class org.elasticsearch.search.aggregations.metrics.InternalBounds
- bottomRight() - Method in interface org.elasticsearch.search.aggregations.metrics.SpatialBounds
-
Get the bottom-right location of the bounding box.
- boundAddress() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- boundAddress() - Method in interface org.elasticsearch.http.HttpServerTransport
- boundAddress() - Method in class org.elasticsearch.readiness.ReadinessService
-
Returns the current bound address for the readiness service.
- 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.SearchHighlightContext.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.SearchHighlightContext.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.SearchHighlightContext.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.SearchHighlightContext.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.elasticsearch.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. - boundedCellMultiValues(MultiGeoPointValues, GeoBoundingBox) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource
-
Generate a bounded iterator of grid-cells for multi-value case.
- boundedCellMultiValues(MultiGeoPointValues, GeoBoundingBox) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashCellIdSource
- boundedCellMultiValues(MultiGeoPointValues, GeoBoundingBox) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileCellIdSource
- boundedCellSingleValue(GeoPointValues, GeoBoundingBox) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource
-
Generate a bounded iterator of grid-cells for singleton case.
- boundedCellSingleValue(GeoPointValues, GeoBoundingBox) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashCellIdSource
- boundedCellSingleValue(GeoPointValues, GeoBoundingBox) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileCellIdSource
- boundingBox - Variable in class org.elasticsearch.script.field.PointDocValuesField
- BoundingBox<T extends SpatialPoint> - Class in org.elasticsearch.common.geo
-
A class representing a Bounding-Box for use by Geo and Cartesian queries and aggregations that deal with extents/rectangles representing rectangular areas of interest.
- BoundingBox(T, T) - Constructor for class org.elasticsearch.common.geo.BoundingBox
- BoundingBox.BoundsParser<T extends BoundingBox<? extends SpatialPoint>> - Class in org.elasticsearch.common.geo
- boundRemoteAccessAddress() - Method in class org.elasticsearch.transport.TransportService
- boundRemoteIngressAddress() - Method in class org.elasticsearch.transport.TcpTransport
- boundRemoteIngressAddress() - Method in interface org.elasticsearch.transport.Transport
-
The address the Remote Access port is bound on, or
null
if it is not bound. - BOUNDS_FIELD - Static variable in class org.elasticsearch.common.geo.BoundingBox
- BoundsParser(XContentParser) - Constructor for class org.elasticsearch.common.geo.BoundingBox.BoundsParser
- 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
- box(double, double, double, double) - Method in class org.elasticsearch.common.geo.SimpleFeatureFactory
-
Returns a
byte[]
containing the mvt representation of the provided rectangle - BQSpaceUtils - Class in org.elasticsearch.index.codec.vectors
-
Utility class for quantization calculations
- BQSpaceUtils() - Constructor for class org.elasticsearch.index.codec.vectors.BQSpaceUtils
- BQVectorUtils - Class in org.elasticsearch.index.codec.vectors
-
Utility class for vector quantization calculations
- BQVectorUtils() - Constructor for class org.elasticsearch.index.codec.vectors.BQVectorUtils
- BREADTH_FIRST - Enum constant in enum class 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 - Variable in class org.elasticsearch.search.aggregations.metrics.MemoryTrackingTDigestArrays.MemoryTrackingTDigestByteArray
- breaker() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
The circuit breaker used to account for aggs.
- breaker() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- BREAKER - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestParameters.Metric
- 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 BaseBroadcastResponse, 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(String[], IndicesOptions, TimeValue) - 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
- 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(StreamInput) - 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
- BroadcastUnpromotableRequest - Class in org.elasticsearch.action.support.broadcast.unpromotable
-
A request that is broadcast to the unpromotable assigned replicas of a primary.
- BroadcastUnpromotableRequest(IndexShardRoutingTable) - Constructor for class org.elasticsearch.action.support.broadcast.unpromotable.BroadcastUnpromotableRequest
- BroadcastUnpromotableRequest(IndexShardRoutingTable, boolean) - Constructor for class org.elasticsearch.action.support.broadcast.unpromotable.BroadcastUnpromotableRequest
- BroadcastUnpromotableRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.broadcast.unpromotable.BroadcastUnpromotableRequest
- Bucket(double, long, boolean, DocValueFormat, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- Bucket(double, InternalVariableWidthHistogram.Bucket.BucketBounds, long, DocValueFormat, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- Bucket(long, long, boolean, DocValueFormat, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- Bucket(long, long, long, long, long, InternalAggregations, DocValueFormat, double) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms.Bucket
- Bucket(long, long, long, long, InternalAggregations, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.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, 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, DocValueFormat, double) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.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, long, long, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, long, long, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms.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.prefix.InternalIpPrefix.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
- Bucket(DocValueFormat, BytesRef, boolean, boolean, int, boolean, long, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.prefix.InternalIpPrefix.Bucket
- BUCKET_COUNT - Static variable in class org.elasticsearch.common.network.HandlingTimeTracker
- BucketAggregationList(List<B>) - Constructor for class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation.BucketAggregationList
- 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
- BucketBounds(double, double) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket.BucketBounds
- BucketBounds(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket.BucketBounds
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
A rough count of the number of buckets that
Aggregator
s built by this builder will contain per owning parent bucket. - bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.countedterms.CountedTermsAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.prefix.IpPrefixAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.random.RandomSamplerAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.LeafOnly
- bucketCollector() - Method in record class org.elasticsearch.search.aggregations.BucketCollector.BucketCollectorWrapper
-
Returns the value of the
bucketCollector
record component. - 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
- BucketCollector.BucketCollectorWrapper - Record Class in org.elasticsearch.search.aggregations
- BucketCollectorWrapper(BucketCollector) - Constructor for record class org.elasticsearch.search.aggregations.BucketCollector.BucketCollectorWrapper
-
Creates an instance of a
BucketCollectorWrapper
record class. - bucketComparator(String, SortOrder) - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Builds a comparator that compares two buckets aggregated by this Aggregator.
- bucketComparator(String, SortOrder) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
- bucketComparator(String, SortOrder) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- bucketComparator(String, SortOrder) - Method in class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.MultiValue
- bucketComparator(String, SortOrder) - Method in class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.SingleValue
- bucketComparator(String, SortOrder) - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- bucketComparator(Aggregator, SortOrder) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
- bucketCountThresholds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- bucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- bucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.terms.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
- BucketCountThresholds(TermsAggregator.ConstantBucketCountThresholds) - 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)
- BucketedSort - Class in org.elasticsearch.search.sort
-
Type specialized sort implementations designed for use in aggregations.
- BucketedSort(BigArrays, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Constructor for class org.elasticsearch.search.sort.BucketedSort
- BucketedSort.ExtraData - Interface in org.elasticsearch.search.sort
-
Callbacks for storing extra data along with competitive sorts.
- BucketedSort.ExtraData.Loader - Interface in org.elasticsearch.search.sort
- BucketedSort.ForDoubles - Class in org.elasticsearch.search.sort
-
Superclass for implementations of BucketedSort for
double
keys. - BucketedSort.ForDoubles.Leaf - Class in org.elasticsearch.search.sort
- BucketedSort.ForFloats - Class in org.elasticsearch.search.sort
-
Superclass for implementations of BucketedSort for
float
keys. - BucketedSort.ForFloats.Leaf - Class in org.elasticsearch.search.sort
- BucketedSort.ForLongs - Class in org.elasticsearch.search.sort
-
Superclass for implementations of BucketedSort for
long
keys. - BucketedSort.ForLongs.Leaf - Class in org.elasticsearch.search.sort
- BucketedSort.Leaf - Class in org.elasticsearch.search.sort
-
Performs the actual collection against a LeafReaderContext.
- BucketedSort.ResultBuilder<T> - Interface in org.elasticsearch.search.sort
-
Used with
BucketedSort.getValues(long, ResultBuilder)
to build results from the sorting operation. - 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 Class 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.terms.InternalMappedSignificantTerms
- 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(String, String, String[], String, BucketHelpers.GapPolicy) - 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.histogram.AbstractHistogramAggregator
- BucketPriorityQueue<B> - Class in org.elasticsearch.search.aggregations.bucket.terms
- BucketPriorityQueue(int, BigArrays, Comparator<? super B>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.BucketPriorityQueue
- BucketReducer<B extends MultiBucketsAggregation.Bucket> - Class in org.elasticsearch.search.aggregations.bucket
-
Class for reducing a list of
BucketReducer
to a singleInternalAggregations
and the number of documents. - BucketReducer(B, AggregationReduceContext, int) - Constructor for class org.elasticsearch.search.aggregations.bucket.BucketReducer
- buckets - Variable in class org.elasticsearch.script.TimeSeriesCounter.Counter
- buckets - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- buckets - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- buckets - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- buckets - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- 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, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
- BucketsAggregator.BucketBuilderForFixedCount<B> - Interface in org.elasticsearch.search.aggregations.bucket
- BucketsAggregator.BucketBuilderForVariable<B> - Interface in org.elasticsearch.search.aggregations.bucket
- BucketsAggregator.ResultBuilderForVariable<B> - Interface in org.elasticsearch.search.aggregations.bucket
- BucketsAggregator.SingleBucketResultBuilder - Interface in org.elasticsearch.search.aggregations.bucket
- 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
- BucketSignificancePriorityQueue<B extends SignificantTerms.Bucket> - Class in org.elasticsearch.search.aggregations.bucket.terms
- BucketSignificancePriorityQueue(int, BigArrays) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.BucketSignificancePriorityQueue
- bucketsInOrd(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.BytesKeyedBucketOrds
-
Count the buckets in
owningBucketOrd
. - bucketsInOrd(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds
-
Count the buckets in
owningBucketOrd
. - bucketsInOrd(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromMany
- bucketsInOrd(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromManySmall
- bucketsInOrd(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromSingle
- bucketSize(long, Rounding.DateTimeUnit) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregator
- bucketSize(long, Rounding.DateTimeUnit) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSource
- bucketSize(long, Rounding.DateTimeUnit) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.SizedBucketAggregator
-
Reports size of the particular bucket in requested units.
- bucketSize(Rounding.DateTimeUnit) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregator
- bucketSize(Rounding.DateTimeUnit) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSource
- bucketSize(Rounding.DateTimeUnit) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.SizedBucketAggregator
-
Reports size of all buckets in requested units.
- 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 - Variable in class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
-
Current write buffer.
- BUFFER_PREFIX - Static variable in class org.elasticsearch.common.geo.SimpleVectorTileFormatter
- BUFFER_SIZE - Static variable in class org.elasticsearch.common.compress.DeflateCompressor
- BUFFER_SIZE - Static variable in class org.elasticsearch.common.io.DiskIoBufferPool
- BUFFER_SIZE - Static variable in class org.elasticsearch.common.io.Streams
- BUFFER_SIZE_SETTING - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Size hint for the IO buffer size to use when reading from and writing to the repository.
- 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.BlobStoreRepository
-
IO buffer size hint for reading and writing to the underlying blob store.
- 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.cluster.stats.CCSUsage.Builder
- build() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConditions.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.bulk.BulkProcessor2.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.search.SearchResponse.Cluster.Builder
- build() - Method in class org.elasticsearch.action.support.IndicesOptions.Builder
- build() - Method in class org.elasticsearch.action.support.IndicesOptions.GatekeeperOptions.Builder
- build() - Method in class org.elasticsearch.action.support.IndicesOptions.WildcardOptions.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.ClusterInfo.ReservedSpace.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.ComposableIndexTemplate.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.DataStream.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.DataStream.DataStreamIndices.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.DataStreamLifecycle.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.IndexWriteLoad.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.LifecycleExecutionState.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.ReservedStateMetadata.Builder
-
Builds an
ReservedStateMetadata
from this builder. - build() - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.Template.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.ImmutableOpenMap.Builder
-
Builds a new ImmutableOpenMap from this builder.
- build() - Method in class org.elasticsearch.common.logging.ECSJsonLayout.Builder
- build() - Method in class org.elasticsearch.common.logging.ESJsonLayout.Builder
-
Deprecated.
- 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.settings.Settings.Builder
- build() - Method in class org.elasticsearch.health.metadata.HealthMetadata.Builder
- build() - Method in class org.elasticsearch.health.metadata.HealthMetadata.Disk.Builder
- build() - Method in class org.elasticsearch.health.metadata.HealthMetadata.ShardLimits.Builder
- build() - Method in class org.elasticsearch.health.node.UpdateHealthInfoCacheAction.Request.Builder
- build() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Builds an
Ordinals
instance from the builders current state. - build() - Method in interface org.elasticsearch.index.mapper.BlockLoader.Builder
-
Build the actual block.
- build() - Method in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper.Builder
- build() - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper.Builder
- build() - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper.Builder
- build() - Method in class org.elasticsearch.index.mapper.SourceFieldMapper.Builder
- build() - Method in class org.elasticsearch.index.mapper.TimeSeriesIdFieldMapper.Builder
- build() - Method in class org.elasticsearch.indices.IndicesServiceBuilder
- build() - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
-
Builds a
SystemIndexDescriptor
using the fields supplied to this builder. - build() - Method in class org.elasticsearch.inference.configuration.SettingsConfigurationDependency.Builder
- build() - Method in class org.elasticsearch.inference.configuration.SettingsConfigurationSelectOption.Builder
- build() - Method in class org.elasticsearch.inference.configuration.SettingsConfigurationValidation.Builder
- build() - Method in class org.elasticsearch.inference.InferenceServiceConfiguration.Builder
- build() - Method in class org.elasticsearch.inference.SettingsConfiguration.Builder
- build() - Method in class org.elasticsearch.inference.TaskSettingsConfiguration.Builder
- build() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Builder
- build() - Method in class org.elasticsearch.repositories.ShardGenerations.Builder
- build() - Method in class org.elasticsearch.rest.RestHandler.Route.RouteBuilder
- build() - Method in class org.elasticsearch.script.ScriptMetadata.Builder
- build() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterByFilterAggregator.AdapterBuilder
-
Build the the adapter or
null
if the this isn't a valid rewrite. - build() - Method in class org.elasticsearch.search.aggregations.support.AggregationUsageService.Builder
- build() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- build() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry.Builder
- build() - Method in class org.elasticsearch.search.aggregations.TopBucketBuilder
-
Return the most competitive buckets sorted by the comparator.
- 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.transport.ConnectionProfile.Builder
-
Creates a new
ConnectionProfile
based on the added connections. - build(boolean) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- build(int) - Method in class org.elasticsearch.search.vectors.KnnSearchBuilder.Builder
- build(int, long, InternalAggregations) - Method in interface org.elasticsearch.search.aggregations.bucket.BucketsAggregator.BucketBuilderForFixedCount
- build(int, BucketOrder, Consumer<DelayedBucket<B>>, BiFunction<List<B>, AggregationReduceContext, B>, AggregationReduceContext) - Static method in class org.elasticsearch.search.aggregations.TopBucketBuilder
-
Create a
TopBucketBuilder
to build a list of the top buckets. - build(long, long, InternalAggregations) - Method in interface org.elasticsearch.search.aggregations.bucket.BucketsAggregator.BucketBuilderForVariable
- build(long, List<B>) - Method in interface org.elasticsearch.search.aggregations.bucket.BucketsAggregator.ResultBuilderForVariable
- build(long, InternalAggregations) - Method in interface org.elasticsearch.search.aggregations.bucket.BucketsAggregator.SingleBucketResultBuilder
- build(long, SortValue) - Method in interface org.elasticsearch.search.sort.BucketedSort.ResultBuilder
- build(String, int, AggregatorFactories, AggregationContext, Aggregator, Map<String, Object>, ValuesSourceConfig, int, String) - Method in interface org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregatorSupplier
- build(String, AggregatorFactories, double, double, BucketOrder, boolean, long, DoubleBounds, DoubleBounds, ValuesSourceConfig, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregatorSupplier
- build(String, AggregatorFactories, int, int, int, ValuesSourceConfig, AggregationContext, Aggregator, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregatorSupplier
- build(String, AggregatorFactories, List<QueryToFilterAdapter>, boolean, String, boolean, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
-
Build an
Aggregator
for afilters
aggregation. - build(String, AggregatorFactories, GeoDistance, GeoPoint, DistanceUnit, ValuesSource, DocValueFormat, InternalRange.Factory, RangeAggregator.Range[], boolean, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregatorSupplier
- build(String, AggregatorFactories, Rounding, BucketOrder, boolean, long, boolean, LongBounds, LongBounds, ValuesSourceConfig, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationSupplier
- build(String, AggregatorFactories, ValuesSourceConfig, boolean, long, IpPrefixAggregator.IpPrefix, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.prefix.IpPrefixAggregationSupplier
- build(String, AggregatorFactories, ValuesSourceConfig, InternalRange.Factory<?, ?>, RangeAggregator.Range[], boolean, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
-
Build an
Aggregator
for arange
aggregation. - build(String, AggregatorFactories, ValuesSourceConfig, InternalRange.Factory<?, ?>, RangeAggregator.Range[], boolean, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.range.RangeAggregatorSupplier
- build(String, AggregatorFactories, ValuesSourceConfig, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.missing.MissingAggregatorSupplier
- build(String, AggregatorFactories, ValuesSource, int, GeoBoundingBox, int, int, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.GeoGridAggregatorSupplier
- build(String, AggregatorFactories, ValuesSource, DocValueFormat, List<BinaryRangeAggregator.Range>, boolean, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregatorSupplier
- build(String, AggregationContext, Aggregator, ValuesSourceConfig, boolean, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregatorSupplier
- build(String, ValuesSourceConfig, int, CardinalityAggregatorFactory.ExecutionMode, AggregationContext, Aggregator, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.CardinalityAggregatorSupplier
- build(String, ValuesSourceConfig, AggregationContext, Aggregator, double[], PercentilesConfig, boolean, DocValueFormat, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.PercentilesAggregatorSupplier
- build(String, ValuesSourceConfig, AggregationContext, Aggregator, double, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregatorProvider
- build(String, ValuesSourceConfig, AggregationContext, Aggregator, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.MetricAggregatorSupplier
- build(String, ValuesSourceConfig, DocValueFormat, AggregationContext, Aggregator, Map<String, Object>, double, TDigestExecutionHint) - Method in interface org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregatorSupplier
- build(Collection<? extends SearchPhaseResult>) - Method in class org.elasticsearch.search.profile.SearchProfileResultsBuilder
-
Merge the profiling information from some fetch results into this profiling information.
- build(Collection<T>, Function<T, StoredFieldsSpec>) - Static method in record class org.elasticsearch.search.fetch.StoredFieldsSpec
- build(List<String>, IndicesAliasesRequest.AliasActions, int) - Static method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesResponse.AliasActionResult
-
Build result that could be either a success or failure
- build(List<IndicesAliasesResponse.AliasActionResult>) - Static method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesResponse
-
Build a response from a list of action results.
- build(List<NestedObjectMapper>) - Static method in interface org.elasticsearch.index.mapper.NestedLookup
-
Construct a NestedLookup from a list of NestedObjectMappers
- build(IndexReader, IndexOrdinalsFieldData, CircuitBreaker, Logger, ToScriptFieldFactory<SortedSetDocValues>) - Static method in enum class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsBuilder
-
Build global ordinals for the provided
IndexReader
. - build(IndexSearcher, String, Query) - Static method in class org.elasticsearch.search.aggregations.bucket.filter.QueryToFilterAdapter
-
Build a filter for the query against the provided searcher.
- build(Settings) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
- build(BigArrays, CardinalityUpperBound) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.BytesKeyedBucketOrds
-
Build a
LongKeyedBucketOrds
. - build(BigArrays, CardinalityUpperBound) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds
-
Build a
LongKeyedBucketOrds
who's values have unknown bounds. - build(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.PrevalidateNodeRemovalRequest.Builder
- build(IndexAnalyzers) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- build(IndexAnalyzers) - Method in interface org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.CandidateGenerator
- build(TokenizerFactory, Map<String, CharFilterFactory>, Map<String, TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.CustomNormalizerProvider
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.BooleanScriptFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.DateScriptFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.DoubleScriptFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.GeoPointScriptFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.IpScriptFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.LongScriptFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.plain.LatLonPointIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.plain.SortedDoublesIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.plain.SortedOrdinalsIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.SourceValueFetcherMultiGeoPointIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.SourceValueFetcherSortedBinaryIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.SourceValueFetcherSortedBooleanIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.SourceValueFetcherSortedDoubleIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.SourceValueFetcherSortedNumericIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.fielddata.StringScriptFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.mapper.vectors.MultiVectorIndexFieldData.Builder
- build(IndexFieldDataCache, CircuitBreakerService) - Method in class org.elasticsearch.index.mapper.vectors.VectorIndexFieldData.Builder
- build(IndexService.IndexCreationContext, IndexSettings) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
-
Creates an index-level
IndexAnalyzers
from this registry using the given index settings andIndexService.IndexCreationContext
. - build(IndexService.IndexCreationContext, IndexSettings, Map<String, AnalyzerProvider<?>>, Map<String, AnalyzerProvider<?>>, Map<String, TokenizerFactory>, Map<String, CharFilterFactory>, Map<String, TokenFilterFactory>) - Static method in class org.elasticsearch.index.analysis.AnalysisRegistry
- build(Mapper.Builder, MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.Mapper.Builder
-
Returns a newly built mapper.
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.NestedObjectMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.PassThroughObjectMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.PlaceHolderFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.vectors.MultiDenseVectorFieldMapper.Builder
- build(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.vectors.SparseVectorFieldMapper.Builder
- build(SearchExecutionContext) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- build(SearchExecutionContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- build(SearchExecutionContext) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- build(SearchExecutionContext) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- build(SearchExecutionContext) - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- build(SearchExecutionContext) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- build(SearchExecutionContext) - Method in class org.elasticsearch.search.sort.SortBuilder
-
Create a SortFieldAndFormat from this builder.
- build(SearchExecutionContext) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- build(SearchExecutionContext) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- build(SearchExecutionContext) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
- build(SearchExecutionContext) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- build(SearchExecutionContext) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
- build(Script, StringFieldScript.LeafFactory, String, String, int, int, boolean) - Static method in class org.elasticsearch.search.runtime.StringScriptFieldFuzzyQuery
- build(AggregationContext) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- build(AggregationContext, AggregatorFactory) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- build(AggregationContext, AggregatorFactory) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Internal: build an
AggregatorFactory
based on the configuration of this builder. - build(AggregationContext, AggregatorFactory) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- build(SearchContext, InnerHitsContext) - Method in class org.elasticsearch.index.query.InnerHitContextBuilder
- build(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
- build(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.NXYBuilder
- Build - Record Class in org.elasticsearch
-
Information about a build of Elasticsearch.
- Build(String, Build.Type, String, String, String, String, boolean, String, String, String) - Constructor for record class org.elasticsearch.Build
-
Creates an instance of a
Build
record class. - BUILD_AGGREGATION - Enum constant in enum class org.elasticsearch.search.profile.aggregation.AggregationTimingType
- BUILD_LEAF_COLLECTOR - Enum constant in enum class org.elasticsearch.search.profile.aggregation.AggregationTimingType
- BUILD_SCORER - Enum constant in enum class org.elasticsearch.search.profile.query.QueryTimingType
- Build.Type - Enum Class in org.elasticsearch
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.GlobalOrdCardinalityAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.MetricsAggregator
-
Build an aggregation for data that has been collected into
owningBucketOrd
. - buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.MinAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.NonCollectingMultiMetricAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.NonCollectingSingleMetricAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.SumAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregator
- buildAggregation(String, int, List<InternalGeoGridBucket>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregator
- buildAggregation(String, int, List<InternalGeoGridBucket>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
- buildAggregation(String, int, List<InternalGeoGridBucket>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregator
- buildAggregation(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregator
- buildAggregation(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregator
-
Called after a collection run is finished to build the aggregation for the collected state.
- buildAggregation(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregator
- buildAggregation(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.MaxBucketPipelineAggregator
- buildAggregation(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.MinBucketPipelineAggregator
- buildAggregation(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregator
- buildAggregation(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.StatsBucketPipelineAggregator
- buildAggregation(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.SumBucketPipelineAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Build the results of this aggregation.
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.prefix.IpPrefixAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.random.RandomSamplerAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTermsAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.terms.NumericTermsAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTermsAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.metrics.MetricsAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.aggregations.NonCollectingAggregator
- buildAggregations(LongArray) - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- buildAggregationsForFixedBucketCount(LongArray, int, BucketsAggregator.BucketBuilderForFixedCount<B>, Function<List<B>, InternalAggregation>) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Build aggregation results for an aggregator that has a fixed number of buckets per owning ordinal.
- buildAggregationsForSingleBucket(LongArray, BucketsAggregator.SingleBucketResultBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Build aggregation results for an aggregator that always contain a single bucket.
- buildAggregationsForVariableBuckets(LongArray, LongKeyedBucketOrds, BucketsAggregator.BucketBuilderForVariable<B>, BucketsAggregator.ResultBuilderForVariable<B>) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Build aggregation results for an aggregator with a varying number of
long
keyed buckets. - buildAliasFilter(ClusterState, String, Set<String>) - Method in class org.elasticsearch.indices.IndicesService
- buildAliasFilter(ClusterState, String, Set<String>) - Method in class org.elasticsearch.search.SearchService
- buildAnonymousFieldType(String) - Method in class org.elasticsearch.index.query.FilteredSearchExecutionContext
- buildAnonymousFieldType(String) - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Given a type (eg.
- buildAsString() - Method in class org.elasticsearch.common.blobstore.BlobPath
- buildBroadcastShardsHeader(XContentBuilder, ToXContent.Params, int, int, int, int, ShardOperationFailedException[]) - Static method in class org.elasticsearch.rest.action.RestActions
- buildBroadcastShardsHeader(XContentBuilder, ToXContent.Params, BaseBroadcastResponse) - Static method in class org.elasticsearch.rest.action.RestActions
- buildBucketedSort(SearchExecutionContext, BigArrays, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- buildBucketedSort(SearchExecutionContext, BigArrays, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- buildBucketedSort(SearchExecutionContext, BigArrays, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- buildBucketedSort(SearchExecutionContext, BigArrays, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- buildBucketedSort(SearchExecutionContext, BigArrays, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.search.sort.SortBuilder
-
Create a BucketedSort which is useful for sorting inside of aggregations.
- buildBucketedSort(SortBuilder<?>, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Build a collector for sorted values specialized for aggregations.
- buildBucketedSort(SortBuilder<?>, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- buildCharFilterFactories(IndexSettings) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
- buildCompositeMap(String, Map<String, Object>, XContentBuilder) - Static method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation
- buildConfig(Settings) - Static method in class org.elasticsearch.http.CorsHandler
- buildContext() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.random.InternalRandomSampler
- buildContext(SearchExecutionContext) - Method in class org.elasticsearch.search.rescore.RescorerBuilder
-
Build the RescoreContext that will be used to actually execute the rescore against a particular shard.
- buildCustomAnalyzer(IndexService.IndexCreationContext, IndexSettings, boolean, NameOrDefinition, List<NameOrDefinition>, List<NameOrDefinition>) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
-
Creates a custom analyzer from a collection of
NameOrDefinition
specifications for each component Callers are responsible for closing the returned Analyzer - buildCustomAnalyzer(IndexSettings, boolean, NameOrDefinition, List<NameOrDefinition>, List<NameOrDefinition>) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Creates a new custom analyzer that should be closed when finished being used.
- buildCustomAnalyzer(IndexSettings, boolean, NameOrDefinition, List<NameOrDefinition>, List<NameOrDefinition>) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- buildDecisionsForAllNodes(ShardRouting, RoutingAllocation) - Static method in class org.elasticsearch.gateway.BaseGatewayShardAllocator
-
Builds decisions for all nodes in the cluster, so that the explain API can provide information on allocation decisions for each node, while still waiting to allocate the shard (e.g.
- buildDefaultConnectionProfile(Settings) - Static method in class org.elasticsearch.transport.ConnectionProfile
-
Builds a default connection profile based on the provided settings.
- buildDefaultHeaders(Settings) - Static method in class org.elasticsearch.common.util.concurrent.ThreadContext
- buildDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.DeferableBucketAggregator
-
Build the
DeferringBucketCollector
. - buildDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregator
- buildDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedBytesHashSamplerAggregator
- buildDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedMapSamplerAggregator
- buildDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedNumericSamplerAggregator
- buildDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedOrdinalsSamplerAggregator
- buildDeferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- buildDescription() - Method in class org.elasticsearch.action.search.SearchRequest
- buildDfsPhaseResults() - Method in class org.elasticsearch.search.profile.dfs.DfsProfiler
- buildEmpty(IndexReader, IndexOrdinalsFieldData, ToScriptFieldFactory<SortedSetDocValues>) - Static method in enum class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsBuilder
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Build an empty aggregation.
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.prefix.IpPrefixAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.prefix.IpPrefixAggregator.Unmapped
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Unmapped
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.random.RandomSamplerAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTermsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.terms.NumericTermsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTermsAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.GlobalOrdCardinalityAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.MinAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.NonCollectingMultiMetricAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.NonCollectingSingleMetricAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.SumAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregator
- buildEmptyAggregation() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- buildEmptySignificantTermsAggregation(long, long, SignificanceHeuristic) - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator
- buildEmptySubAggregations() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- buildEmptyTermsAggregation() - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator
- builder() - Static method in class org.elasticsearch.action.admin.cluster.node.shutdown.PrevalidateNodeRemovalRequest
- builder() - Static method in record class org.elasticsearch.action.support.IndicesOptions
- builder() - Static method in record class org.elasticsearch.action.support.IndicesOptions.GatekeeperOptions
- builder() - Static method in record class org.elasticsearch.action.support.IndicesOptions.WildcardOptions
- builder() - Static method in class org.elasticsearch.cluster.block.ClusterBlocks
- builder() - Static method in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- builder() - Static method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- builder() - Static method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- builder() - Static method in record class org.elasticsearch.cluster.metadata.LifecycleExecutionState
- builder() - Static method in class org.elasticsearch.cluster.metadata.Metadata
- builder() - Static method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- builder() - Static method in class org.elasticsearch.cluster.metadata.Template
- builder() - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes
- builder() - Method in class org.elasticsearch.cluster.routing.IndexRouting.ExtractFromSource
- builder() - Static method in class org.elasticsearch.cluster.routing.RoutingTable
- builder() - Static method in class org.elasticsearch.common.cache.CacheBuilder
- builder() - Static method in class org.elasticsearch.common.collect.ImmutableOpenMap
- builder() - Static method in class org.elasticsearch.common.settings.Settings
-
Returns a builder to be used in order to build settings.
- builder() - Static method in class org.elasticsearch.indices.SystemIndexDescriptor
- builder() - Static method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- builder() - Static method in class org.elasticsearch.repositories.ShardGenerations
- builder() - Method in class org.elasticsearch.search.aggregations.AggregationReduceContext
-
Builder for the agg being processed or
null
if this context was built for the top level or a pipeline aggregation. - builder() - Static method in class org.elasticsearch.search.aggregations.AggregatorFactories
- builder() - Static method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext
- builder() - Static method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
- builder() - Static method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
- builder() - Static method in class org.elasticsearch.search.suggest.completion.RegexOptions
- builder() - Method in class org.elasticsearch.snapshots.RegisteredPolicySnapshots
- builder(int) - Static method in class org.elasticsearch.cluster.metadata.IndexWriteLoad
- builder(int) - Static method in class org.elasticsearch.common.collect.ImmutableOpenMap
- builder(String) - Static method in class org.elasticsearch.cluster.metadata.AliasMetadata
- builder(String) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata
- builder(String) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- builder(String) - Static method in record class org.elasticsearch.cluster.metadata.ReservedStateMetadata
-
Convenience method for creating a
ReservedStateMetadata.Builder
forReservedStateMetadata
- builder(String, List<Index>) - Static method in class org.elasticsearch.cluster.metadata.DataStream
- builder(String, DataStream.DataStreamIndices) - Static method in class org.elasticsearch.cluster.metadata.DataStream
- builder(String, ReservedStateMetadata) - Static method in record class org.elasticsearch.cluster.metadata.ReservedStateMetadata
-
Convenience method for creating a
ReservedStateMetadata.Builder
forReservedStateMetadata
- builder(BiConsumer<BulkRequest, ActionListener<BulkResponse>>, BulkProcessor.Listener, String) - Static method in class org.elasticsearch.action.bulk.BulkProcessor
- builder(BiConsumer<BulkRequest, ActionListener<BulkResponse>>, BulkProcessor2.Listener, ThreadPool) - Static method in class org.elasticsearch.action.bulk.BulkProcessor2
- builder(Map<KType, VType>) - Static method in class org.elasticsearch.common.collect.ImmutableOpenMap
- builder(IndicesOptions) - Static method in record class org.elasticsearch.action.support.IndicesOptions
- builder(IndicesOptions.GatekeeperOptions) - Static method in record class org.elasticsearch.action.support.IndicesOptions.GatekeeperOptions
- builder(IndicesOptions.WildcardOptions) - Static method in record class org.elasticsearch.action.support.IndicesOptions.WildcardOptions
- builder(ClusterBlocks) - Static method in class org.elasticsearch.cluster.block.ClusterBlocks
-
Convenience method, equivalent to:
builder().blocks(blocks)
- builder(ClusterName) - Static method in class org.elasticsearch.cluster.ClusterState
- builder(ClusterState) - Static method in class org.elasticsearch.cluster.ClusterState
- builder(CoordinationMetadata) - Static method in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- builder(IndexGraveyard) - Static method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- builder(IndexMetadata) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata
- builder(LifecycleExecutionState) - Static method in record class org.elasticsearch.cluster.metadata.LifecycleExecutionState
- builder(Metadata) - Static method in class org.elasticsearch.cluster.metadata.Metadata
- builder(SingleNodeShutdownMetadata) - Static method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- builder(Template) - Static method in class org.elasticsearch.cluster.metadata.Template
- builder(DiscoveryNodes) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes
- builder(RoutingTable) - Static method in class org.elasticsearch.cluster.routing.RoutingTable
- builder(ShardRoutingRoleStrategy) - Static method in class org.elasticsearch.cluster.routing.RoutingTable
- builder(ShardRoutingRoleStrategy, RoutingTable) - Static method in class org.elasticsearch.cluster.routing.RoutingTable
- builder(ShardRoutingRoleStrategy, Index) - Static method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- builder(Rounding.DateTimeUnit) - Static method in class org.elasticsearch.common.Rounding
- builder(TimeValue) - Static method in class org.elasticsearch.common.Rounding
- builder(Index) - Static method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockDocValuesReader.BooleansBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockDocValuesReader.BytesRefsFromBinaryBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockDocValuesReader.BytesRefsFromOrdsBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockDocValuesReader.DoublesBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockDocValuesReader.IntsBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockDocValuesReader.LongsBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in interface org.elasticsearch.index.mapper.BlockLoader
-
The
BlockLoader.Builder
for data of this type. - builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockLoader.Delegating
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockSourceReader.BooleansBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockSourceReader.BytesRefsBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockSourceReader.DoublesBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockSourceReader.GeometriesBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockSourceReader.IntsBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockSourceReader.LongsBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockStoredFieldsReader.BytesFromBytesRefsBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockStoredFieldsReader.BytesFromStringsBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.BlockStoredFieldsReader.IdBlockLoader
- builder(BlockLoader.BlockFactory, int) - Method in class org.elasticsearch.index.mapper.SourceFieldBlockLoader
- builder(ShardId) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- builder(PersistentTasksCustomMetadata) - Static method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- builder(RestRequest.Method, String) - Static method in class org.elasticsearch.rest.RestHandler.Route
- builder(TaskInfo) - Static method in record class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup
- builder(ToXContent.Params) - Static method in interface org.elasticsearch.common.xcontent.ChunkedToXContent
-
Returns a new
ChunkedToXContentBuilder
to construct a series of XContent chunks - Builder() - Constructor for class org.elasticsearch.action.admin.cluster.node.shutdown.PrevalidateNodeRemovalRequest.Builder
- Builder() - Constructor for class org.elasticsearch.action.admin.cluster.stats.CCSUsage.Builder
- Builder() - Constructor for class org.elasticsearch.action.delete.DeleteResponse.Builder
- Builder() - Constructor for class org.elasticsearch.action.DocWriteResponse.Builder
- Builder() - Constructor for class org.elasticsearch.action.index.IndexResponse.Builder
- Builder() - Constructor for class org.elasticsearch.action.support.IndicesOptions.GatekeeperOptions.Builder
- Builder() - Constructor for class org.elasticsearch.action.update.UpdateResponse.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.ClusterInfo.ReservedSpace.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.coordination.CoordinationMetadata.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.Builder
-
Deprecated, for removal: This API element is subject to removal in a future version.
- Builder() - Constructor for class org.elasticsearch.cluster.metadata.DataStreamLifecycle.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.metadata.LifecycleExecutionState.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.metadata.Metadata.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.RestoreInProgress.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.routing.IndexRouting.ExtractFromSource.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.routing.RoutingTable.Builder
- Builder() - Constructor for class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- Builder() - Constructor for class org.elasticsearch.common.logging.ECSJsonLayout.Builder
- Builder() - Constructor for class org.elasticsearch.common.logging.ESJsonLayout.Builder
-
Deprecated.
- Builder() - Constructor for class org.elasticsearch.health.node.UpdateHealthInfoCacheAction.Request.Builder
- Builder() - Constructor for class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper.Builder
- Builder() - Constructor for class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- Builder() - Constructor for class org.elasticsearch.index.mapper.RoutingFieldMapper.Builder
- Builder() - Constructor for class org.elasticsearch.index.mapper.TimeSeriesIdFieldMapper.Builder
- Builder() - Constructor for class org.elasticsearch.inference.configuration.SettingsConfigurationDependency.Builder
- Builder() - Constructor for class org.elasticsearch.inference.configuration.SettingsConfigurationSelectOption.Builder
- Builder() - Constructor for class org.elasticsearch.inference.configuration.SettingsConfigurationValidation.Builder
- Builder() - Constructor for class org.elasticsearch.inference.InferenceServiceConfiguration.Builder
- Builder() - Constructor for class org.elasticsearch.inference.SettingsConfiguration.Builder
- Builder() - Constructor for class org.elasticsearch.inference.TaskSettingsConfiguration.Builder
- Builder() - Constructor for class org.elasticsearch.repositories.ShardGenerations.Builder
- Builder() - Constructor for class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
-
Create an empty builder.
- Builder() - Constructor for class org.elasticsearch.search.aggregations.support.AggregationUsageService.Builder
- Builder() - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- Builder() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry.Builder
- Builder() - Constructor for class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext.Builder
- Builder() - Constructor for class org.elasticsearch.search.suggest.completion.context.GeoQueryContext.Builder
- Builder() - Constructor for class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
- Builder() - Constructor for class org.elasticsearch.search.suggest.completion.RegexOptions.Builder
- Builder() - Constructor for class org.elasticsearch.search.vectors.KnnSearchBuilder.Builder
- Builder() - Constructor for class org.elasticsearch.transport.ConnectionProfile.Builder
-
create an empty builder
- Builder(int) - Constructor for class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- Builder(String) - Constructor for class org.elasticsearch.cluster.metadata.AliasMetadata.Builder
- Builder(String) - Constructor for class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- Builder(String) - Constructor for class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- Builder(String) - Constructor for class org.elasticsearch.cluster.metadata.ReservedStateMetadata.Builder
-
Empty builder for ReservedStateMetadata.
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.FieldAliasMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.Builder
-
Creates a new Builder with a field name
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.Mapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.MetadataFieldMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.PassThroughObjectMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.RuntimeField.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.vectors.SparseVectorFieldMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping.Builder
-
Create a builder for a named
CategoryContextMapping
- Builder(String) - Constructor for class org.elasticsearch.search.suggest.completion.context.GeoContextMapping.Builder
- Builder(String, boolean) - Constructor for class org.elasticsearch.index.mapper.BinaryFieldMapper.Builder
- Builder(String, double, double, int, ValuesSourceType, ToScriptFieldFactory<SortedSetDocValues>) - Constructor for class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.Builder
- Builder(String, String) - Constructor for class org.elasticsearch.index.mapper.PlaceHolderFieldMapper.Builder
- Builder(String, String, ValuesSourceType, ToScriptFieldFactory<SortedSetDocValues>) - Constructor for class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData.Builder
- Builder(String, Optional<ObjectMapper.Subobjects>) - Constructor for class org.elasticsearch.index.mapper.ObjectMapper.Builder
- Builder(String, Optional<ObjectMapper.Subobjects>) - Constructor for class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- Builder(String, ReservedStateMetadata) - Constructor for class org.elasticsearch.cluster.metadata.ReservedStateMetadata.Builder
-
Creates an reserved state metadata builder
- Builder(String, IndexAnalyzers, boolean) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- Builder(String, NamedAnalyzer, IndexVersion) - Constructor for class org.elasticsearch.index.mapper.CompletionFieldMapper.Builder
- Builder(String, IndexNumericFieldData.NumericType, ToScriptFieldFactory<SortedNumericDocValues>, boolean) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData.Builder
- Builder(String, IndexNumericFieldData.NumericType, ValuesSourceType, ToScriptFieldFactory<SortedNumericDocValues>, boolean) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData.Builder
- Builder(String, IndexNumericFieldData.NumericType, ValuesSourceType, ToScriptFieldFactory<SortedNumericDoubleValues>, boolean) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedDoublesIndexFieldData.Builder
- Builder(String, IndexVersion) - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- Builder(String, IndexVersion) - Constructor for class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.Builder
- Builder(String, IndexVersion) - Constructor for class org.elasticsearch.index.mapper.vectors.MultiDenseVectorFieldMapper.Builder
- Builder(String, IndexVersion, Function<Query, BitSetProducer>, IndexSettings) - Constructor for class org.elasticsearch.index.mapper.NestedObjectMapper.Builder
- Builder(String, IndexVersion, IndexAnalyzers, boolean) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- Builder(String, DateFieldMapper.Resolution, DateFormatter, ScriptCompiler, boolean, IndexVersion) - Constructor for class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- Builder(String, MappingParserContext) - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- Builder(String, NumberFieldMapper.NumberType, ScriptCompiler, boolean, boolean, IndexVersion, IndexMode) - Constructor for class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- Builder(String, NumberFieldMapper.NumberType, ScriptCompiler, Settings, IndexVersion, IndexMode) - Constructor for class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- Builder(String, RangeType, boolean) - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- Builder(String, RangeType, Settings) - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- Builder(String, BooleanFieldScript.LeafFactory, ToScriptFieldFactory<SortedNumericDocValues>) - Constructor for class org.elasticsearch.index.fielddata.BooleanScriptFieldData.Builder
- Builder(String, DateFieldScript.LeafFactory, ToScriptFieldFactory<SortedNumericDocValues>) - Constructor for class org.elasticsearch.index.fielddata.DateScriptFieldData.Builder
- Builder(String, DoubleFieldScript.LeafFactory, ToScriptFieldFactory<SortedNumericDoubleValues>) - Constructor for class org.elasticsearch.index.fielddata.DoubleScriptFieldData.Builder
- Builder(String, GeoPointFieldScript.LeafFactory, ToScriptFieldFactory<MultiGeoPointValues>) - Constructor for class org.elasticsearch.index.fielddata.GeoPointScriptFieldData.Builder
- Builder(String, IpFieldScript.LeafFactory, ToScriptFieldFactory<SortedBinaryDocValues>) - Constructor for class org.elasticsearch.index.fielddata.IpScriptFieldData.Builder
- Builder(String, LongFieldScript.LeafFactory, ToScriptFieldFactory<SortedNumericDocValues>) - Constructor for class org.elasticsearch.index.fielddata.LongScriptFieldData.Builder
- Builder(String, ScriptCompiler, boolean, IndexVersion) - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.Builder
- Builder(String, ScriptCompiler, boolean, IndexVersion) - Constructor for class org.elasticsearch.index.mapper.IpFieldMapper.Builder
- Builder(String, ScriptCompiler, boolean, IndexVersion, IndexMode) - Constructor for class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- Builder(String, ScriptContext<Factory>) - Constructor for class org.elasticsearch.index.mapper.AbstractScriptFieldType.Builder
- Builder(String, StringFieldScript.LeafFactory, ToScriptFieldFactory<SortedBinaryDocValues>) - Constructor for class org.elasticsearch.index.fielddata.StringScriptFieldData.Builder
- Builder(String, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData.Builder
- Builder(String, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData.Builder
- Builder(String, ValuesSourceType, IndexVersion, int, DenseVectorFieldMapper.ElementType) - Constructor for class org.elasticsearch.index.mapper.vectors.MultiVectorIndexFieldData.Builder
- Builder(String, ValuesSourceType, IndexVersion, DenseVectorFieldMapper.ElementType, int, boolean, Function<LeafReader, LeafReader>) - Constructor for class org.elasticsearch.index.mapper.vectors.VectorIndexFieldData.Builder
- Builder(String, ValuesSourceType, ValueFetcher, SourceProvider, ToScriptFieldFactory<SortedNumericDocValues>) - Constructor for class org.elasticsearch.index.fielddata.SourceValueFetcherSortedBooleanIndexFieldData.Builder
- Builder(String, ValuesSourceType, ValueFetcher, SourceProvider, ToScriptFieldFactory<SortedNumericDocValues>) - Constructor for class org.elasticsearch.index.fielddata.SourceValueFetcherSortedNumericIndexFieldData.Builder
- Builder(String, ValuesSourceType, ValueFetcher, SourceProvider, ToScriptFieldFactory<MultiGeoPointValues>) - Constructor for class org.elasticsearch.index.fielddata.SourceValueFetcherMultiGeoPointIndexFieldData.Builder
- Builder(String, ValuesSourceType, ValueFetcher, SourceProvider, ToScriptFieldFactory<SortedBinaryDocValues>) - Constructor for class org.elasticsearch.index.fielddata.SourceValueFetcherSortedBinaryIndexFieldData.Builder
- Builder(String, ValuesSourceType, ValueFetcher, SourceProvider, ToScriptFieldFactory<SortedNumericDoubleValues>) - Constructor for class org.elasticsearch.index.fielddata.SourceValueFetcherSortedDoubleIndexFieldData.Builder
- Builder(String, ValuesSourceType, ValueFetcher, SourceProvider, ToScriptFieldFactory<T>) - Constructor for class org.elasticsearch.index.fielddata.SourceValueFetcherIndexFieldData.Builder
- Builder(String, ValuesSourceType, ToScriptFieldFactory<SortedSetDocValues>) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedOrdinalsIndexFieldData.Builder
- Builder(String, ValuesSourceType, ToScriptFieldFactory<SortedSetDocValues>) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData.Builder
- Builder(String, ValuesSourceType, ToScriptFieldFactory<MultiGeoPointValues>) - Constructor for class org.elasticsearch.index.fielddata.plain.LatLonPointIndexFieldData.Builder
- Builder(SearchResponse.Cluster) - Constructor for class org.elasticsearch.action.search.SearchResponse.Cluster.Builder
- Builder(ClusterName) - Constructor for class org.elasticsearch.cluster.ClusterState.Builder
- Builder(ClusterState) - Constructor for class org.elasticsearch.cluster.ClusterState.Builder
- Builder(CoordinationMetadata) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationMetadata.Builder
- Builder(IndexMetadata) - Constructor for class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- Builder(IndexTemplateMetadata) - Constructor for class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- Builder(ReservedStateMetadata) - Constructor for class org.elasticsearch.cluster.metadata.ReservedStateMetadata.Builder
-
Creates an reserved state metadata builder
- Builder(DiscoveryNodes) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- Builder(RestoreInProgress) - Constructor for class org.elasticsearch.cluster.RestoreInProgress.Builder
- Builder(IndexShardRoutingTable) - Constructor for class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- Builder(RoutingTable) - Constructor for class org.elasticsearch.cluster.routing.RoutingTable.Builder
- Builder(ShardRoutingRoleStrategy) - Constructor for class org.elasticsearch.cluster.routing.RoutingTable.Builder
- Builder(ShardRoutingRoleStrategy, RoutingTable) - Constructor for class org.elasticsearch.cluster.routing.RoutingTable.Builder
- Builder(ShardRoutingRoleStrategy, Index) - Constructor for class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- Builder(ImmutableOpenMap<KType, VType>) - Constructor for class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- Builder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
-
Read from a stream.
- Builder(Rounding.DateTimeUnit) - Constructor for class org.elasticsearch.common.Rounding.Builder
- Builder(TimeValue) - Constructor for class org.elasticsearch.common.Rounding.Builder
- Builder(IndexMode, Settings, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.SourceFieldMapper.Builder
- Builder(ShardId) - Constructor for class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- Builder(ScriptMetadata) - Constructor for class org.elasticsearch.script.ScriptMetadata.Builder
- Builder(MeterRegistry) - Constructor for class org.elasticsearch.search.aggregations.support.AggregationUsageService.Builder
- Builder(MeterRegistry) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry.Builder
- Builder(ConnectionProfile) - Constructor for class org.elasticsearch.transport.ConnectionProfile.Builder
-
copy constructor, using another profile as a base
- builderParams - Variable in class org.elasticsearch.index.mapper.FieldMapper
- builderParams(Mapper.Builder, MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- BuilderParams(FieldMapper.MultiFields, FieldMapper.CopyTo, Optional<Mapper.SourceKeepMode>, boolean, OnScriptError) - Constructor for record class org.elasticsearch.index.mapper.FieldMapper.BuilderParams
-
Creates an instance of a
BuilderParams
record class. - builders() - Method in class org.elasticsearch.threadpool.ThreadPool
- BuildExtension - Interface in org.elasticsearch.internal
-
Allows plugging in current build info.
- buildFactory(String, String, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsParser
- buildFactory(String, String, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketParser
- buildFailureMessage() - Method in class org.elasticsearch.action.bulk.BulkResponse
- buildFailureStoreIndexSettings(Settings) - Static method in class org.elasticsearch.cluster.metadata.DataStreamFailureStoreDefinition
-
Obtains the default settings to be used when creating a failure store index on a data stream.
- buildFieldContext(String) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Lookup the context for a field.
- buildFieldContext(MappedFieldType) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Lookup the context for an already resolved field type.
- buildFieldData(MappedFieldType) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Build field data.
- buildFieldData(MappedFieldType) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- buildFieldDoc(SortAndFormats, Object[], String) - Static method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- buildFieldType(Supplier<Boolean>, Supplier<Boolean>, Supplier<String>, Supplier<Boolean>, Supplier<String>) - Static method in class org.elasticsearch.index.mapper.TextParams
- buildFilteredQuery(Query) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- buildFilteredQuery(Query) - Method in class org.elasticsearch.search.internal.SearchContext
-
Automatically apply all required filters to the given query such as alias filters, types filters, etc.
- buildFilteredQuery(Query) - Method in class org.elasticsearch.search.internal.SubSearchContext
- buildFilteredQuery(Query) - Method in class org.elasticsearch.search.rank.RankSearchContext
- buildForValueRange(BigArrays, CardinalityUpperBound, long, long) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds
-
Build a
LongKeyedBucketOrds
who's values have known bounds. - buildFromKeyValues(DiscoveryNodeFilters.OpType, Map<String, List<String>>) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
- buildFromParsedArgs(BiFunction<Boolean, Boolean, T>) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
-
Adapt a standard two argument ctor into one that consumes a ConstructingObjectParser's fields.
- buildFullName(String) - Method in class org.elasticsearch.index.mapper.MapperBuilderContext
-
Builds the full name of the field, taking into account parent objects
- buildHash() - Method in class org.elasticsearch.index.mapper.RoutingPathFields
-
Here we build the hash of the routing values using a similarity function so that we have a result with the following pattern: hash128(concatenate(routing field names)) + foreach(routing field value, limit = MAX_ROUTING_FIELDS) { hash32(routing field value) } + hash128(concatenate(routing field values)) The idea is to be able to place 'similar' values close to each other.
- buildHelpWidths(Table, RestRequest) - Static method in class org.elasticsearch.rest.action.cat.RestTable
- buildIdFieldMapper(BooleanSupplier) - Method in enum class org.elasticsearch.index.IndexMode
-
Build the
FieldMapper
for_id
. - buildIndexAnalyzer(MapperService) - Static method in class org.elasticsearch.index.shard.IndexShard
- buildIndexFieldDataCache(IndexFieldDataCache.Listener, Index, String) - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
- buildIndexSort(Function<String, MappedFieldType>, BiFunction<MappedFieldType, Supplier<SearchLookup>, IndexFieldData<?>>) - Method in class org.elasticsearch.index.IndexSortConfig
-
Builds the
Sort
order from the settings for this index or returns null if this index has no sort. - buildLegacyTsid(RoutingPathFields) - Static method in class org.elasticsearch.index.mapper.TimeSeriesIdFieldMapper
- buildMappers(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- buildNodesHeader(XContentBuilder, ToXContent.Params, int, int, int, List<FailedNodeException>) - Static method in class org.elasticsearch.rest.action.RestActions
-
Create the XContent header for any
BaseNodesResponse
. - buildNodesHeader(XContentBuilder, ToXContent.Params, BaseNodesResponse<NodeResponse>) - Static method in class org.elasticsearch.rest.action.RestActions
-
Create the XContent header for any
BaseNodesResponse
. - buildPipelineTree() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Build a tree of
PipelineAggregator
s to modify the tree of aggregation results after the final reduction. - buildPipelineTree() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
-
Build a tree of
PipelineAggregator
s to modify the tree of aggregation results after the final reduction. - buildQuery(QueryBuilder) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Build a query.
- buildQuery(QueryBuilder) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- buildQueryPhaseCoordinatorContext(int, int) - Method in class org.elasticsearch.search.rank.RankBuilder
-
Generates a context used to be executed on the coordinating node, that would combine all individual shard results.
- buildQueryPhaseResults() - Method in class org.elasticsearch.search.profile.Profilers
-
Build the results for the query phase.
- buildQueryPhaseShardContext(List<Query>, int) - Method in class org.elasticsearch.search.rank.RankBuilder
-
Generates a context used to execute required searches during the query phase on the shard.
- buildQueryWithSampler(QueryBuilder, AggregationContext) - Method in record class org.elasticsearch.search.aggregations.support.SamplingContext
-
Builds the provided query builder into a Lucene query object.
- buildRankFeaturePhaseCoordinatorContext(int, int, Client) - Method in class org.elasticsearch.search.rank.RankBuilder
-
Generates a context used to perform global ranking during the RankFeature phase, on the coordinator based on all the individual shard results.
- buildRankFeaturePhaseShardContext() - Method in class org.elasticsearch.search.rank.RankBuilder
-
Generates a context used to execute the rank feature phase on the shard.
- buildRankFeatureShardResult(SearchHits, int) - Method in class org.elasticsearch.search.rank.context.RankFeaturePhaseRankShardContext
-
This is used to fetch the feature data for a given set of documents, using the
FetchPhase
and theFetchFieldsPhase
subphase. - buildRankFeatureShardResult(SearchHits, int) - Method in class org.elasticsearch.search.rank.rerank.RerankingRankFeaturePhaseRankShardContext
- buildRecoveryTable(RestRequest, RecoveryResponse) - Method in class org.elasticsearch.rest.action.cat.RestCatRecoveryAction
-
buildRecoveryTable will build a table of recovery information suitable for displaying at the command line.
- buildRemoteAccessProfileSettings(Settings) - Static method in class org.elasticsearch.transport.RemoteClusterPortSettings
- buildRemoteIndexName(String, String) - Static method in class org.elasticsearch.transport.RemoteClusterAware
- buildResponse(NodesResponse, XContentBuilder) - Method in class org.elasticsearch.rest.action.RestActions.NodesResponseRestListener
- buildResponse(Table, RestChannel) - Static method in class org.elasticsearch.rest.action.cat.RestTable
- buildResponse(SearchHits, Collection<? extends SearchPhaseResult>) - Method in record class org.elasticsearch.action.search.SearchPhaseController.ReducedQueryPhase
-
Creates a new search response from the given merged hits.
- buildResponse(Response) - Method in class org.elasticsearch.rest.action.RestBuilderListener
- buildResponse(Response) - Method in class org.elasticsearch.rest.action.RestResponseListener
-
Builds the response to send back through the channel.
- buildResponse(Response, XContentBuilder) - Method in class org.elasticsearch.rest.action.RestBuilderListener
-
Builds a response to send back over the channel.
- buildResponse(Response, XContentBuilder) - Method in class org.elasticsearch.rest.action.RestToXContentListener
- buildRoutingFields(IndexSettings) - Method in enum class org.elasticsearch.index.IndexMode
-
How
time_series_dimension
fields are handled by indices in this mode. - buildSamplingQueryIfNecessary(AggregationContext) - Method in record class org.elasticsearch.search.aggregations.support.SamplingContext
- buildShapeQuery(SearchExecutionContext, MappedFieldType) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
builds the appropriate lucene shape query
- buildShapeQuery(SearchExecutionContext, MappedFieldType) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- buildSingleChannelProfile(TransportRequestOptions.Type, TimeValue, TimeValue, TimeValue, Compression.Enabled, Compression.Scheme) - Static method in class org.elasticsearch.transport.ConnectionProfile
-
Builds a connection profile that is dedicated to a single channel type.
- buildSort(List<SortBuilder<?>>) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Compile a sort.
- buildSort(List<SortBuilder<?>>) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- buildSort(List<SortBuilder<?>>, SearchExecutionContext) - Static method in class org.elasticsearch.search.sort.SortBuilder
- buildStatus() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- buildSubAggsForAllBuckets(ObjectArray<B[]>, ToLongFunction<B>, BiConsumer<B, InternalAggregations>) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Build the sub aggregation results for a list of buckets and set them on the buckets.
- buildSubAggsForBuckets(LongArray) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Build the results of the sub-aggregations of the buckets at each of the provided ordinals.
- buildSuccess(List<String>, IndicesAliasesRequest.AliasActions) - Static method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesResponse.AliasActionResult
-
Build a success action result with no errors.
- buildTable(RestRequest, ClusterStateResponse, String) - Method in class org.elasticsearch.rest.action.cat.RestCatComponentTemplateAction
- buildTextPlainResponse(Table, RestChannel) - Static method in class org.elasticsearch.rest.action.cat.RestTable
- buildTokenFilterFactories(IndexSettings) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
- buildTokenizerFactories(IndexSettings) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
- buildTookInMillis() - Method in record class org.elasticsearch.action.search.TransportSearchAction.SearchTimeProvider
- buildTookInMillis(long) - Method in class org.elasticsearch.action.bulk.TransportAbstractBulkAction
- buildTopLevel() - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Build the result of this aggregation if it is at the "top level" of the aggregation tree.
- buildUniqueIdentifier(IndexMetadata) - Static method in class org.elasticsearch.repositories.IndexMetaDataGenerations
-
Compute identifier for
IndexMetadata
from its index- and history-uuid as well as its settings-, mapping- and alias-version. - buildVector(Client, ActionListener<float[]>) - Method in interface org.elasticsearch.search.vectors.QueryVectorBuilder
-
Method for building a vector via the client.
- BuildVersion - Class in org.elasticsearch.env
-
A version representing the code of Elasticsearch
- BuildVersion() - Constructor for class org.elasticsearch.env.BuildVersion
- buildWithoutAttemptedToAdaptToFilters(String, AggregatorFactories, ValuesSource.Numeric, DocValueFormat, InternalRange.Factory<?, ?>, RangeAggregator.Range[], double, boolean, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- buildWordScorerFactory() - Method in class org.elasticsearch.search.suggest.phrase.Laplace
- buildWordScorerFactory() - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- buildWordScorerFactory() - Method in class org.elasticsearch.search.suggest.phrase.SmoothingModel
- buildWordScorerFactory() - Method in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- buildXContentBuilder(Table, RestChannel) - Static method in class org.elasticsearch.rest.action.cat.RestTable
- BUILT_IN - Static variable in class org.elasticsearch.index.similarity.SimilarityService
- BUILT_IN_CLUSTER_SETTINGS - Static variable in class org.elasticsearch.common.settings.ClusterSettings
- BUILT_IN_INDEX_SETTINGS - Static variable in class org.elasticsearch.common.settings.IndexScopedSettings
- BuiltInExecutorBuilders - Interface in org.elasticsearch.threadpool.internal
- bulk - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- bulk() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- bulk(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- bulk(BulkRequest) - Method in interface org.elasticsearch.client.internal.Client
-
Executes a bulk of index / delete operations.
- bulk(BulkRequest) - Method in class org.elasticsearch.client.internal.support.AbstractClient
- bulk(BulkRequest, ActionListener<BulkResponse>) - Method in interface org.elasticsearch.client.internal.Client
-
Executes a bulk of index / delete operations.
- bulk(BulkRequest, ActionListener<BulkResponse>) - Method in class org.elasticsearch.client.internal.support.AbstractClient
- Bulk - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- BULK - Enum constant in enum class org.elasticsearch.transport.TransportRequestOptions.Type
- BULK_INCREMENTAL_STATE - Static variable in class org.elasticsearch.TransportVersions
- BulkByScrollResponse - Class in org.elasticsearch.index.reindex
-
Response used for actions that index many documents using a scroll request.
- BulkByScrollResponse(Iterable<BulkByScrollResponse>, String) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollResponse
- BulkByScrollResponse(StreamInput) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollResponse
- BulkByScrollResponse(TimeValue, BulkByScrollTask.Status, List<BulkItemResponse.Failure>, List<ScrollableHitSource.SearchFailure>, boolean) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollResponse
- BulkByScrollTask - Class in org.elasticsearch.index.reindex
-
Task storing information about a currently running BulkByScroll request.
- BulkByScrollTask(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask
- BulkByScrollTask.Status - Class in org.elasticsearch.index.reindex
-
Status of the reindex, update by query, or delete by query.
- BulkByScrollTask.StatusBuilder - Class in org.elasticsearch.index.reindex
-
This class acts as a builder for
BulkByScrollTask.Status
. - BulkByScrollTask.StatusOrException - Class in org.elasticsearch.index.reindex
-
The status of a slice of the request.
- BulkFeatures - Class in org.elasticsearch.action.bulk
- BulkFeatures() - Constructor for class org.elasticsearch.action.bulk.BulkFeatures
- BulkItemRequest - Class in org.elasticsearch.action.bulk
- BulkItemRequest(int, DocWriteRequest<?>) - Constructor for class org.elasticsearch.action.bulk.BulkItemRequest
- BulkItemResponse - Class in org.elasticsearch.action.bulk
-
Represents a single item response for an action executed as part of the bulk API.
- BulkItemResponse.Failure - Class in org.elasticsearch.action.bulk
-
Represents a failure.
- BulkOperationListener - Interface in org.elasticsearch.index.bulk.stats
-
An bulk operation listener for bulk events.
- BulkProcessor - Class in org.elasticsearch.action.bulk
-
A bulk processor is a thread safe bulk processing class, allowing to easily set when to "flush" a new bulk request (either based on number of actions, based on the size, or time), and to easily control the number of concurrent bulk requests allowed to be executed in parallel.
- BulkProcessor.Builder - Class in org.elasticsearch.action.bulk
-
A builder used to create a build an instance of a bulk processor.
- BulkProcessor.Listener - Interface in org.elasticsearch.action.bulk
-
A listener for the execution.
- BulkProcessor2 - Class in org.elasticsearch.action.bulk
-
A bulk processor is a thread safe bulk processing class, allowing to easily set when to "flush" a new bulk request (either based on number of actions, based on the size, or time), and to easily control the number of concurrent bulk requests allowed to be executed in parallel.
- BulkProcessor2.Builder - Class in org.elasticsearch.action.bulk
-
A builder used to create a build an instance of a bulk processor.
- BulkProcessor2.Listener - Interface in org.elasticsearch.action.bulk
-
A listener for the execution.
- BulkRequest - Class in org.elasticsearch.action.bulk
-
A bulk request holds an ordered
IndexRequest
s,DeleteRequest
s andUpdateRequest
s and allows to execute it in a single batch. - BulkRequest() - Constructor for class org.elasticsearch.action.bulk.BulkRequest
- BulkRequest(String) - Constructor for class org.elasticsearch.action.bulk.BulkRequest
- BulkRequest(StreamInput) - Constructor for class org.elasticsearch.action.bulk.BulkRequest
- BulkRequestBuilder - Class in org.elasticsearch.action.bulk
-
A bulk request holds an ordered
IndexRequest
s andDeleteRequest
s and allows to executes it in a single batch. - BulkRequestBuilder(ElasticsearchClient) - Constructor for class org.elasticsearch.action.bulk.BulkRequestBuilder
- BulkRequestBuilder(ElasticsearchClient, String) - Constructor for class org.elasticsearch.action.bulk.BulkRequestBuilder
- BulkRequestHandler - Class in org.elasticsearch.action.bulk
-
Implements the low-level details of bulk request handling
- BulkRequestParser - Class in org.elasticsearch.action.bulk
-
Helper to parse bulk requests.
- BulkRequestParser(boolean, RestApiVersion) - Constructor for class org.elasticsearch.action.bulk.BulkRequestParser
-
Create a new parser.
- BulkRequestParser.IncrementalParser - Class in org.elasticsearch.action.bulk
- BulkResponse - Class in org.elasticsearch.action.bulk
-
A response of a bulk execution.
- BulkResponse(BulkItemResponse[], long) - Constructor for class org.elasticsearch.action.bulk.BulkResponse
- BulkResponse(BulkItemResponse[], long, long) - Constructor for class org.elasticsearch.action.bulk.BulkResponse
- BulkResponse(BulkItemResponse[], long, long, BulkRequest.IncrementalState) - Constructor for class org.elasticsearch.action.bulk.BulkResponse
- BulkResponse(StreamInput) - Constructor for class org.elasticsearch.action.bulk.BulkResponse
- bulkScorer(LeafReaderContext) - Method in class org.elasticsearch.search.profile.query.ProfileWeight
- BulkShardRequest - Class in org.elasticsearch.action.bulk
- BulkShardRequest(StreamInput) - Constructor for class org.elasticsearch.action.bulk.BulkShardRequest
- BulkShardRequest(ShardId, WriteRequest.RefreshPolicy, BulkItemRequest[]) - Constructor for class org.elasticsearch.action.bulk.BulkShardRequest
- BulkShardRequest(ShardId, WriteRequest.RefreshPolicy, BulkItemRequest[], boolean) - Constructor for class org.elasticsearch.action.bulk.BulkShardRequest
- BulkShardResponse - Class in org.elasticsearch.action.bulk
- BulkShardResponse(ShardId, BulkItemResponse[]) - Constructor for class org.elasticsearch.action.bulk.BulkShardResponse
- bulkStats() - Method in class org.elasticsearch.index.shard.IndexShard
- BulkStats - Class in org.elasticsearch.index.bulk.stats
-
Bulk related statistics, including the time and size of shard bulk requests, starting at the shard level and allowing aggregation to indices and node level
- BulkStats() - Constructor for class org.elasticsearch.index.bulk.stats.BulkStats
- BulkStats(long, long, long, long, long) - Constructor for class org.elasticsearch.index.bulk.stats.BulkStats
- BulkStats(StreamInput) - Constructor for class org.elasticsearch.index.bulk.stats.BulkStats
- busiestThreads(int) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- BypassCircuitBreaker - Enum constant in enum class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaActionExecution
-
Will bypass the configured circuit breaker checks
- BYTE - Enum constant in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- BYTE - Enum constant in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- BYTE - Enum constant in enum class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.ElementType
- BYTE_PAGE_SIZE - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- ByteArray - Interface in org.elasticsearch.common.util
-
Abstraction of an array of byte values.
- ByteArrayIndexInput - Class in org.elasticsearch.common.lucene.store
-
Wraps array of bytes into IndexInput
- ByteArrayIndexInput(String, byte[]) - Constructor for class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- ByteArrayIndexInput(String, byte[], int, int) - Constructor for class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- ByteArrayStreamInput - Class in org.elasticsearch.common.io.stream
-
Resettable
StreamInput
that wraps a byte array. - ByteArrayStreamInput() - Constructor for class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- ByteArrayStreamInput(byte[]) - Constructor for class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- ByteBinaryDenseVector - Class in org.elasticsearch.script.field.vectors
- ByteBinaryDenseVector(byte[], BytesRef, int) - Constructor for class org.elasticsearch.script.field.vectors.ByteBinaryDenseVector
- ByteBinaryDenseVectorDocValuesField - Class in org.elasticsearch.script.field.vectors
- ByteBinaryDenseVectorDocValuesField(BinaryDocValues, String, DenseVectorFieldMapper.ElementType, int) - Constructor for class org.elasticsearch.script.field.vectors.ByteBinaryDenseVectorDocValuesField
- byteBuffer - Variable in class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues
- ByteBufferStreamInput - Class in org.elasticsearch.common.io.stream
- ByteBufferStreamInput(ByteBuffer) - Constructor for class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- ByteCosineSimilarity(ScoreScript, DenseVectorDocValuesField, byte[]) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.ByteCosineSimilarity
- ByteCosineSimilarity(ScoreScript, DenseVectorDocValuesField, List<Number>) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.ByteCosineSimilarity
- ByteDenseVectorFunction(ScoreScript, DenseVectorDocValuesField, byte[]) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.ByteDenseVectorFunction
-
Constructs a dense vector function used for byte-sized vectors.
- ByteDenseVectorFunction(ScoreScript, DenseVectorDocValuesField, List<Number>) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.ByteDenseVectorFunction
-
Constructs a dense vector function used for byte-sized vectors.
- ByteDocValuesField - Class in org.elasticsearch.script.field
- ByteDocValuesField(SortedNumericDocValues, String) - Constructor for class org.elasticsearch.script.field.ByteDocValuesField
- ByteDotProduct(ScoreScript, DenseVectorDocValuesField, byte[]) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.ByteDotProduct
- ByteDotProduct(ScoreScript, DenseVectorDocValuesField, List<Number>) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.ByteDotProduct
- ByteHammingDistance(ScoreScript, DenseVectorDocValuesField, byte[]) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.ByteHammingDistance
- ByteHammingDistance(ScoreScript, DenseVectorDocValuesField, List<Number>) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.ByteHammingDistance
- ByteKnnDenseVector - Class in org.elasticsearch.script.field.vectors
- ByteKnnDenseVector(byte[]) - Constructor for class org.elasticsearch.script.field.vectors.ByteKnnDenseVector
- ByteKnnDenseVectorDocValuesField - Class in org.elasticsearch.script.field.vectors
- ByteKnnDenseVectorDocValuesField(ByteVectorValues, String, int) - Constructor for class org.elasticsearch.script.field.vectors.ByteKnnDenseVectorDocValuesField
- ByteKnnDenseVectorDocValuesField(ByteVectorValues, String, int, DenseVectorFieldMapper.ElementType) - Constructor for class org.elasticsearch.script.field.vectors.ByteKnnDenseVectorDocValuesField
- ByteL1Norm(ScoreScript, DenseVectorDocValuesField, byte[]) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.ByteL1Norm
- ByteL1Norm(ScoreScript, DenseVectorDocValuesField, List<Number>) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.ByteL1Norm
- ByteL2Norm(ScoreScript, DenseVectorDocValuesField, byte[]) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.ByteL2Norm
- ByteL2Norm(ScoreScript, DenseVectorDocValuesField, List<Number>) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.ByteL2Norm
- ByteMultiDenseVector - Class in org.elasticsearch.script.field.vectors
- ByteMultiDenseVector(Iterator<byte[]>, BytesRef, int, int) - Constructor for class org.elasticsearch.script.field.vectors.ByteMultiDenseVector
- ByteMultiDenseVectorDocValuesField - Class in org.elasticsearch.script.field.vectors
- ByteMultiDenseVectorDocValuesField(BinaryDocValues, BinaryDocValues, String, DenseVectorFieldMapper.ElementType, int) - Constructor for class org.elasticsearch.script.field.vectors.ByteMultiDenseVectorDocValuesField
- bytePage(boolean) - Method in class org.elasticsearch.common.util.PageCacheRecycler
- ByteRefHttpBody(BytesReference) - Constructor for record class org.elasticsearch.http.HttpBody.ByteRefHttpBody
-
Creates an instance of a
ByteRefHttpBody
record class. - bytes - Variable in class org.elasticsearch.common.io.stream.BytesStreamOutput
- bytes() - Method in class org.elasticsearch.common.io.stream.BytesStream
- bytes() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- bytes() - Method in class org.elasticsearch.common.io.stream.RecyclerBytesStreamOutput
- bytes() - Method in class org.elasticsearch.common.text.Text
-
Returns a
BytesReference
view of the data. - bytes() - Method in record class org.elasticsearch.http.HttpBody.ByteRefHttpBody
-
Returns the value of the
bytes
record component. - bytes() - Method in interface org.elasticsearch.http.HttpBody.Full
- bytes() - Method in class org.elasticsearch.repositories.RepositoryCleanupResult
- bytes() - Method in class org.elasticsearch.transport.BytesTransportRequest
- bytes(XContentBuilder) - Static method in interface org.elasticsearch.common.bytes.BytesReference
-
Convert an
XContentBuilder
into a BytesReference. - Bytes() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes
- Bytes(byte[], String) - Constructor for class org.elasticsearch.search.vectors.DenseVectorQuery.Bytes
- BYTES - Enum constant in enum class org.elasticsearch.common.unit.ByteSizeUnit
- BYTES_HASH - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
- BYTES_REQUIRED_FOR_MESSAGE_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- BYTES_REQUIRED_FOR_VERSION - Static variable in class org.elasticsearch.transport.TcpHeader
- BytesArray - Class in org.elasticsearch.common.bytes
- BytesArray(byte[]) - Constructor for class org.elasticsearch.common.bytes.BytesArray
- BytesArray(byte[], int, int) - Constructor for class org.elasticsearch.common.bytes.BytesArray
- BytesArray(String) - Constructor for class org.elasticsearch.common.bytes.BytesArray
- BytesArray(BytesRef) - Constructor for class org.elasticsearch.common.bytes.BytesArray
- BytesArray(BytesRef, boolean) - Constructor for class org.elasticsearch.common.bytes.BytesArray
- bytesAsInt() - Method in class org.elasticsearch.common.unit.ByteSizeValue
-
Deprecated.
- BytesBinaryIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- BytesBinaryIndexFieldData(String, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData
- BytesBinaryIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
- bytesDeleted() - Method in class org.elasticsearch.common.blobstore.DeleteResult
- BytesFromBytesRefsBlockLoader(String) - Constructor for class org.elasticsearch.index.mapper.BlockStoredFieldsReader.BytesFromBytesRefsBlockLoader
- BytesFromStringsBlockLoader(String) - Constructor for class org.elasticsearch.index.mapper.BlockStoredFieldsReader.BytesFromStringsBlockLoader
- bytesIngested() - Method in record class org.elasticsearch.ingest.IngestStats.ByteStats
-
Returns the value of the
bytesIngested
record component. - byteSize - Variable in class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues
- ByteSizeDirectory - Class in org.elasticsearch.index.store
- ByteSizeDirectory(Directory) - Constructor for class org.elasticsearch.index.store.ByteSizeDirectory
- byteSizeSetting(String, Function<Settings, String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- byteSizeSetting(String, Setting<ByteSizeValue>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- byteSizeSetting(String, ByteSizeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- byteSizeSetting(String, ByteSizeValue, ByteSizeValue, ByteSizeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- ByteSizeUnit - Enum Class in org.elasticsearch.common.unit
-
A
SizeUnit
represents size at a given unit of granularity and provides utility methods to convert across units. - ByteSizeValue - Class in org.elasticsearch.common.unit
- ByteSizeValue(long, ByteSizeUnit) - Constructor for class org.elasticsearch.common.unit.ByteSizeValue
- BytesKeyedBucketOrds - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Maps
BytesRef
bucket keys to bucket ordinals. - BytesKeyedBucketOrds.BucketOrdsEnum - Interface in org.elasticsearch.search.aggregations.bucket.terms
-
An iterator for buckets inside a particular
owningBucketOrd
. - bytesOutput() - Method in class org.elasticsearch.rest.AbstractRestChannel
-
A channel level bytes output that can be reused.
- bytesOutput() - Method in interface org.elasticsearch.rest.RestChannel
- bytesPerValue(BytesRef) - Method in interface org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData.PerValueEstimator
- bytesPerValue(BytesRef) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.PagedBytesEstimator
- bytesProduced() - Method in record class org.elasticsearch.ingest.IngestStats.ByteStats
-
Returns the value of the
bytesProduced
record component. - BytesRefArray - Class in org.elasticsearch.common.util
-
Compact serializable container for ByteRefs
- BytesRefArray(long, BigArrays) - Constructor for class org.elasticsearch.common.util.BytesRefArray
- BytesRefArray(StreamInput, BigArrays) - Constructor for class org.elasticsearch.common.util.BytesRefArray
- bytesReference() - Method in class org.elasticsearch.common.blobstore.OptionalBytesReference
- bytesReference() - Method in record class org.elasticsearch.inference.ChunkedInferenceServiceResults.Chunk
-
Returns the value of the
bytesReference
record component. - BytesReference - Interface in org.elasticsearch.common.bytes
-
A reference to bytes.
- BytesReferenceIndexInput - Class in org.elasticsearch.common.lucene.store
- BytesReferenceIndexInput(String, BytesReference) - Constructor for class org.elasticsearch.common.lucene.store.BytesReferenceIndexInput
- BytesRefFieldComparatorSource - Class in org.elasticsearch.index.fielddata.fieldcomparator
-
Comparator source for string/binary values.
- BytesRefFieldComparatorSource(IndexFieldData<?>, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Constructor for class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
- BytesRefHash - Class in org.elasticsearch.common.util
-
Specialized hash table implementation similar to Lucene's BytesRefHash that maps BytesRef values to ids.
- BytesRefHash(long, float, BigArrays) - Constructor for class org.elasticsearch.common.util.BytesRefHash
- BytesRefHash(long, BigArrays) - Constructor for class org.elasticsearch.common.util.BytesRefHash
- BytesRefHash(BytesRefArray, float, BigArrays) - Constructor for class org.elasticsearch.common.util.BytesRefHash
-
Construct a BytesRefHash given a BytesRefArray.
- BytesRefHash(BytesRefArray, BigArrays) - Constructor for class org.elasticsearch.common.util.BytesRefHash
-
Construct a BytesRefHash given a BytesRefArray with default maximum load factor.
- BytesRefHash.Finder - Class in org.elasticsearch.common.util
- BytesRefProducer - Interface in org.elasticsearch.script
-
used by
ScriptSortBuilder
to refer to classes in x-pack (eg. - BytesRefRecycler - Class in org.elasticsearch.transport
- BytesRefRecycler(PageCacheRecycler) - Constructor for class org.elasticsearch.transport.BytesRefRecycler
- bytesRefs(int) - Method in interface org.elasticsearch.index.mapper.BlockLoader.BlockFactory
-
Build a builder to load
BytesRef
s without any loading constraints. - BytesRefs - Class in org.elasticsearch.common.lucene
- BytesRefs() - Constructor for class org.elasticsearch.common.lucene.BytesRefs
- BytesRefs(ScriptDocValues.Supplier<BytesRef>) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.BytesRefs
- BytesRefsBlockLoader(ValueFetcher, BlockSourceReader.LeafIteratorLookup) - Constructor for class org.elasticsearch.index.mapper.BlockSourceReader.BytesRefsBlockLoader
- BytesRefsFromBinaryBlockLoader(String) - Constructor for class org.elasticsearch.index.mapper.BlockDocValuesReader.BytesRefsFromBinaryBlockLoader
- bytesRefsFromDocValues(int) - Method in interface org.elasticsearch.index.mapper.BlockLoader.BlockFactory
-
Build a builder to load
BytesRef
s as loaded from doc values. - BytesRefsFromOrdsBlockLoader(String) - Constructor for class org.elasticsearch.index.mapper.BlockDocValuesReader.BytesRefsFromOrdsBlockLoader
- BytesRefSortScript - Class in org.elasticsearch.script
- BytesRefSortScript(Map<String, Object>, DocReader) - Constructor for class org.elasticsearch.script.BytesRefSortScript
- BytesRefSortScript.Factory - Interface in org.elasticsearch.script
-
A factory to construct stateful
BytesRefSortScript
factories for a specific index. - BytesRefSortScript.LeafFactory - Interface in org.elasticsearch.script
-
A factory to construct
BytesRefSortScript
instances. - BytesRefStreamOutput - Class in org.elasticsearch.common.io.stream
-
A @link
StreamOutput
that is backed by aBytesRef
. - BytesRefStreamOutput() - Constructor for class org.elasticsearch.common.io.stream.BytesRefStreamOutput
- bytesStillToRecover() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- BytesStream - Class in org.elasticsearch.common.io.stream
- BytesStream() - Constructor for class org.elasticsearch.common.io.stream.BytesStream
- BytesStreamOutput - Class in org.elasticsearch.common.io.stream
-
A @link
StreamOutput
that usesBigArrays
to acquire pages of bytes, which avoids frequent reallocation & copying of the internal data. - BytesStreamOutput() - Constructor for class org.elasticsearch.common.io.stream.BytesStreamOutput
-
Create a non recycling
BytesStreamOutput
with an initial capacity of 0. - BytesStreamOutput(int) - Constructor for class org.elasticsearch.common.io.stream.BytesStreamOutput
-
Create a non recycling
BytesStreamOutput
with enough initial pages acquired to satisfy the capacity given by expected size. - BytesStreamOutput(int, BigArrays) - Constructor for class org.elasticsearch.common.io.stream.BytesStreamOutput
- byteStats() - Method in record class org.elasticsearch.ingest.IngestStats.PipelineStat
-
Returns the value of the
byteStats
record component. - ByteStats(long, long) - Constructor for record class org.elasticsearch.ingest.IngestStats.ByteStats
-
Creates an instance of a
ByteStats
record class. - ByteStats(StreamInput) - Constructor for record class org.elasticsearch.ingest.IngestStats.ByteStats
- bytesToInt(byte[], int) - Static method in class org.elasticsearch.common.Numbers
- bytesToLong(byte[], int) - Static method in class org.elasticsearch.common.Numbers
- bytesToLong(BytesRef) - Static method in class org.elasticsearch.common.Numbers
- bytesToPreallocate() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Bytes to preallocate on the "request" breaker for this aggregation.
- bytesToPreallocate() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
-
Bytes to preallocate on the "request" breaker for these aggregations.
- bytesToShort(byte[], int) - Static method in class org.elasticsearch.common.Numbers
- bytesToString(BytesRef) - Static method in class org.elasticsearch.index.fielddata.ScriptDocValues.StringsSupplier
- bytesToString(BytesRef) - Static method in class org.elasticsearch.script.field.BaseKeywordDocValuesField
- BytesTransportRequest - Class in org.elasticsearch.transport
-
A specialized, bytes only request, that can potentially be optimized on the network layer, specifically for the same large buffer send to several nodes.
- BytesTransportRequest(ReleasableBytesReference, TransportVersion) - Constructor for class org.elasticsearch.transport.BytesTransportRequest
- BytesTransportRequest(StreamInput) - Constructor for class org.elasticsearch.transport.BytesTransportRequest
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.FieldData
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.Script
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithScript
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource
-
Get a byte array like view into the values.
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint.Fielddata
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Range
- ByteUtils - Enum Class in org.elasticsearch.common.util
-
Utility methods to do byte-level encoding.
- byteVector() - Method in record class org.elasticsearch.search.vectors.VectorData
-
Returns the value of the
byteVector
record component.
C
- c - Variable in class org.elasticsearch.common.recycler.ConcurrentDequeRecycler
- cache - Variable in class org.elasticsearch.index.analysis.PreConfiguredAnalysisComponent
- cache - Variable in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- cache - Variable in class org.elasticsearch.search.fetch.subphase.highlight.FieldHighlightContext
- cache() - Method in class org.elasticsearch.index.IndexService
- Cache<K,
V> - Class in org.elasticsearch.common.cache -
A simple concurrent cache.
- CACHE_REPOSITORY_DATA - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Setting to disable caching of the latest repository data.
- Cache.CacheStats - Class in org.elasticsearch.common.cache
- CacheBuilder<K,
V> - Class in org.elasticsearch.common.cache - CachedSupplier<T> - Class in org.elasticsearch.common.util
-
A
Supplier
that caches its return value. - cacheEvictions() - Method in record class org.elasticsearch.script.ScriptContextStats
-
Returns the value of the
cacheEvictions
record component. - cacheEvictions() - Method in record class org.elasticsearch.script.ScriptStats
-
Returns the value of the
cacheEvictions
record component. - cacheEvictionsHistory() - Method in record class org.elasticsearch.script.ScriptContextStats
-
Returns the value of the
cacheEvictionsHistory
record component. - cacheEvictionsHistory() - Method in record class org.elasticsearch.script.ScriptStats
-
Returns the value of the
cacheEvictionsHistory
record component. - cacheExpireDefault - Variable in class org.elasticsearch.script.ScriptContext
-
The default expiration of a script in the cache for the context, if not overridden
- cacheKey() - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Key for the lookup to be used in caches.
- cacheKey(CheckedBiConsumer<ShardSearchRequest, StreamOutput, IOException>) - Method in class org.elasticsearch.search.internal.ShardSearchRequest
-
Returns the cache key for this shard search request, based on its content
- CacheLoader<K,
V> - Interface in org.elasticsearch.common.cache - cacheSizeDefault - Variable in class org.elasticsearch.script.ScriptContext
-
The default size of the cache for the context if not overridden
- cacheStats() - Method in class org.elasticsearch.script.ScriptService
- CacheStats(long, long, long) - Constructor for class org.elasticsearch.common.cache.Cache.CacheStats
- caFromTriangle(byte) - Static method in interface org.elasticsearch.lucene.spatial.TriangleTreeVisitor
- calculate(boolean, int, HealthInfo) - Method in class org.elasticsearch.cluster.coordination.StableMasterHealthIndicatorService
- calculate(boolean, int, HealthInfo) - Method in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- calculate(boolean, int, HealthInfo) - Method in interface org.elasticsearch.health.HealthIndicatorService
- calculate(boolean, int, HealthInfo) - Method in class org.elasticsearch.health.node.DiskHealthIndicatorService
- calculate(boolean, int, HealthInfo) - Method in class org.elasticsearch.health.node.ShardsCapacityHealthIndicatorService
- calculate(boolean, int, HealthInfo) - Method in class org.elasticsearch.snapshots.RepositoryIntegrityHealthIndicatorService
- calculate(boolean, HealthInfo) - Method in interface org.elasticsearch.health.HealthIndicatorService
- calculate(double, double, double, double, DistanceUnit) - Method in enum class org.elasticsearch.common.geo.GeoDistance
-
compute the distance between two points using the selected algorithm (PLANE, ARC)
- calculate(Integer, ByteSizeValue, IndexMetadata) - Method in interface org.elasticsearch.action.admin.indices.shrink.ResizeNumberOfShardsCalculator
-
Calculates the target number of shards based on the parameters of the request
- calculate(Integer, ByteSizeValue, IndexMetadata) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeNumberOfShardsCalculator.CloneShardsCalculator
- calculate(Integer, ByteSizeValue, IndexMetadata) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeNumberOfShardsCalculator.ShrinkShardsCalculator
- calculate(Integer, ByteSizeValue, IndexMetadata) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeNumberOfShardsCalculator.SplitShardsCalculator
- calculate(ClusterState, DataStream, Double) - Method in class org.elasticsearch.action.datastreams.autosharding.DataStreamAutoShardingService
-
Computes the optimal number of shards for the provided data stream according to the write index's indexing load (to check if we must increase the number of shards, whilst the heuristics for decreasing the number of shards _might_ use the provided write indexing load).
- calculateAcceptableNumberOfShards(int, int) - Static method in class org.elasticsearch.action.admin.indices.shrink.ResizeNumberOfShardsCalculator.ShrinkShardsCalculator
- calculateAllNodeFeatures(Collection<Set<String>>) - Static method in class org.elasticsearch.cluster.ClusterFeatures
- calculateDelayBound(long) - Method in class org.elasticsearch.action.support.RetryableAction
- calculateMaxClauseValue(ThreadPool) - Static method in class org.elasticsearch.search.SearchUtils
- calculateMinShouldMatch(int, String) - Static method in class org.elasticsearch.common.lucene.search.Queries
- calculateNumRoutingShards(int, IndexVersion) - Static method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
-
Returns a default number of routing shards based on the number of shards of the index.
- calculatePercentage(long, long) - Static method in class org.elasticsearch.monitor.os.OsStats
- calculateValue(ByteSizeValue, ByteSizeValue) - Method in class org.elasticsearch.common.unit.RelativeByteSizeValue
-
Calculate the size to use, optionally catering for a max headroom.
- CALENDAR - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
- calendarInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Sets the interval of the DateHistogram using calendar units (`1d`, `1w`, `1M`, etc).
- calendarInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Sets the interval of the DateHistogram using calendar units (`1d`, `1w`, `1M`, etc).
- calendarInterval(DateHistogramInterval) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalConsumer
- calendarInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
-
Sets the interval of the DateHistogram using calendar units (`1d`, `1w`, `1M`, etc).
- camelCaseToSnakeCase(String) - Static method in enum class org.elasticsearch.common.time.LegacyFormatNames
- CAN_MATCH_SEARCH_SOURCE - Static variable in class org.elasticsearch.index.engine.Engine
- canAcceptNull() - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- canAddIgnoredField() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- canAddShards() - Method in record class org.elasticsearch.indices.ShardLimitValidator.Result
-
Returns the value of the
canAddShards
record component. - canAllocate(IndexMetadata, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
Returns a
Decision
whether the given shard routing can be allocated at all at this state of theRoutingAllocation
. - canAllocate(IndexMetadata, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- canAllocate(IndexMetadata, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
- canAllocate(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
Returns a
Decision
whether the given shard routing can be allocated at all at this state of theRoutingAllocation
. - canAllocate(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- canAllocate(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
- canAllocate(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.MaxRetryAllocationDecider
- canAllocate(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ReplicaAfterPrimaryActiveAllocationDecider
- canAllocate(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ResizeAllocationDecider
- canAllocate(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.RestoreInProgressAllocationDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
Returns a
Decision
whether the given shard routing can be allocated on the given node. - canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.IndexVersionAllocationDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.MaxRetryAllocationDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.NodeReplacementAllocationDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.NodeShutdownAllocationDecider
-
Determines if a shard can be allocated to a particular node, based on whether that node is shutting down or not.
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.NodeVersionAllocationDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ReplicaAfterPrimaryActiveAllocationDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ResizeAllocationDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.RestoreInProgressAllocationDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.SameShardAllocationDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
- canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.SnapshotInProgressAllocationDecider
-
Returns a
Decision
whether the given shard routing can be allocated on the given node. - canAllocate(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
- canAllocateReplicaWhenThereIsRetentionLease(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
Returns a
Decision
whether the given replica shard can be allocated to the given node when there is an existing retention lease already existing on the node (meaning it has been allocated there previously) This method does not actually check whether there is a retention lease, that is the responsibility of the caller. - canAllocateReplicaWhenThereIsRetentionLease(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- canAllocateReplicaWhenThereIsRetentionLease(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.NodeReplacementAllocationDecider
- canAssign() - Method in class org.elasticsearch.persistent.decider.EnableAssignmentDecider
-
Returns a
AssignmentDecision
whether the given persistent task can be assigned to a node of the cluster. - canBeAllocatedToAtLeastOneNode(ShardRouting, RoutingAllocation) - Static method in class org.elasticsearch.gateway.ReplicaShardAllocator
-
Determines if the shard can be allocated on at least one node based on the allocation deciders.
- canCache(ShardSearchRequest, SearchContext) - Static method in class org.elasticsearch.indices.IndicesService
-
Can the shard request be cached at all?
- cancel() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
-
Cancel any scheduled run, but do not prevent subsequent restarts.
- cancel() - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
- cancel() - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- cancel() - Method in interface org.elasticsearch.threadpool.Scheduler.Cancellable
-
Cancel the execution of this object.
- cancel() - Method in class org.elasticsearch.threadpool.Scheduler.ReschedulingRunnable
- cancel(boolean) - Method in class org.elasticsearch.action.support.PlainActionFuture
- cancel(Exception) - Method in class org.elasticsearch.action.support.RetryableAction
- cancel(String) - Method in class org.elasticsearch.cluster.coordination.Publication
- cancel(String) - Method in class org.elasticsearch.common.util.CancellableThreads
-
cancel all current running operations.
- cancel(String) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
-
Cancels the recovery and interrupts all eligible threads.
- cancel(String) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
cancel the recovery.
- cancel(Future<?>) - Static method in class org.elasticsearch.common.util.concurrent.FutureUtils
-
Cancel execution of this future without interrupting a running thread.
- cancel(CancellableTask, String, Runnable) - Method in class org.elasticsearch.tasks.TaskManager
-
Cancels a task
- CANCEL_CHILD_ACTION_NAME - Static variable in class org.elasticsearch.tasks.TaskCancellationService
- CancelAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
A command that cancels relocation, or recovery of a given shard on a node.
- CancelAllocationCommand(String, int, String, boolean) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
-
Creates a new
CancelAllocationCommand
- CancelAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
-
Read from a stream.
- cancelChildLocal(TaskId, long, String) - Method in class org.elasticsearch.tasks.TaskManager
-
Cancels children tasks of the specified parent, with the request ID specified, as long as the request ID is positive.
- cancelChildRemote(TaskId, long, Transport.Connection, String) - Method in class org.elasticsearch.tasks.TaskCancellationService
-
Sends an action to cancel a child task, associated with the given request ID and parent task.
- cancelChildRemote(TaskId, long, Transport.Connection, String) - Method in class org.elasticsearch.tasks.TaskManager
-
Send an Action to cancel children tasks of the specified parent, with the request ID specified.
- CANCELED - Enum constant in enum class org.elasticsearch.action.admin.cluster.stats.CCSUsageTelemetry.Result
- CANCELED_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- cancellable() - Method in record class org.elasticsearch.tasks.TaskInfo
-
Returns the value of the
cancellable
record component. - CancellableFanOut<Item,
ItemResponse, FinalResponse> - Class in org.elasticsearch.action.support -
Allows an action to fan-out to several sub-actions and accumulate their results, but which reacts to a cancellation by releasing all references to itself, and hence the partially-accumulated results, allowing them to be garbage-collected.
- CancellableFanOut() - Constructor for class org.elasticsearch.action.support.CancellableFanOut
- CancellableSingleObjectCache<Input,
Key, Value> - Class in org.elasticsearch.common.util -
A cache of a single object whose refresh process can be cancelled.
- CancellableSingleObjectCache(ThreadContext) - Constructor for class org.elasticsearch.common.util.CancellableSingleObjectCache
- CancellableTask - Class in org.elasticsearch.tasks
-
A task that can be cancelled
- CancellableTask(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.tasks.CancellableTask
- CancellableTask.CancellationListener - Interface in org.elasticsearch.tasks
-
This interface is implemented by any class that needs to react to the cancellation of this task.
- CancellableTasksTracker<T> - Class in org.elasticsearch.tasks
-
Tracks items that are associated with cancellable tasks, supporting efficient lookup by task ID and by parent task ID
- CancellableTasksTracker() - Constructor for class org.elasticsearch.tasks.CancellableTasksTracker
- cancellableThreads() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- CancellableThreads - Class in org.elasticsearch.common.util
-
A utility class for multi threaded operation that needs to be cancellable via interrupts.
- CancellableThreads() - Constructor for class org.elasticsearch.common.util.CancellableThreads
- CancellableThreads.ExecutionCancelledException - Exception in org.elasticsearch.common.util
- CancellableThreads.Interruptible - Interface in org.elasticsearch.common.util
- CancellableThreads.OnCancel - Interface in org.elasticsearch.common.util
- cancelled() - Method in record class org.elasticsearch.tasks.TaskInfo
-
Returns the value of the
cancelled
record component. - cancelRecoveriesForShard(ShardId, String) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
cancel all ongoing recoveries for the given shard
- cancelRecovery(long, String) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
cancel the recovery with the given id (if found) and remove it from the recovery collection
- cancelRelocation() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Cancel relocation of a shard.
- cancelRelocation(AllocationId) - Static method in class org.elasticsearch.cluster.routing.AllocationId
-
Creates a new allocation id representing a cancelled relocation.
- cancelSearchTask(SearchTask, String) - Method in class org.elasticsearch.action.search.SearchTransportService
- cancelTaskAndDescendants(CancellableTask, String, boolean, ActionListener<Void>) - Method in class org.elasticsearch.tasks.TaskManager
- cancelTasks(CancelTasksRequest) - Method in class org.elasticsearch.client.internal.ClusterAdminClient
- cancelTasks(CancelTasksRequest, ActionListener<ListTasksResponse>) - Method in class org.elasticsearch.client.internal.ClusterAdminClient
- CancelTasksRequest - Class in org.elasticsearch.action.admin.cluster.node.tasks.cancel
-
A request to cancel tasks
- CancelTasksRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
- CancelTasksRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
- CancelTasksRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.tasks.cancel
-
Builder for the request to cancel tasks running on the specified nodes
- CancelTasksRequestBuilder(ElasticsearchClient) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequestBuilder
- canContainData() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Should this node hold data (shards) or not.
- canContainData() - Method in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
Indicates whether a node with this role can contain data.
- canContainData(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Check if the given settings are indicative of any role that can contain data.
- canDeleteIndexContents(Index) - Method in class org.elasticsearch.indices.IndicesService
-
This method returns true if the current node is allowed to delete the given index.
- canDeleteShardContent(ShardId, IndexSettings) - Method in class org.elasticsearch.indices.IndicesService
-
Returns
ShardDeletionCheckResult
signaling whether the shards content for the given shard can be deleted. - Candidate(BytesRef, TermStats, double, double, boolean) - Constructor for class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- CANDIDATE - Enum constant in enum class org.elasticsearch.cluster.coordination.Coordinator.Mode
- CandidateGenerator - Class in org.elasticsearch.search.suggest.phrase
- CandidateGenerator() - Constructor for class org.elasticsearch.search.suggest.phrase.CandidateGenerator
- candidates - Variable in class org.elasticsearch.search.suggest.phrase.Correction
- candidates - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.CandidateSet
- CandidateSet(DirectCandidateGenerator.Candidate[], DirectCandidateGenerator.Candidate) - Constructor for class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.CandidateSet
- canDownloadSnapshotFiles() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- canEarlyTerminate(Sort, Sort) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Whether a query sorted by
searchSort
can be early-terminated if the index is sorted byindexSort
. - canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
Returns a
Decision
whether the given shard can be forced to the given node in the event that the shard's source node is being replaced. - canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
- canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
- canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.IndexVersionAllocationDecider
- canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.MaxRetryAllocationDecider
- canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.NodeReplacementAllocationDecider
- canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.NodeVersionAllocationDecider
- canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ReplicaAfterPrimaryActiveAllocationDecider
- canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ResizeAllocationDecider
- canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.RestoreInProgressAllocationDecider
- canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.SameShardAllocationDecider
- canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.SnapshotInProgressAllocationDecider
- canForceAllocateDuringReplace(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
- canForceAllocatePrimary(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
Returns a
Decision
whether the given primary shard can be forcibly allocated on the given node. - canForceAllocatePrimary(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- canForceAllocatePrimary(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.MaxRetryAllocationDecider
- canForceAllocatePrimary(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ResizeAllocationDecider
- canForceAllocatePrimary(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.RestoreInProgressAllocationDecider
- canForceAllocatePrimary(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.SameShardAllocationDecider
- canHighlight(MappedFieldType) - Method in class org.elasticsearch.search.fetch.subphase.highlight.DefaultHighlighter
- canHighlight(MappedFieldType) - Method in class org.elasticsearch.search.fetch.subphase.highlight.FastVectorHighlighter
- canHighlight(MappedFieldType) - Method in interface org.elasticsearch.search.fetch.subphase.highlight.Highlighter
- canHighlight(MappedFieldType) - Method in class org.elasticsearch.search.fetch.subphase.highlight.PlainHighlighter
- canLeadReduction() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
- canLeadReduction() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- canLeadReduction() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- canLeadReduction() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- canLeadReduction() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Return true if this aggregation can lead a reduction (ie, is not unmapped or empty).
- canLeadReduction() - Method in class org.elasticsearch.search.aggregations.metrics.Max
- canLeadReduction() - Method in class org.elasticsearch.search.aggregations.metrics.Min
- canMatch() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexResponse
- canMatch() - Method in class org.elasticsearch.search.CanMatchShardResponse
- canMatch(CanMatchNodeRequest, ActionListener<CanMatchNodeResponse>) - Method in class org.elasticsearch.search.SearchService
- canMatch(ShardSearchRequest) - Method in class org.elasticsearch.search.SearchService
-
This method uses a lightweight searcher without wrapping (i.e., not open a full reader on frozen indices) to rewrite the query to check if the query can match any documents.
- CanMatchNodeRequest - Class in org.elasticsearch.action.search
-
Node-level request used during can-match phase
- CanMatchNodeRequest(SearchRequest, IndicesOptions, List<CanMatchNodeRequest.Shard>, int, long, String) - Constructor for class org.elasticsearch.action.search.CanMatchNodeRequest
- CanMatchNodeRequest(StreamInput) - Constructor for class org.elasticsearch.action.search.CanMatchNodeRequest
- CanMatchNodeRequest.Shard - Class in org.elasticsearch.action.search
- CanMatchNodeResponse - Class in org.elasticsearch.action.search
- CanMatchNodeResponse(List<CanMatchNodeResponse.ResponseOrFailure>) - Constructor for class org.elasticsearch.action.search.CanMatchNodeResponse
- CanMatchNodeResponse(StreamInput) - Constructor for class org.elasticsearch.action.search.CanMatchNodeResponse
- CanMatchNodeResponse.ResponseOrFailure - Class in org.elasticsearch.action.search
- CanMatchShardResponse - Class in org.elasticsearch.search
-
Shard-level response for can-match requests
- CanMatchShardResponse(boolean, MinAndMax<?>) - Constructor for class org.elasticsearch.search.CanMatchShardResponse
- CanMatchShardResponse(StreamInput) - Constructor for class org.elasticsearch.search.CanMatchShardResponse
- canMerge(T, T, FieldMapper.Conflicts) - Method in interface org.elasticsearch.index.mapper.FieldMapper.MergeValidator
- canMoveToClosed() - Method in class org.elasticsearch.common.component.Lifecycle
- canMoveToStarted() - Method in class org.elasticsearch.common.component.Lifecycle
- canMoveToStopped() - Method in class org.elasticsearch.common.component.Lifecycle
- CANNOT_REBALANCE_CAN_ALLOCATE - Static variable in class org.elasticsearch.cluster.routing.allocation.Explanations.Rebalance
- CANNOT_REBALANCE_CANNOT_ALLOCATE - Static variable in class org.elasticsearch.cluster.routing.allocation.Explanations.Rebalance
- cannotBindToGuiceType(String) - Method in class org.elasticsearch.injection.guice.internal.Errors
- cannotInjectInnerClass(Class<?>) - Method in class org.elasticsearch.injection.guice.internal.Errors
- cannotInjectRawMembersInjector() - Method in class org.elasticsearch.injection.guice.internal.Errors
- cannotInjectRawProvider() - Method in class org.elasticsearch.injection.guice.internal.Errors
- cannotInjectRawTypeLiteral() - Method in class org.elasticsearch.injection.guice.internal.Errors
- cannotInjectTypeLiteralOf(Type) - Method in class org.elasticsearch.injection.guice.internal.Errors
- cannotSatisfyCircularDependency(Class<?>) - Method in class org.elasticsearch.injection.guice.internal.Errors
- canonicalize(Type) - Static method in class org.elasticsearch.injection.guice.internal.MoreTypes
-
Returns a type that is functionally equal but not necessarily equal according to
Object.equals()
. - canonicalName(String) - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns base file name from part name
- canRebalance(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
Returns a
Decision
whether the cluster can execute re-balanced operations at all. - canRebalance(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- canRebalance(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider
- canRebalance(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ConcurrentRebalanceAllocationDecider
- canRebalance(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
- canRebalance(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
Returns a
Decision
whether the given shard routing can be re-balanced to the given allocation. - canRebalance(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- canRebalance(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider
- canRebalance(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ConcurrentRebalanceAllocationDecider
- canRebalance(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
- canRebalance(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.RebalanceOnlyWhenActiveAllocationDecider
- canRebalance(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.SnapshotInProgressAllocationDecider
-
Returns a
Decision
whether the given shard routing can be re-balanced to the given allocation. - canRebalanceCluster() - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Returns
true
if the shard is allowed to be rebalanced to another node in the cluster, returnsfalse
otherwise. - canRecoverSnapshotFilesFromSourceNode() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- canRemain() - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Returns
true
if the shard can remain on its current node, returnsfalse
otherwise. - canRemain(IndexMetadata, ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
Returns a
Decision
whether the given shard routing can be remain on the given node. - canRemain(IndexMetadata, ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
- canRemain(IndexMetadata, ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
- canRemain(IndexMetadata, ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
- canRemain(IndexMetadata, ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.NodeReplacementAllocationDecider
- canRemain(IndexMetadata, ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.NodeShutdownAllocationDecider
-
Applies the same rules as
NodeShutdownAllocationDecider.canAllocate(ShardRouting, RoutingNode, RoutingAllocation)
to determine if shards can remain on their current node. - canRemain(IndexMetadata, ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
- canRemain(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- canReturnNullResponseIfMatchNoDocs() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
-
Returns true if the caller can handle null response
QuerySearchResult.nullInstance()
. - canReturnNullResponseIfMatchNoDocs(boolean) - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- canReuse(int) - Method in class org.elasticsearch.index.mapper.BlockDocValuesReader
-
Checks if the reader can be used to read a range documents starting with the given docID by the current thread.
- canReuse(int) - Method in class org.elasticsearch.index.mapper.BlockLoader.ConstantNullsReader
- canReuse(int) - Method in interface org.elasticsearch.index.mapper.BlockLoader.Reader
-
Checks if the reader can be used to read a range documents starting with the given docID by the current thread.
- canReuse(int) - Method in class org.elasticsearch.index.mapper.BlockSourceReader
- canReuse(int) - Method in class org.elasticsearch.index.mapper.BlockStoredFieldsReader
- canRewriteToMatchNone() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- canRewriteToMatchNone(SearchSourceBuilder) - Static method in class org.elasticsearch.search.SearchService
-
Returns true iff the given search source builder can be early terminated by rewriting to a match none query.
- canSearchShard(ShardRouting, ClusterState) - Static method in class org.elasticsearch.cluster.routing.OperationRouting
- canStream(TaskType) - Method in interface org.elasticsearch.inference.InferenceService
-
Checks the task type against the set of supported streaming tasks returned by
InferenceService.supportedStreamingTasks()
. - canTripCircuitBreaker() - Method in class org.elasticsearch.health.RestGetHealthAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestAddVotingConfigExclusionAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestCancelTasksAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClearVotingConfigExclusionsAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterAllocationExplainAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterGetSettingsAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterHealthAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStateAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStatsAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterUpdateSettingsAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestListTasksAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesCapabilitiesAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesHotThreadsAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesInfoAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesStatsAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesUsageAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestPrevalidateNodeRemovalAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestReloadSecureSettingsAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.cluster.RestRemoteClusterInfoAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.indices.RestClearIndicesCacheAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesStatsAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.FilterRestHandler
- canTripCircuitBreaker() - Method in interface org.elasticsearch.rest.RestHandler
- canTripCircuitBreaker() - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- canUpdateInPlace(Settings, Set<String>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- canUpdateInPlace(Settings, Set<String>) - Method in class org.elasticsearch.repositories.FilterRepository
- canUpdateInPlace(Settings, Set<String>) - Method in interface org.elasticsearch.repositories.Repository
-
Check if this instances
Settings
can be changed to the provided updated settings without recreating the repository. - canUseSyntheticSourceDelegateForLoading() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
-
Returns true if the delegate sub-field can be used for loading and querying (ie.
- canUseSyntheticSourceDelegateForQuerying() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
-
Returns true if the delegate sub-field can be used for querying only (ie.
- capabilities() - Method in class org.elasticsearch.action.admin.cluster.node.capabilities.NodesCapabilitiesRequest
- capabilities(String...) - Method in class org.elasticsearch.action.admin.cluster.node.capabilities.NodesCapabilitiesRequest
- CAPABILITIES - Static variable in class org.elasticsearch.rest.action.admin.indices.CreateIndexCapabilities
- CAPABILITIES - Static variable in class org.elasticsearch.rest.action.search.SearchCapabilities
- CAPABILITIES_ACTION - Static variable in class org.elasticsearch.rest.action.admin.cluster.RestNodesCapabilitiesAction
- capacity() - Method in class org.elasticsearch.common.util.LongLongHash
-
Return the number of allocated slots to store this hash table.
- capacity() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- capitalize(String) - Static method in class org.elasticsearch.common.Strings
-
Capitalize a
String
, changing the first letter to upper case as perCharacter.toUpperCase(char)
. - capitalize(String) - Static method in class org.elasticsearch.injection.guice.internal.Strings
-
Returns a string that is equivalent to the specified string with its first character converted to uppercase as by
String.toUpperCase(java.util.Locale)
. - captureAsWriteable() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Captures the current thread context as writeable, allowing it to be serialized out later
- captureResponseHeaders() - Method in interface org.elasticsearch.cluster.ClusterStateTaskExecutor.TaskContext
-
Creates a context which captures any response headers (e.g.
- cardinality() - Method in class org.elasticsearch.common.util.BitArray
- cardinality() - Method in class org.elasticsearch.lucene.util.CombinedBitSet
-
This implementation is slow and requires to iterate over all bits to compute the intersection.
- cardinality() - Method in class org.elasticsearch.lucene.util.MatchAllBitSet
- cardinality(long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
-
Returns the current computed cardinality
- cardinality(long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLog
- cardinality(long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractLinearCounting
- cardinality(long) - Method in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- cardinality(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Cardinality
aggregation with the given name. - Cardinality - Interface in org.elasticsearch.search.aggregations.metrics
-
An aggregation that computes approximate numbers of unique terms.
- CardinalityAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- CardinalityAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- CardinalityAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
-
Read from a stream.
- CardinalityAggregationBuilder(CardinalityAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- CardinalityAggregator - Class in org.elasticsearch.search.aggregations.metrics
-
An aggregator that computes approximate counts of unique values.
- CardinalityAggregator(String, ValuesSourceConfig, int, CardinalityAggregatorFactory.ExecutionMode, AggregationContext, Aggregator, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- CardinalityAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics
- CardinalityAggregatorFactory.ExecutionMode - Enum Class in org.elasticsearch.search.aggregations.metrics
- CardinalityAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.metrics
- CardinalityUpperBound - Class in org.elasticsearch.search.aggregations
-
Upper bound of how many
owningBucketOrds
that anAggregator
will have to collect into. - CARTESIAN - Static variable in class org.elasticsearch.lucene.spatial.CoordinateEncoder
-
Encodes arbitrary x/y values in the float space into / from sortable integers
- CartesianShapeDocValuesQuery - Class in org.elasticsearch.lucene.spatial
-
Lucene geometry query for
BinaryShapeDocValuesField
. - CartesianShapeDocValuesQuery(String, ShapeField.QueryRelation, XYGeometry...) - Constructor for class org.elasticsearch.lucene.spatial.CartesianShapeDocValuesQuery
- CartesianShapeIndexer - Class in org.elasticsearch.lucene.spatial
-
Utility class that converts geometries into Lucene-compatible form for indexing in a shape field.
- CartesianShapeIndexer(String) - Constructor for class org.elasticsearch.lucene.spatial.CartesianShapeIndexer
- caseInsensitive() - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- caseInsensitive() - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- caseInsensitive() - Method in class org.elasticsearch.index.query.TermQueryBuilder
- caseInsensitive() - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- caseInsensitive(boolean) - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- caseInsensitive(boolean) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- caseInsensitive(boolean) - Method in class org.elasticsearch.index.query.TermQueryBuilder
- caseInsensitive(boolean) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- caseInsensitivePrefix(String) - Static method in class org.elasticsearch.common.lucene.search.AutomatonQueries
-
Build an automaton query accepting all terms with the specified prefix, ASCII case insensitive.
- caseInsensitivePrefixQuery(Term) - Static method in class org.elasticsearch.common.lucene.search.AutomatonQueries
-
Build an automaton query accepting all terms with the specified prefix, ASCII case insensitive.
- CaseInsensitivePrefixQuery - Class in org.elasticsearch.common.lucene.search
- CaseInsensitivePrefixQuery(Term) - Constructor for class org.elasticsearch.common.lucene.search.CaseInsensitivePrefixQuery
- CaseInsensitivePrefixQuery(Term, int, boolean) - Constructor for class org.elasticsearch.common.lucene.search.CaseInsensitivePrefixQuery
- CaseInsensitivePrefixQuery(Term, int, boolean, MultiTermQuery.RewriteMethod) - Constructor for class org.elasticsearch.common.lucene.search.CaseInsensitivePrefixQuery
- caseInsensitiveTermQuery(Term) - Static method in class org.elasticsearch.common.lucene.search.AutomatonQueries
-
Build an automaton accepting all terms ASCII case insensitive.
- CaseInsensitiveTermQuery - Class in org.elasticsearch.common.lucene.search
-
A case insensitive term query.
- CaseInsensitiveTermQuery(Term) - Constructor for class org.elasticsearch.common.lucene.search.CaseInsensitiveTermQuery
-
Constructs a case insensitive term query.
- caseInsensitiveWildcardQuery(Term) - Static method in class org.elasticsearch.common.lucene.search.AutomatonQueries
-
Build an automaton matching a wildcard pattern, ASCII case insensitive.
- CaseInsensitiveWildcardQuery - Class in org.elasticsearch.common.lucene.search
-
A case insensitive wildcard query.
- CaseInsensitiveWildcardQuery(Term) - Constructor for class org.elasticsearch.common.lucene.search.CaseInsensitiveWildcardQuery
-
Constructs a case insensitive wildcard query.
- CaseInsensitiveWildcardQuery(Term, int, boolean, MultiTermQuery.RewriteMethod) - Constructor for class org.elasticsearch.common.lucene.search.CaseInsensitiveWildcardQuery
- castToDouble(SortedNumericDocValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Wrap the provided
SortedNumericDocValues
instance to cast all values to doubles. - castToLong(SortedNumericDoubleValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Wrap the provided
SortedNumericDoubleValues
instance to cast all values to longs. - category(String) - Static method in class org.elasticsearch.search.suggest.completion.context.ContextBuilder
-
Create a new
CategoryContextMapping
- CATEGORY - Enum constant in enum class org.elasticsearch.search.suggest.completion.context.ContextMapping.Type
- categoryClass - Variable in class org.elasticsearch.common.io.stream.NamedWriteableRegistry.Entry
-
The superclass of a
NamedWriteable
which will be read byNamedWriteableRegistry.Entry.reader
. - CategoryContextMapping - Class in org.elasticsearch.search.suggest.completion.context
-
A
ContextMapping
that uses a simple string as a criteria The suggestions are boosted and/or filtered by their associated category (string) value. - CategoryContextMapping.Builder - Class in org.elasticsearch.search.suggest.completion.context
-
Builder for
CategoryContextMapping
- CategoryQueryContext - Class in org.elasticsearch.search.suggest.completion.context
-
Defines the query context for
CategoryContextMapping
- CategoryQueryContext.Builder - Class in org.elasticsearch.search.suggest.completion.context
- cause - Variable in exception org.elasticsearch.action.ShardOperationFailedException
- cause() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- cause() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The cause for this index creation.
- cause() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction.Request
- cause() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- cause() - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutComposableIndexTemplateAction.Request
- cause() - Method in record class org.elasticsearch.health.Diagnosis.Definition
-
Returns the value of the
cause
record component. - cause() - Method in record class org.elasticsearch.health.node.DiskHealthInfo
-
Returns the value of the
cause
record component. - cause() - Method in record class org.elasticsearch.index.shard.IndexShard.ShardFailure
-
Returns the value of the
cause
record component. - cause(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The cause for this index creation.
- cause(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction.Request
-
The cause for this index template creation.
- cause(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The cause for this index template creation.
- cause(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The cause for this index template creation.
- cause(String) - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutComposableIndexTemplateAction.Request
-
The cause for this index template creation.
- CAUSE_FIELD - Static variable in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- CCS_COLLECT_TELEMETRY - Static variable in class org.elasticsearch.search.SearchService
- CCS_REMOTE_TELEMETRY_STATS - Static variable in class org.elasticsearch.TransportVersions
- CCS_TELEMETRY_FIELD_NAME - Static variable in class org.elasticsearch.action.admin.cluster.stats.CCSTelemetrySnapshot
- CCS_TELEMETRY_STATS - Static variable in class org.elasticsearch.TransportVersions
- CCS_VERSION_CHECK_SETTING - Static variable in class org.elasticsearch.search.SearchService
- CCSSingleCoordinatorSearchProgressListener - Class in org.elasticsearch.action.search
-
Use this progress listener for cross-cluster searches where a single coordinator is used for all clusters (minimize_roundtrips=false).
- CCSSingleCoordinatorSearchProgressListener() - Constructor for class org.elasticsearch.action.search.CCSSingleCoordinatorSearchProgressListener
- CCSTelemetrySnapshot - Class in org.elasticsearch.action.admin.cluster.stats
-
Holds a snapshot of the CCS telemetry statistics from
CCSUsageTelemetry
. - CCSTelemetrySnapshot() - Constructor for class org.elasticsearch.action.admin.cluster.stats.CCSTelemetrySnapshot
-
Creates a new empty stats instance, that will get additional stats added through
CCSTelemetrySnapshot.add(CCSTelemetrySnapshot)
- CCSTelemetrySnapshot(long, long, Map<String, Long>, LongMetric.LongMetricValue, LongMetric.LongMetricValue, LongMetric.LongMetricValue, long, double, long, Map<String, Long>, Map<String, Long>, Map<String, CCSTelemetrySnapshot.PerClusterCCSTelemetry>) - Constructor for class org.elasticsearch.action.admin.cluster.stats.CCSTelemetrySnapshot
-
Creates a new stats instance with the provided info.
- CCSTelemetrySnapshot(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.stats.CCSTelemetrySnapshot
- CCSTelemetrySnapshot.PerClusterCCSTelemetry - Class in org.elasticsearch.action.admin.cluster.stats
- CCSUsage - Class in org.elasticsearch.action.admin.cluster.stats
-
This is a container for telemetry data from an individual cross-cluster search for _search or _async_search (or other search endpoints that use the
TransportSearchAction
such as _msearch). - CCSUsage.Builder - Class in org.elasticsearch.action.admin.cluster.stats
- CCSUsage.PerClusterUsage - Class in org.elasticsearch.action.admin.cluster.stats
- CCSUsageTelemetry - Class in org.elasticsearch.action.admin.cluster.stats
-
Service holding accumulated CCS search usage statistics.
- CCSUsageTelemetry() - Constructor for class org.elasticsearch.action.admin.cluster.stats.CCSUsageTelemetry
- CCSUsageTelemetry.PerClusterCCSTelemetry - Class in org.elasticsearch.action.admin.cluster.stats
-
Telemetry of each remote involved in cross cluster searches
- CCSUsageTelemetry.Result - Enum Class in org.elasticsearch.action.admin.cluster.stats
-
Result of the request execution.
- CCW - Static variable in enum class org.elasticsearch.common.geo.Orientation
- cdf(double) - Method in class org.elasticsearch.search.aggregations.metrics.TDigestState
- Cell(Object) - Constructor for class org.elasticsearch.common.Table.Cell
- Cell(Object, Map<String, String>) - Constructor for class org.elasticsearch.common.Table.Cell
- Cell(Object, Table.Cell) - Constructor for class org.elasticsearch.common.Table.Cell
- CellIdSource - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Base class to help convert
MultiGeoPointValues
toCellIdSource.CellMultiValues
andGeoPointValues
toCellIdSource.CellSingleValue
- CellIdSource(ValuesSource.GeoPoint, int, GeoBoundingBox, LongConsumer) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource
- CellIdSource.CellMultiValues - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Class representing the long-encoded grid-cells belonging to the multi-value geo-doc-values.
- CellIdSource.CellSingleValue - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Class representing the long-encoded grid-cells belonging to the singleton geo-doc-values.
- CellMultiValues(MultiGeoPointValues, int, LongConsumer) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource.CellMultiValues
- CellSingleValue(GeoPointValues, int) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource.CellSingleValue
- centeredModulus(double, double) - Static method in class org.elasticsearch.common.geo.GeoUtils
- CENTIMETERS - Enum constant in enum class org.elasticsearch.common.unit.DistanceUnit
- centroid - Variable in class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues
- centroid - Variable in class org.elasticsearch.script.field.PointDocValuesField
- centroid - Variable in class org.elasticsearch.search.aggregations.metrics.InternalCentroid
- centroid() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- centroid() - Method in interface org.elasticsearch.search.aggregations.metrics.CentroidAggregation
- centroid() - Method in class org.elasticsearch.search.aggregations.metrics.InternalCentroid
- CENTROID - Static variable in class org.elasticsearch.search.aggregations.metrics.InternalCentroid.Fields
- CentroidAggregation - Interface in org.elasticsearch.search.aggregations.metrics
-
Generic interface for both geographic and cartesian centroid aggregations.
- CentroidCalculator - Class in org.elasticsearch.lucene.spatial
-
This class keeps a running Kahan-sum of coordinates that are to be averaged in
TriangleTreeWriter
for use as the centroid of a shape. - CentroidCalculator() - Constructor for class org.elasticsearch.lucene.spatial.CentroidCalculator
- centroidCount() - Method in class org.elasticsearch.search.aggregations.metrics.TDigestState
- centroidDp - Variable in class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues
- centroidFromStream(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalCentroid
- centroidFromStream(StreamInput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- centroids() - Method in class org.elasticsearch.search.aggregations.metrics.TDigestState
- centroidToStream(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalCentroid
- centroidToStream(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- CFE - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- CFS - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- Cgroup(String, BigInteger, String, long, long, OsStats.Cgroup.CpuStat, String, String, String) - Constructor for class org.elasticsearch.monitor.os.OsStats.Cgroup
- changed - Variable in class org.elasticsearch.repositories.RepositoriesService.RegisterRepositoryTask
- changedCustomMetadataSet() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns a set of custom meta data types when any custom metadata for the cluster has changed between the previous cluster state and the new cluster state.
- changes() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Returns observer to use for changes made to the routing nodes
- channel - Variable in class org.elasticsearch.index.translog.BaseTranslogReader
- channel - Variable in class org.elasticsearch.rest.action.RestActionListener
- channel(TransportRequestOptions.Type) - Method in class org.elasticsearch.transport.TcpTransport.NodeChannels
- ChannelActionListener<Response extends TransportResponse> - Class in org.elasticsearch.action.support
- ChannelActionListener(TransportChannel) - Constructor for class org.elasticsearch.action.support.ChannelActionListener
- ChannelFactory - Interface in org.elasticsearch.index.translog
-
only for testing until we have a disk-full FileSystem
- Channels - Class in org.elasticsearch.common.io
- channelScore(DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
- ChannelStats() - Constructor for class org.elasticsearch.transport.TcpChannel.ChannelStats
- CHAR_FILTERS - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Fields
- charAt(int) - Method in class org.elasticsearch.common.settings.SecureString
- CharFilteredText(String, String[]) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.CharFilteredText
- CharFilterFactory - Interface in org.elasticsearch.index.analysis
- charfilters() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.DetailAnalyzeResponse
- charFilters() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- charFilters() - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- CHARS - Enum constant in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
- charset() - Method in record class org.elasticsearch.bootstrap.ConsoleLoader.Console
-
Returns the value of the
charset
record component. - charTermAttr - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- check() - Method in class org.elasticsearch.index.mapper.FieldMapper.Conflicts
- check() - Static method in class org.elasticsearch.SpecialPermission
-
Check that the current stack has
SpecialPermission
access according to theSecurityManager
. - check(boolean, boolean, T) - Method in interface org.elasticsearch.index.mapper.FieldMapper.SerializerCheck
-
Check on whether or not a parameter should be serialized
- check(BootstrapContext) - Method in interface org.elasticsearch.bootstrap.BootstrapCheck
-
Test if the node fails the check.
- check(Metadata.MapOperation, String, Object) - Method in record class org.elasticsearch.script.Metadata.FieldProperty
- checkActiveShardCount() - Method in class org.elasticsearch.action.support.replication.ReplicationOperation
-
Checks whether we can perform a write based on the required active shard count setting.
- checkAllowedInMode(AnalysisMode) - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
-
Checks the wrapped analyzer for the provided restricted
AnalysisMode
and throws an error if the analyzer is not allowed to run in that mode. - checkAndNotify() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
- checkAndNotify() - Method in interface org.elasticsearch.watcher.ResourceWatcher
-
Called periodically by
ResourceWatcherService
so resource watcher can check the resource - checkBlock(ClusterAllocationExplainRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.allocation.TransportClusterAllocationExplainAction
- checkBlock(DesiredBalanceRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.allocation.TransportDeleteDesiredBalanceAction
- checkBlock(DesiredBalanceRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.allocation.TransportGetDesiredBalanceAction
- checkBlock(TransportGetAllocationStatsAction.Request, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.allocation.TransportGetAllocationStatsAction
- checkBlock(AddVotingConfigExclusionsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.configuration.TransportAddVotingConfigExclusionsAction
- checkBlock(ClearVotingConfigExclusionsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.configuration.TransportClearVotingConfigExclusionsAction
- checkBlock(GetDesiredNodesAction.Request, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.desirednodes.TransportGetDesiredNodesAction
- checkBlock(UpdateDesiredNodesRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.desirednodes.TransportUpdateDesiredNodesAction
- checkBlock(ClusterHealthRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
- checkBlock(GetFeatureUpgradeStatusRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.migration.TransportGetFeatureUpgradeStatusAction
- checkBlock(PostFeatureUpgradeRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.migration.TransportPostFeatureUpgradeAction
- checkBlock(PrevalidateNodeRemovalRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportPrevalidateNodeRemovalAction
- checkBlock(CleanupRepositoryRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.repositories.cleanup.TransportCleanupRepositoryAction
- checkBlock(DeleteRepositoryRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.TransportDeleteRepositoryAction
- checkBlock(GetRepositoriesRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
- checkBlock(PutRepositoryRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.TransportPutRepositoryAction
- checkBlock(VerifyRepositoryRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.TransportVerifyRepositoryAction
- checkBlock(ClusterRerouteRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
- checkBlock(ClusterGetSettingsAction.Request, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterGetSettingsAction
- checkBlock(ClusterUpdateSettingsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
-
skip check block if: Only at least one of cluster.blocks.read_only or cluster.blocks.read_only_allow_delete is being cleared (set to null or false).
- checkBlock(ClusterSearchShardsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.shards.TransportClusterSearchShardsAction
- checkBlock(CloneSnapshotRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.TransportCloneSnapshotAction
- checkBlock(CreateSnapshotRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.TransportCreateSnapshotAction
- checkBlock(DeleteSnapshotRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.TransportDeleteSnapshotAction
- checkBlock(GetSnapshottableFeaturesRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.TransportSnapshottableFeaturesAction
- checkBlock(ResetFeatureStateRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.TransportResetFeatureStateAction
- checkBlock(GetSnapshotsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.TransportGetSnapshotsAction
- checkBlock(GetShardSnapshotRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.TransportGetShardSnapshotAction
- checkBlock(RestoreSnapshotRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.TransportRestoreSnapshotAction
- checkBlock(SnapshotsStatusRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportSnapshotsStatusAction
- checkBlock(ClusterStateRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
- checkBlock(DeleteStoredScriptRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportDeleteStoredScriptAction
- checkBlock(GetStoredScriptRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportGetStoredScriptAction
- checkBlock(PutStoredScriptRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportPutStoredScriptAction
- checkBlock(PendingClusterTasksRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.tasks.TransportPendingClusterTasksAction
- checkBlock(GetAliasesRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.alias.get.TransportGetAliasesAction
- checkBlock(IndicesAliasesRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
- checkBlock(CloseIndexRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
- checkBlock(CreateIndexRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.create.AutoCreateAction.TransportAction
- checkBlock(CreateIndexRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
- checkBlock(DeleteDanglingIndexRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.dangling.delete.TransportDeleteDanglingIndexAction
- checkBlock(DeleteIndexRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
- checkBlock(PutMappingRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportAutoPutMappingAction
- checkBlock(PutMappingRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
- checkBlock(OpenIndexRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
- checkBlock(AddIndexBlockRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.readonly.TransportAddIndexBlockAction
- checkBlock(RolloverRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.rollover.TransportRolloverAction
- checkBlock(GetSettingsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.settings.get.TransportGetSettingsAction
- checkBlock(UpdateSettingsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.settings.put.TransportUpdateSettingsAction
- checkBlock(IndicesShardStoresRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.shards.TransportIndicesShardStoresAction
- checkBlock(ResizeRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.shrink.TransportResizeAction
- checkBlock(DeleteIndexTemplateRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
- checkBlock(TransportDeleteComponentTemplateAction.Request, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteComponentTemplateAction
- checkBlock(TransportDeleteComposableIndexTemplateAction.Request, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteComposableIndexTemplateAction
- checkBlock(GetComponentTemplateAction.Request, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetComponentTemplateAction
- checkBlock(GetComposableIndexTemplateAction.Request, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetComposableIndexTemplateAction
- checkBlock(GetIndexTemplatesRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetIndexTemplatesAction
- checkBlock(SimulateIndexTemplateRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.post.TransportSimulateIndexTemplateAction
- checkBlock(SimulateTemplateAction.Request, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.post.TransportSimulateTemplateAction
- checkBlock(PutComponentTemplateAction.Request, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutComponentTemplateAction
- checkBlock(PutIndexTemplateRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
- checkBlock(TransportPutComposableIndexTemplateAction.Request, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutComposableIndexTemplateAction
- checkBlock(DeletePipelineRequest, ClusterState) - Method in class org.elasticsearch.action.ingest.DeletePipelineTransportAction
- checkBlock(GetPipelineRequest, ClusterState) - Method in class org.elasticsearch.action.ingest.GetPipelineTransportAction
- checkBlock(PutPipelineRequest, ClusterState) - Method in class org.elasticsearch.action.ingest.PutPipelineTransportAction
- checkBlock(AcknowledgedRequest.Plain, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.desirednodes.TransportDeleteDesiredNodesAction
- checkBlock(CompletionPersistentTaskAction.Request, ClusterState) - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction.TransportAction
- checkBlock(RemovePersistentTaskAction.Request, ClusterState) - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.TransportAction
- checkBlock(StartPersistentTaskAction.Request, ClusterState) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.TransportAction
- checkBlock(UpdatePersistentTaskStatusAction.Request, ClusterState) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.TransportAction
- checkBlock(Request, ClusterState) - Method in class org.elasticsearch.action.support.master.info.TransportClusterInfoAction
- checkBlock(Request, ClusterState) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- checkBlock(Request, ClusterState) - Method in class org.elasticsearch.action.support.TransportLocalClusterStateAction
- checkCancellation() - Method in class org.elasticsearch.search.rescore.RescoreContext
- checkCancelled(SearchShardTask) - Method in class org.elasticsearch.search.SearchService
- checkCCSVersionCompatibility(Writeable) - Static method in class org.elasticsearch.action.search.TransportSearchHelper
-
Using the 'search.check_ccs_compatibility' setting, clients can ask for an early check that inspects the incoming request and tries to verify that it can be handled by a CCS compliant earlier version, e.g.
- checkCorsSettingForRegex(String) - Static method in class org.elasticsearch.rest.RestUtils
-
Determine if CORS setting is a regex
- checkDecisionState() - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- checkDimensions(int) - Method in class org.elasticsearch.script.field.vectors.BitBinaryDenseVector
- checkDimensions(int) - Method in class org.elasticsearch.script.field.vectors.BitKnnDenseVector
- checkDimensions(int) - Method in class org.elasticsearch.script.field.vectors.BitMultiDenseVector
- checkDimensions(int) - Method in interface org.elasticsearch.script.field.vectors.DenseVector
- checkDimensions(int) - Method in interface org.elasticsearch.script.field.vectors.MultiDenseVector
- checkDimensions(int, int) - Static method in interface org.elasticsearch.script.field.vectors.DenseVector
- checkDimensions(int, int) - Static method in interface org.elasticsearch.script.field.vectors.MultiDenseVector
- checkDimensions(Integer, int) - Method in enum class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.ElementType
- CheckedBiConsumer<T,
U, E extends Exception> - Interface in org.elasticsearch.common -
A
BiConsumer
-like interface which allows throwing checked exceptions. - CheckedBiFunction<T,
U, R, E extends Exception> - Interface in org.elasticsearch.common -
A
BiFunction
-like interface which allows throwing checked exceptions. - CheckedIntFunction<T,
E extends Exception> - Interface in org.elasticsearch.common - CheckedSupplier<R,
E extends Exception> - Interface in org.elasticsearch.common -
A
Supplier
-like interface which allows throwing checked exceptions. - checkForCancel() - Method in class org.elasticsearch.common.util.CancellableThreads
- checkForDeprecatedVersion(String, Settings) - Static method in class org.elasticsearch.index.analysis.Analysis
- checkForDuplicatePriorities(Collection<PassThroughObjectMapper>) - Static method in class org.elasticsearch.index.mapper.PassThroughObjectMapper
-
Checks the passed objects for duplicate or negative priorities.
- checkForDuplicatesAndAdd(String, Runnable) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverConfiguration.ValueParser
- checkForFailedPluginRemovals(Path) - Static method in class org.elasticsearch.plugins.PluginsUtils
-
Check for the existence of a marker file that indicates any plugins are in a garbage state from a failed attempt to remove the plugin.
- checkForNull(T, Object, Dependency<?>) - Method in class org.elasticsearch.injection.guice.internal.Errors
-
Returns
value
if it is non-null allowed to be null. - checkFrequencies(long, long, long, long, String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
- checkFrequencyValidity(long, long, long, long, String) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.SignificanceHeuristic
- checkGlobalBlock(ClusterState) - Static method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- checkGlobalBlock(ClusterState) - Static method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- checkGlobalBlock(ClusterState, ReloadAnalyzersRequest) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportReloadAnalyzersAction
- checkGlobalBlock(ClusterState, ClearIndicesCacheRequest) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
- checkGlobalBlock(ClusterState, AnalyzeIndexDiskUsageRequest) - Method in class org.elasticsearch.action.admin.indices.diskusage.TransportAnalyzeIndexDiskUsageAction
- checkGlobalBlock(ClusterState, ForceMergeRequest) - Method in class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
- checkGlobalBlock(ClusterState, RecoveryRequest) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- checkGlobalBlock(ClusterState, IndicesSegmentsRequest) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
- checkGlobalBlock(ClusterState, FieldUsageStatsRequest) - Method in class org.elasticsearch.action.admin.indices.stats.TransportFieldUsageAction
- checkGlobalBlock(ClusterState, IndicesStatsRequest) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
- checkGlobalBlock(ClusterState, ValidateQueryRequest) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- checkGlobalBlock(ClusterState, Request) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Executes a global block check before polling the cluster state.
- checkGlobalBlock(ClusterState, Request) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- checkHealthChanged() - Method in class org.elasticsearch.health.node.tracker.HealthTracker
-
Determine the current health info for this tracker and check if it has changed from the last reported value.
- checkIdle(IndexShard, long) - Method in class org.elasticsearch.indices.IndexingMemoryController
-
ask this shard to check now whether it is inactive, and reduces its indexing buffer if so.
- checkIfSortedDocsIsApplicable(IndexReader, MappedFieldType) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSource
-
Returns true if a
SortedDocsProducer
should be used to optimize the execution. - checkIncomingMergeType(FieldMapper) - Method in class org.elasticsearch.index.mapper.FieldMapper
- checkIndex(PrintStream) - Method in class org.elasticsearch.index.store.Store
-
Checks and returns the status of the existing index in this store.
- checkIndexableLength(BytesRef) - Static method in class org.elasticsearch.common.lucene.BytesRefs
-
Checks that the input is not longer than
IndexWriter.MAX_TERM_LENGTH
- checkIndexSplitAllowed() - Method in class org.elasticsearch.cluster.routing.IndexRouting
-
Check if the _split index operation is allowed for an index
- checkIndexSplitAllowed() - Method in class org.elasticsearch.cluster.routing.IndexRouting.ExtractFromSource
- checkIndexTime() - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- checkIndexTime(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- checkIntegrity() - Method in class org.elasticsearch.index.codec.tsdb.ES87TSDBDocValuesProducer
- checkIntegrity() - Method in class org.elasticsearch.index.codec.vectors.ES813Int8FlatVectorFormat.ES813FlatVectorReader
- checkIntegrity() - Method in class org.elasticsearch.index.codec.vectors.ES816BinaryQuantizedVectorsReader
- checkIntegrity(StoreFileMetadata, Directory) - Static method in class org.elasticsearch.index.store.Store
- checkIntegrityNoException(StoreFileMetadata) - Method in class org.elasticsearch.index.store.Store
- checkIntegrityNoException(StoreFileMetadata, Directory) - Static method in class org.elasticsearch.index.store.Store
- checkMaxSize(int) - Method in class org.elasticsearch.script.AbstractFieldScript
-
Check if the we can add another value to the list of values.
- checkModelConfig(Model, ActionListener<Model>) - Method in interface org.elasticsearch.inference.InferenceService
-
Optionally test the new model configuration in the inference service.
- checkNegativeBoost(float) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- checkNodeRoleRelatedIssues(IndexMetadata, List<NodeAllocationResult>, ClusterState, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
-
Generates a list of diagnoses for common problems that keep a shard from allocating to nodes depending on their role; a very common example of such a case are data tiers.
- checkNodesWithRoleAtShardLimit(IndexMetadata, ClusterState, List<NodeAllocationResult>, Set<DiscoveryNode>, String) - Method in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- checkNoFormat(String) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Validate the provided
format
is null. - checkNoRemainingFields(String, Map<?, ?>) - Static method in class org.elasticsearch.index.mapper.MappingParser
-
Verify that there are no remaining fields in the provided map that contained mapped fields
- checkNoRemainingFields(Map<?, ?>, String) - Static method in class org.elasticsearch.index.mapper.MappingParser
-
Verify that there are no remaining fields in the provided map that contained mapped fields
- checkNotEnoughNodesWithRole(List<NodeAllocationResult>, String) - Method in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- checkNoTimeZone(ZoneId) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Validate the provided
timeZone
is null. - checkNotScoped() - Method in class org.elasticsearch.injection.guice.internal.AbstractBindingBuilder
- checkNotTargetted() - Method in class org.elasticsearch.injection.guice.internal.AbstractBindingBuilder
- checkOperationLimits(Request) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- checkOperationLimits(Request) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- checkParentLimit(long, String) - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
-
Checks whether the parent breaker has been tripped
- CHECKPOINT_FILE_NAME - Static variable in class org.elasticsearch.index.translog.Translog
- CHECKPOINT_SUFFIX - Static variable in class org.elasticsearch.index.translog.Translog
- CheckpointState(long, long, boolean, boolean) - Constructor for class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
- CheckpointState(StreamInput) - Constructor for class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
- checkPrecisionRange(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Checks that the precision is within range supported by elasticsearch - between 1 and 12 Returns the precision value if it is in the range and throws an IllegalArgumentException if it is outside the range.
- checkPrecisionRange(int) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
-
Assert the precision value is within the allowed range, and return it if ok, or throw.
- checkPrimaryLimits(Request, boolean, boolean) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- checkPrimaryLimits(Request, boolean, boolean) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- checkReplicaLimits(ReplicaRequest) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- checkReplicaLimits(ReplicaRequest) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- checkRequestBlock(ClusterState, ReloadAnalyzersRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportReloadAnalyzersAction
- checkRequestBlock(ClusterState, ClearIndicesCacheRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
- checkRequestBlock(ClusterState, AnalyzeIndexDiskUsageRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.diskusage.TransportAnalyzeIndexDiskUsageAction
- checkRequestBlock(ClusterState, ForceMergeRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
- checkRequestBlock(ClusterState, RecoveryRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- checkRequestBlock(ClusterState, IndicesSegmentsRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
- checkRequestBlock(ClusterState, FieldUsageStatsRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.stats.TransportFieldUsageAction
- checkRequestBlock(ClusterState, IndicesStatsRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
- checkRequestBlock(ClusterState, ValidateQueryRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- checkRequestBlock(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- checkRequestBlock(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
- checkRequestBlock(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- checkRequestBlock(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- checkRequestBlock(ClusterState, Request, String[]) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Executes a global request-level check before polling the cluster state.
- checkRequestBlock(ClusterState, Request, String[]) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- checkRestrictedLoggers(Settings) - Static method in class org.elasticsearch.common.logging.Loggers
- checkSegmentInfoIntegrity(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
- checkShardLimitForFrozenNodes(int, int, int, DiscoveryNodes, Metadata) - Static method in class org.elasticsearch.indices.ShardLimitValidator
-
This method checks whether there is enough room in the cluster to add the given number of shards with the given number of replicas without exceeding the "cluster.max_shards_per_node_frozen" setting for _frozen_ nodes.
- checkShardLimitForNormalNodes(int, int, int, DiscoveryNodes, Metadata) - Static method in class org.elasticsearch.indices.ShardLimitValidator
-
This method checks whether there is enough room in the cluster to add the given number of shards with the given number of replicas without exceeding the "cluster.max_shards_per_node" setting for _normal_ nodes.
- checksum() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns file md5 checksum provided by
Store
- checksum() - Method in class org.elasticsearch.index.store.StoreFileMetadata
-
Returns a string representation of the files checksum.
- ChecksumBlobStoreFormat<T> - Class in org.elasticsearch.repositories.blobstore
-
Snapshot metadata file format used in v2.0 and above
- ChecksumBlobStoreFormat(String, String, CheckedBiFunction<String, XContentParser, T, IOException>, Function<T, ? extends ToXContent>) - Constructor for class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- ChecksumBlobStoreFormat(String, String, CheckedBiFunction<String, XContentParser, T, IOException>, CheckedBiFunction<String, XContentParser, T, IOException>, Function<T, ? extends ToXContent>) - Constructor for class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- checksummedStream(ByteBuffer, long, int, BufferedChecksumStreamInput) - Method in class org.elasticsearch.index.translog.BaseTranslogReader
-
reads an operation at the given position and returns it.
- checkSupported(RestRequest.Method, String, Set<String>, Set<String>, RestApiVersion) - Method in class org.elasticsearch.rest.RestController
- checkVectorBounds(float[]) - Method in enum class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.ElementType
- checkWriteable(Object) - Static method in class org.elasticsearch.common.io.stream.StreamOutput
- childBindingAlreadySet(Key<?>) - Method in class org.elasticsearch.injection.guice.internal.Errors
- childBytes(XContentParser) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Returns the contents of an object as an unparsed BytesReference This is useful for things like mappings where we're copying bytes around but don't actually need to parse their contents, and so avoids building large maps of maps unnecessarily
- ChildMemoryCircuitBreaker - Class in org.elasticsearch.common.breaker
-
Breaker that will check a parent's when incrementing
- ChildMemoryCircuitBreaker(LongCounter, BreakerSettings, Logger, HierarchyCircuitBreakerService, String) - Constructor for class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
-
Create a circuit breaker that will break if the number of estimated bytes grows above the limit.
- children - Variable in class org.elasticsearch.index.query.InnerHitContextBuilder
- children(OperationPurpose) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Lists all child containers under this container.
- children(OperationPurpose) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- children(OperationPurpose) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- childTasks() - Method in record class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup
-
Returns the value of the
childTasks
record component. - ChiSquare - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- ChiSquare(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ChiSquare
- ChiSquare(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ChiSquare
-
Read from a stream.
- ChiSquare.ChiSquareBuilder - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- ChiSquareBuilder(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ChiSquare.ChiSquareBuilder
- Chunk(String, BytesReference) - Constructor for record class org.elasticsearch.inference.ChunkedInferenceServiceResults.Chunk
-
Creates an instance of a
Chunk
record class. - CHUNK_SENTENCE_OVERLAP_SETTING_ADDED - Static variable in class org.elasticsearch.TransportVersions
- CHUNK_SIZE_SETTING - Static variable in class org.elasticsearch.repositories.fs.FsRepository
- chunked(RestStatus, ChunkedRestResponseBodyPart, Releasable) - Static method in class org.elasticsearch.rest.RestResponse
- ChunkedBlobOutputStream<T> - Class in org.elasticsearch.repositories.blobstore
-
Base class for doing chunked writes to a blob store.
- ChunkedBlobOutputStream(BigArrays, long) - Constructor for class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
- ChunkedBroadcastResponse - Class in org.elasticsearch.action.support.broadcast
- ChunkedBroadcastResponse(int, int, int, List<DefaultShardOperationFailedException>) - Constructor for class org.elasticsearch.action.support.broadcast.ChunkedBroadcastResponse
- ChunkedBroadcastResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.broadcast.ChunkedBroadcastResponse
- chunkedContent() - Method in class org.elasticsearch.rest.RestResponse
- chunkedInfer(Model, String, List<String>, Map<String, Object>, InputType, ChunkingOptions, TimeValue, ActionListener<List<ChunkedInferenceServiceResults>>) - Method in interface org.elasticsearch.inference.InferenceService
-
Chunk long text according to
chunkingOptions
or the model defaults ifchunkingOptions
contains unset values. - ChunkedInferenceServiceResults - Interface in org.elasticsearch.inference
- ChunkedInferenceServiceResults.Chunk - Record Class in org.elasticsearch.inference
-
A chunk of inference results containing matched text and the bytes reference.
- ChunkedLoggingStream - Class in org.elasticsearch.common.logging
-
An
OutputStream
which Gzip-compresses the written data, Base64-encodes it, and writes it in fixed-size chunks to a logger. - ChunkedRestResponseBodyPart - Interface in org.elasticsearch.rest
-
A body (or a part thereof) of an HTTP response that uses the
chunked
transfer-encoding. - ChunkedToXContent - Interface in org.elasticsearch.common.xcontent
-
An alternative to
ToXContent
allowing for progressive serialization by creating anIterator
ofToXContent
chunks. - ChunkedToXContentBuilder - Class in org.elasticsearch.common.xcontent
-
A fluent builder to create
Iterator<ToXContent>
objects - ChunkedToXContentBuilder(ToXContent.Params) - Constructor for class org.elasticsearch.common.xcontent.ChunkedToXContentBuilder
- ChunkedToXContentHelper - Enum Class in org.elasticsearch.common.xcontent
- ChunkedToXContentObject - Interface in org.elasticsearch.common.xcontent
-
Chunked equivalent of
ToXContentObject
that serializes as a full object. - ChunkedZipResponse - Class in org.elasticsearch.rest
-
A REST response with
Content-type: application/zip
to which the caller can write entries in an asynchronous and streaming fashion. - ChunkedZipResponse(String, RestChannel, Releasable) - Constructor for class org.elasticsearch.rest.ChunkedZipResponse
- CHUNKING_SETTINGS - Static variable in class org.elasticsearch.inference.ModelConfigurations
- ChunkingOptions - Record Class in org.elasticsearch.inference
- ChunkingOptions(Integer, Integer) - Constructor for record class org.elasticsearch.inference.ChunkingOptions
-
Creates an instance of a
ChunkingOptions
record class. - ChunkingSettings - Interface in org.elasticsearch.inference
- ChunkingStrategy - Enum Class in org.elasticsearch.inference
- chunksAsMatchedTextAndByteReference(XContent) - Method in interface org.elasticsearch.inference.ChunkedInferenceServiceResults
-
Implementations of this function serialize their embeddings to
BytesReference
for storage in semantic text fields. - chunkSize() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Returns data file chunk size.
- chunkSize() - Method in class org.elasticsearch.repositories.fs.FsRepository
- CIDRUtils - Class in org.elasticsearch.common.network
- CIRCUIT_BREAKER_LIMIT_SETTING - Static variable in class org.elasticsearch.indices.breaker.BreakerSettings
- CIRCUIT_BREAKER_OVERHEAD_SETTING - Static variable in class org.elasticsearch.indices.breaker.BreakerSettings
- CIRCUIT_BREAKER_TYPE - Static variable in class org.elasticsearch.indices.breaker.BreakerSettings
- CIRCUIT_BREAKER_TYPE_ATTRIBUTE - Static variable in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
- circuitBreak(String, long) - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
-
Method used to trip the breaker, delegates to the parent to determine whether to trip the breaker or not
- circuitBreak(String, long) - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
-
Trip the circuit breaker
- circuitBreak(String, long) - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- CircuitBreaker - Interface in org.elasticsearch.common.breaker
-
Interface for an object that can be incremented, breaking after some configured limit has been reached.
- CircuitBreaker.Durability - Enum Class in org.elasticsearch.common.breaker
- CircuitBreaker.Type - Enum Class in org.elasticsearch.common.breaker
- circuitBreakerConsumer - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource
- CircuitBreakerMetrics - Class in org.elasticsearch.indices.breaker
-
A class collecting trip count metrics for circuit breakers (parent, field data, request, in flight requests and custom child circuit breakers).
- CircuitBreakerMetrics(TelemetryProvider) - Constructor for class org.elasticsearch.indices.breaker.CircuitBreakerMetrics
- CircuitBreakerPlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
implementations to add custom circuit breakers - circuitBreakerService(CircuitBreakerService) - Method in class org.elasticsearch.indices.IndicesServiceBuilder
- CircuitBreakerService - Class in org.elasticsearch.indices.breaker
-
Interface for Circuit Breaker services, which provide breakers to classes that load field data.
- CircuitBreakerService() - Constructor for class org.elasticsearch.indices.breaker.CircuitBreakerService
- CircuitBreakerStats - Class in org.elasticsearch.indices.breaker
-
Class encapsulating stats about the circuit breaker
- CircuitBreakerStats(String, long, long, double, long) - Constructor for class org.elasticsearch.indices.breaker.CircuitBreakerStats
- CircuitBreakerStats(StreamInput) - Constructor for class org.elasticsearch.indices.breaker.CircuitBreakerStats
- CircuitBreakingException - Exception in org.elasticsearch.common.breaker
-
Exception thrown when the circuit breaker trips
- CircuitBreakingException(String, long, long, CircuitBreaker.Durability) - Constructor for exception org.elasticsearch.common.breaker.CircuitBreakingException
- CircuitBreakingException(String, CircuitBreaker.Durability) - Constructor for exception org.elasticsearch.common.breaker.CircuitBreakingException
- CircuitBreakingException(StreamInput) - Constructor for exception org.elasticsearch.common.breaker.CircuitBreakingException
- clampToNanosRange(Instant) - Static method in class org.elasticsearch.common.time.DateUtils
-
Returns an instant that is with valid nanosecond resolution.
- Classes - Class in org.elasticsearch.common
- Classes(long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.Classes
- Classes(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.Classes
- CLASSIC - Enum constant in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- CLASSIFICATION - Enum constant in enum class org.elasticsearch.inference.InputType
- className() - Method in record class org.elasticsearch.plugins.scanners.PluginInfo
-
Returns the value of the
className
record component. - ClassPermission - Class in org.elasticsearch.script
-
Checked by scripting engines to allow loading a java class.
- ClassPermission(String) - Constructor for class org.elasticsearch.script.ClassPermission
-
Creates a new ClassPermission object.
- ClassPermission(String, String) - Constructor for class org.elasticsearch.script.ClassPermission
-
Creates a new ClassPermission object.
- clauses() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- clauses() - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
- CLEAN - Enum constant in enum class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
- CLEAN_FILES - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- CLEAN_WITH_CORRUPTED_MARKER - Enum constant in enum class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
- CleanableResponseHandler<T extends TransportResponse> - Class in org.elasticsearch.cluster.coordination
-
Combines an ActionListenerResponseHandler with an ActionListener.runAfter action, but with an explicit type so that tests that simulate reboots can release resources without invoking the listener.
- CleanableResponseHandler(ActionListener<? super T>, Writeable.Reader<T>, Executor, Runnable) - Constructor for class org.elasticsearch.cluster.coordination.CleanableResponseHandler
- cleanCaches() - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
- cleanCaches() - Method in interface org.elasticsearch.cluster.routing.allocation.ExistingShardsAllocator
-
Called when this node becomes the elected master and when it stops being the elected master, so that implementations can clean up any in-flight activity from an earlier mastership.
- cleanCaches() - Method in class org.elasticsearch.gateway.GatewayAllocator
- cleanFiles(int, long, Store.MetadataSnapshot, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- cleanFiles(int, long, Store.MetadataSnapshot, ActionListener<Void>) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
After all source files has been sent over, this command is sent to the target so it can clean any local files that are not part of the source store
- cleanFiles(int, long, Store.MetadataSnapshot, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- cleanLuceneIndex(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
-
This method removes all lucene files from the given directory.
- cleanTruncate(String, int) - Static method in class org.elasticsearch.common.Strings
-
Truncates string to a length less than length.
- cleanup(long, IndexVersion, ActionListener<DeleteResult>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Runs cleanup actions on the repository.
- cleanup(Runnable) - Method in class org.elasticsearch.index.reindex.ClientScrollableHitSource
- cleanup(Runnable) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource
-
Called after the process has been totally finished to clean up any resources the process needed like remote connections.
- cleanupAndVerify(String, Store.MetadataSnapshot) - Method in class org.elasticsearch.index.store.Store
-
This method deletes every file in this store that is not contained in the given source meta data or is a legacy checksum file.
- cleanUpFeature(Collection<SystemIndexDescriptor>, Collection<? extends IndexPatternMatcher>, String, ClusterService, Client, ActionListener<ResetFeatureStateResponse.ResetFeatureStateStatus>) - Static method in class org.elasticsearch.indices.SystemIndices.Feature
-
Clean up the state of a feature
- cleanUpFeature(ClusterService, Client, ActionListener<ResetFeatureStateResponse.ResetFeatureStateStatus>) - Method in interface org.elasticsearch.plugins.SystemIndexPlugin
-
Cleans up the state of the feature by deleting system indices and associated indices.
- cleanupOldFiles(long, Path[]) - Method in class org.elasticsearch.gateway.MetadataStateFormat
-
Clean ups all state files not matching passed generation.
- cleanupRepository(CleanupRepositoryRequest, ActionListener<CleanupRepositoryResponse>) - Method in class org.elasticsearch.client.internal.ClusterAdminClient
- CleanupRepositoryRequest - Class in org.elasticsearch.action.admin.cluster.repositories.cleanup
- CleanupRepositoryRequest(TimeValue, TimeValue, String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryRequest
- CleanupRepositoryRequest(TimeValue, TimeValue, StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryRequest
- CleanupRepositoryRequestBuilder - Class in org.elasticsearch.action.admin.cluster.repositories.cleanup
- CleanupRepositoryRequestBuilder(ElasticsearchClient, TimeValue, TimeValue, String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryRequestBuilder
- CleanupRepositoryResponse - Class in org.elasticsearch.action.admin.cluster.repositories.cleanup
- CleanupRepositoryResponse() - Constructor for class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryResponse
- CleanupRepositoryResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryResponse
- CleanupRepositoryResponse(RepositoryCleanupResult) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryResponse
- cleanupsInProgressCount() - Method in record class org.elasticsearch.cluster.ClusterSnapshotStats
-
Returns the value of the
cleanupsInProgressCount
record component. - clear() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Clears all info flags.
- clear() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Clears all info flags.
- clear() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Clears all the request flags.
- clear() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Clears all stats flags.
- clear() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
-
Clears all the request flags.
- clear() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- clear() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Do not include any data
- clear() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
Clears all stats.
- clear() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
Clears all stats.
- clear() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
-
Clears all stats.
- clear() - Method in class org.elasticsearch.action.ResultDeduplicator
-
Remove all tracked requests from this instance so that the first time
ResultDeduplicator.executeOnce(T, org.elasticsearch.action.ActionListener<R>, java.util.function.BiConsumer<T, org.elasticsearch.action.ActionListener<R>>)
is invoked with any request it triggers an actual request execution. - clear() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceReconciler
- clear() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.NodeAllocationOrdering
- clear() - Method in class org.elasticsearch.common.collect.EvictingQueue
- clear() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- clear() - Method in class org.elasticsearch.common.util.CopyOnFirstWriteMap
- clear() - Method in class org.elasticsearch.common.util.ObjectArrayPriorityQueue
-
Removes all entries from the PriorityQueue.
- clear() - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache
-
Clears all the field data stored cached in on this index.
- clear() - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
- clear() - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
- clear() - Method in class org.elasticsearch.index.query.TermsQueryBuilder.BinaryValues
- clear() - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- clear() - Method in class org.elasticsearch.lucene.analysis.miscellaneous.DisableGraphAttributeImpl
- clear() - Method in class org.elasticsearch.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- clear() - Method in class org.elasticsearch.script.CtxMap
-
Clear entire map.
- clear() - Method in class org.elasticsearch.script.DynamicMap
- clear() - Method in class org.elasticsearch.search.lookup.FieldLookup
- clear() - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- clear() - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- clear(int) - Method in class org.elasticsearch.lucene.util.CombinedBitSet
- clear(int) - Method in class org.elasticsearch.lucene.util.MatchAllBitSet
- clear(int, int) - Method in class org.elasticsearch.lucene.util.CombinedBitSet
- clear(int, int) - Method in class org.elasticsearch.lucene.util.MatchAllBitSet
- clear(long) - Method in class org.elasticsearch.common.util.BitArray
-
Clear the
index
th bit. - clear(String) - Method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- clear(String) - Method in class org.elasticsearch.index.cache.IndexCache
- clear(String) - Method in class org.elasticsearch.index.cache.query.DisabledQueryCache
- clear(String) - Method in class org.elasticsearch.index.cache.query.IndexQueryCache
- clear(String) - Method in interface org.elasticsearch.index.cache.query.QueryCache
- clear(String) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache
-
Clears all the field data stored cached in on this index for the specified field name.
- clear(String) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
- CLEAR_SCROLL_CONTEXTS_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- clearCache(ClearIndicesCacheRequest) - Method in class org.elasticsearch.client.internal.IndicesAdminClient
- clearCache(ClearIndicesCacheRequest, ActionListener<BroadcastResponse>) - Method in class org.elasticsearch.client.internal.IndicesAdminClient
- clearCaches(boolean, boolean, String...) - Method in class org.elasticsearch.index.IndexService
-
Clears the caches for the given shard id if the shard is still allocated on this node
- clearCandidateGenerators() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Clear the candidate generators.
- clearCurrentNodes() - Method in class org.elasticsearch.cluster.coordination.FollowersChecker
-
Clear the set of known nodes, stopping all checks.
- clearField(String) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
- clearFiles() - Method in class org.elasticsearch.index.engine.SegmentsStats
- clearIndex(String) - Method in class org.elasticsearch.indices.IndicesQueryCache
-
Clear all entries that belong to the given index.
- clearIndexShardCache(ShardId, boolean, boolean, boolean, String...) - Method in class org.elasticsearch.indices.IndicesService
-
Clears the caches for the given shard id if the shard is still allocated on this node
- ClearIndicesCacheRequest - Class in org.elasticsearch.action.admin.indices.cache.clear
- ClearIndicesCacheRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- ClearIndicesCacheRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- ClearIndicesCacheRequestBuilder - Class in org.elasticsearch.action.admin.indices.cache.clear
- ClearIndicesCacheRequestBuilder(ElasticsearchClient) - Constructor for class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
- clearIsApplyingClusterState() - Static method in class org.elasticsearch.cluster.service.ClusterApplierService
- clearRemoteShardRequestDeduplicator() - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
Clears out
ShardStateAction.remoteShardStateUpdateDeduplicator
. - clearRepositoriesStatsArchive(long) - Method in class org.elasticsearch.repositories.RepositoriesService
- clearRescorers() - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Clears all rescorers from the builder.
- clearRescorers() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- clearScroll(String, Runnable) - Method in class org.elasticsearch.index.reindex.ClientScrollableHitSource
- clearScroll(String, Runnable) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource
-
Called to clear a scroll id.
- clearScroll(ClearScrollRequest) - Method in interface org.elasticsearch.client.internal.Client
-
Clears the search contexts associated with specified scroll ids.
- clearScroll(ClearScrollRequest) - Method in class org.elasticsearch.client.internal.support.AbstractClient
- clearScroll(ClearScrollRequest, ActionListener<ClearScrollResponse>) - Method in interface org.elasticsearch.client.internal.Client
-
Clears the search contexts associated with specified scroll ids.
- clearScroll(ClearScrollRequest, ActionListener<ClearScrollResponse>) - Method in class org.elasticsearch.client.internal.support.AbstractClient
- ClearScrollController - Class in org.elasticsearch.action.search
- ClearScrollRequest - Class in org.elasticsearch.action.search
- ClearScrollRequest() - Constructor for class org.elasticsearch.action.search.ClearScrollRequest
- ClearScrollRequest(StreamInput) - Constructor for class org.elasticsearch.action.search.ClearScrollRequest
- ClearScrollRequestBuilder - Class in org.elasticsearch.action.search
- ClearScrollRequestBuilder(ElasticsearchClient) - Constructor for class org.elasticsearch.action.search.ClearScrollRequestBuilder
- ClearScrollResponse - Class in org.elasticsearch.action.search
- ClearScrollResponse(boolean, int) - Constructor for class org.elasticsearch.action.search.ClearScrollResponse
- clearState() - Method in class org.elasticsearch.watcher.FileWatcher
-
Clears any state with the FileWatcher, making all files show up as new
- clearTraceContext() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
When using a
Tracer
, sometimes you need to start a span completely unrelated to any current span. - clearTrackedNodes() - Method in class org.elasticsearch.cluster.coordination.LagDetector
- clearVotingConfigExclusions() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.Builder
- ClearVotingConfigExclusionsRequest - Class in org.elasticsearch.action.admin.cluster.configuration
-
A request to clear the voting config exclusions from the cluster state, optionally waiting for these nodes to be removed from the cluster first.
- ClearVotingConfigExclusionsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsRequest
- ClearVotingConfigExclusionsRequest(TimeValue) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsRequest
-
Construct a request to remove all the voting config exclusions from the cluster state.
- client - Variable in class org.elasticsearch.action.ActionRequestBuilder
- client - Variable in class org.elasticsearch.action.ActionRequestLazyBuilder
- client - Variable in class org.elasticsearch.client.internal.ClusterAdminClient
- client - Variable in class org.elasticsearch.client.internal.IndicesAdminClient
- client - Variable in class org.elasticsearch.cluster.metadata.TemplateUpgradeService
- client - Variable in class org.elasticsearch.index.query.QueryRewriteContext
- client - Variable in class org.elasticsearch.ingest.Processor.Parameters
-
Provides access to the node client
- client() - Method in record class org.elasticsearch.inference.InferenceServiceExtension.InferenceServiceFactoryContext
-
Returns the value of the
client
record component. - client() - Method in class org.elasticsearch.node.Node
-
A client that can be used to execute actions (operations) against the cluster.
- client() - Method in record class org.elasticsearch.node.PluginServiceInstances
-
Returns the value of the
client
record component. - client() - Method in interface org.elasticsearch.plugins.Plugin.PluginServices
-
A client to make requests to the system
- client(Client) - Method in class org.elasticsearch.indices.IndicesServiceBuilder
- Client - Interface in org.elasticsearch.client.internal
-
A client provides a one stop interface for performing actions/operations against the cluster.
- CLIENT - Enum constant in enum class org.elasticsearch.transport.InboundDecoder.ChannelType
- CLIENT_TYPE_SETTING_S - Static variable in interface org.elasticsearch.client.internal.Client
- ClientScrollableHitSource - Class in org.elasticsearch.index.reindex
-
A scrollable source of hits from a Client instance.
- ClientScrollableHitSource(Logger, BackoffPolicy, ThreadPool, Runnable, Consumer<ScrollableHitSource.AsyncResponse>, Consumer<Exception>, ParentTaskAssigningClient, SearchRequest) - Constructor for class org.elasticsearch.index.reindex.ClientScrollableHitSource
- clientStats() - Method in record class org.elasticsearch.http.HttpStats
-
Returns the value of the
clientStats
record component. - ClientStats(int, String, String, String, String, String, String, long, long, long, long, long) - Constructor for record class org.elasticsearch.http.HttpStats.ClientStats
-
Creates an instance of a
ClientStats
record class. - CLOCKWISE - Static variable in enum class org.elasticsearch.common.geo.Orientation
- clone() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- clone() - Method in class org.elasticsearch.common.lucene.store.BytesReferenceIndexInput
- clone() - Method in class org.elasticsearch.common.settings.SecureString
-
Returns a new copy of this object that is backed by its own char array.
- clone() - Method in class org.elasticsearch.index.codec.postings.ES812PostingsFormat.IntBlockTermState
- clone() - Method in class org.elasticsearch.index.engine.ElasticsearchConcurrentMergeScheduler
- clone() - Method in class org.elasticsearch.script.Metadata
- clone(long, BigArrays) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
-
Clone the data structure at the given bucket
- clone(List<CompoundRetrieverBuilder.RetrieverSource>, List<QueryBuilder>) - Method in class org.elasticsearch.search.retriever.CompoundRetrieverBuilder
-
Returns a clone of the original retriever, replacing the sub-retrievers with the provided
newChildRetrievers
and the filters with thenewPreFilterQueryBuilders
. - clone(RetrieverBuilder) - Method in class org.elasticsearch.search.retriever.RetrieverBuilderWrapper
- CLONE - Enum constant in enum class org.elasticsearch.action.admin.indices.shrink.ResizeType
- cloneLocalPeerRecoveryRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
- cloneLocalPeerRecoveryRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.shard.IndexShard
- CloneShardsCalculator() - Constructor for class org.elasticsearch.action.admin.indices.shrink.ResizeNumberOfShardsCalculator.CloneShardsCalculator
- cloneShardSnapshot(SnapshotId, SnapshotId, RepositoryShardId, ShardGeneration, ActionListener<ShardSnapshotResult>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- cloneShardSnapshot(SnapshotId, SnapshotId, RepositoryShardId, ShardGeneration, ActionListener<ShardSnapshotResult>) - Method in class org.elasticsearch.repositories.FilterRepository
- cloneShardSnapshot(SnapshotId, SnapshotId, RepositoryShardId, ShardGeneration, ActionListener<ShardSnapshotResult>) - Method in class org.elasticsearch.repositories.InvalidRepository
- cloneShardSnapshot(SnapshotId, SnapshotId, RepositoryShardId, ShardGeneration, ActionListener<ShardSnapshotResult>) - Method in interface org.elasticsearch.repositories.Repository
-
Clones a shard snapshot.
- cloneShardSnapshot(SnapshotId, SnapshotId, RepositoryShardId, ShardGeneration, ActionListener<ShardSnapshotResult>) - Method in class org.elasticsearch.repositories.UnknownTypeRepository
- cloneSnapshot(CloneSnapshotRequest, ActionListener<Void>) - Method in class org.elasticsearch.snapshots.SnapshotsService
- cloneSnapshot(CloneSnapshotRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.client.internal.ClusterAdminClient
- CloneSnapshotRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.clone
- CloneSnapshotRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
- CloneSnapshotRequest(TimeValue, String, String, String, String[]) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
-
Creates a clone snapshot request for cloning the given source snapshot's indices into the given target snapshot on the given repository.
- CloneSnapshotRequestBuilder - Class in org.elasticsearch.action.admin.cluster.snapshots.clone
- CloneSnapshotRequestBuilder(ElasticsearchClient, TimeValue, String, String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequestBuilder
- cloneWithRecordedSource() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Creates a sub-context from the current
DocumentParserContext
to indicate that the source for the sub-context has been recorded and avoid duplicate recording for parts of the sub-context. - close() - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Closes the processor.
- close() - Method in class org.elasticsearch.action.bulk.BulkProcessor2
-
This method flushes any requests, prevents any future retries, closes this processor, and returns once any pending requests complete.
- close() - Method in class org.elasticsearch.action.bulk.IncrementalBulkService.Handler
- close() - Method in class org.elasticsearch.action.search.QueryPhaseResultConsumer
- close() - Method in class org.elasticsearch.action.search.SearchResponseMerger
- close() - Method in class org.elasticsearch.action.support.RefCountingListener
-
Release the original reference to this object, which completes the delegate
ActionListener
if there are no other references. - close() - Method in class org.elasticsearch.action.support.RefCountingRunnable
-
Release the original reference to this object, which executes the delegate
Runnable
if there are no other references. - close() - Method in class org.elasticsearch.action.support.replication.PendingReplicationActions
- close() - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- close() - Method in interface org.elasticsearch.cluster.coordination.CoordinationState.PersistedState
- close() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
- close() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- close() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
- close() - Method in class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- close() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- close() - Method in class org.elasticsearch.common.io.stream.BytesRefStreamOutput
-
Closes this stream to further operations.
- close() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- close() - Method in class org.elasticsearch.common.io.stream.CountingStreamOutput
- close() - Method in class org.elasticsearch.common.io.stream.DataOutputStreamOutput
- close() - Method in class org.elasticsearch.common.io.stream.DelayableWriteable.Serialized
- close() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- close() - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- close() - Method in class org.elasticsearch.common.io.stream.OutputStreamStreamOutput
- close() - Method in class org.elasticsearch.common.io.stream.RecyclerBytesStreamOutput
- close() - Method in class org.elasticsearch.common.io.stream.ReleasableBytesStreamOutput
- close() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Closes the stream to further operations.
- close() - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Closes this stream to further operations.
- close() - Method in class org.elasticsearch.common.io.stream.VersionCheckingStreamOutput
- close() - Method in class org.elasticsearch.common.logging.ChunkedLoggingStream
- close() - Method in class org.elasticsearch.common.lucene.index.FreqTermsEnum
- close() - Method in class org.elasticsearch.common.lucene.LoggerInfoStream
- close() - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- close() - Method in class org.elasticsearch.common.lucene.store.BytesReferenceIndexInput
- close() - Method in class org.elasticsearch.common.lucene.store.FilterIndexOutput
- close() - Method in class org.elasticsearch.common.lucene.store.IndexOutputOutputStream
- close() - Method in interface org.elasticsearch.common.network.CloseableChannel
-
Closes the channel.
- close() - Method in class org.elasticsearch.common.recycler.NoneRecycler.NV
- close() - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
- close() - Method in class org.elasticsearch.common.settings.LocallyMountedSecrets
- close() - Method in interface org.elasticsearch.common.settings.SecureSettings
- close() - Method in class org.elasticsearch.common.settings.SecureString
-
Closes the string by clearing the underlying char array.
- close() - Method in class org.elasticsearch.common.util.BitArray
- close() - Method in class org.elasticsearch.common.util.BytesRefArray
- close() - Method in class org.elasticsearch.common.util.BytesRefHash
- close() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
-
Cancel any scheduled run
- close() - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
- close() - Method in class org.elasticsearch.common.util.concurrent.ThrottledIterator
- close() - Method in class org.elasticsearch.common.util.Int3Hash
- close() - Method in class org.elasticsearch.common.util.LongHash
- close() - Method in class org.elasticsearch.common.util.LongLongHash
- close() - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
- close() - Method in class org.elasticsearch.common.util.ObjectArrayPriorityQueue
- close() - Method in class org.elasticsearch.common.util.ObjectObjectPagedHashMap
- close() - Method in class org.elasticsearch.common.util.ReleasableByteArray
- close() - Method in class org.elasticsearch.common.util.ReleasableLongArray
- close() - Method in class org.elasticsearch.discovery.ProbeConnectionResult
- close() - Method in class org.elasticsearch.env.NodeEnvironment
- close() - Method in class org.elasticsearch.env.NodeEnvironment.NodeLock
- close() - Method in class org.elasticsearch.env.ShardLock
- close() - Method in class org.elasticsearch.gateway.AsyncShardFetch
- close() - Method in class org.elasticsearch.gateway.GatewayMetaState
- close() - Method in class org.elasticsearch.gateway.GatewayMetaState.LucenePersistedState
- close() - Method in class org.elasticsearch.gateway.PersistedClusterStateService.Writer
- close() - Method in interface org.elasticsearch.http.HttpBody.ChunkHandler
- close() - Method in interface org.elasticsearch.http.HttpBody.Full
- close() - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
- close() - Method in interface org.elasticsearch.index.analysis.IndexAnalyzers
- close() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
- close() - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProviderFactory
- close() - Method in class org.elasticsearch.index.analysis.ReloadableCustomAnalyzer
- close() - Method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- close() - Method in class org.elasticsearch.index.cache.IndexCache
- close() - Method in class org.elasticsearch.index.cache.query.DisabledQueryCache
- close() - Method in class org.elasticsearch.index.cache.query.IndexQueryCache
- close() - Method in class org.elasticsearch.index.codec.tsdb.ES87TSDBDocValuesProducer
- close() - Method in class org.elasticsearch.index.codec.vectors.ES813Int8FlatVectorFormat.ES813FlatVectorReader
- close() - Method in class org.elasticsearch.index.codec.vectors.ES813Int8FlatVectorFormat.ES813FlatVectorWriter
- close() - Method in class org.elasticsearch.index.codec.vectors.ES816BinaryQuantizedVectorsReader
- close() - Method in class org.elasticsearch.index.codec.vectors.ES816BinaryQuantizedVectorsWriter
- close() - Method in class org.elasticsearch.index.engine.ElasticsearchConcurrentMergeScheduler
- close() - Method in class org.elasticsearch.index.engine.Engine
- close() - Method in class org.elasticsearch.index.engine.Engine.GetResult
- close() - Method in class org.elasticsearch.index.engine.Engine.IndexCommitRef
- close() - Method in class org.elasticsearch.index.engine.Engine.Searcher
- close() - Method in class org.elasticsearch.index.engine.Engine.SearcherSupplier
- close() - Method in class org.elasticsearch.index.engine.FlushListeners
- close() - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
- close() - Method in interface org.elasticsearch.index.fielddata.LeafFieldData
- close() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Closes this builder and release all resources.
- close() - Method in class org.elasticsearch.index.mapper.flattened.KeyedFlattenedLeafFieldData
- close() - Method in class org.elasticsearch.index.mapper.MapperService
- close() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- close() - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker.FieldUsageStatsTrackingSession
- close() - Method in class org.elasticsearch.index.shard.GlobalCheckpointListeners
- close() - Method in class org.elasticsearch.index.shard.RefreshListeners
- close() - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
- close() - Method in class org.elasticsearch.index.store.Store
- close() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
- close() - Method in class org.elasticsearch.index.translog.Translog
- close() - Method in class org.elasticsearch.index.translog.TranslogReader
- close() - Method in class org.elasticsearch.index.translog.TranslogWriter
- close() - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
- close() - Method in class org.elasticsearch.indices.IndexingMemoryController
- close() - Method in class org.elasticsearch.indices.IndicesQueryCache
- close() - Method in class org.elasticsearch.indices.IndicesRequestCache
- close() - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
- close() - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection.RecoveryRef
- close() - Method in class org.elasticsearch.indices.store.IndicesStore
- close() - Method in class org.elasticsearch.inference.InferenceServiceRegistry
- close() - Method in class org.elasticsearch.node.Node
- close() - Method in class org.elasticsearch.node.NodeService
- close() - Method in class org.elasticsearch.persistent.PersistentTasksClusterService
- close() - Method in class org.elasticsearch.plugins.Plugin
-
Close the resources opened by this plugin.
- close() - Method in class org.elasticsearch.plugins.UberModuleClassLoader
- close() - Method in class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
- close() - Method in class org.elasticsearch.repositories.FilterRepository
- close() - Method in interface org.elasticsearch.rest.BaseRestHandler.RestChannelConsumer
-
Called just after the execution has started (or failed, if the request was invalid), but typically well before the execution has completed.
- close() - Method in class org.elasticsearch.rest.ChunkedZipResponse
-
Close this
ChunkedZipResponse
. - close() - Method in class org.elasticsearch.rest.RestResponse
- close() - Method in class org.elasticsearch.rest.StreamingXContentResponse
-
Close this
StreamingXContentResponse
, indicating that there will be no more fragments to send. - close() - Method in interface org.elasticsearch.script.ScriptEngine
- close() - Method in class org.elasticsearch.script.ScriptService
- close() - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- close() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Called upon release of the aggregator.
- close() - Method in interface org.elasticsearch.search.aggregations.AggregatorReducer
- close() - Method in class org.elasticsearch.search.aggregations.AggregatorsReducer
- close() - Method in class org.elasticsearch.search.aggregations.bucket.BucketReducer
- close() - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
- close() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSource
- close() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- close() - Method in class org.elasticsearch.search.aggregations.bucket.FixedMultiBucketAggregatorsReducer
- close() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- close() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds
- close() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromMany
- close() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromManySmall
- close() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromSingle
- close() - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator.ValuesSourceCollectorSource
- close() - Method in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- close() - Method in class org.elasticsearch.search.aggregations.metrics.MemoryTrackingTDigestArrays.MemoryTrackingTDigestByteArray
- close() - Method in class org.elasticsearch.search.aggregations.metrics.TDigestState
- close() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- close() - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- close() - Method in class org.elasticsearch.search.internal.ReaderContext
- close() - Method in class org.elasticsearch.search.internal.SearchContext
- close() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- close() - Method in class org.elasticsearch.search.sort.BucketedSort
- close() - Method in class org.elasticsearch.transport.CloseableConnection
- close() - Method in class org.elasticsearch.transport.ClusterConnectionManager
- close() - Method in interface org.elasticsearch.transport.ConnectionManager
- close() - Method in class org.elasticsearch.transport.DeflateTransportDecompressor
- close() - Method in class org.elasticsearch.transport.InboundAggregator
- close() - Method in class org.elasticsearch.transport.InboundDecoder
- close() - Method in class org.elasticsearch.transport.InboundPipeline
- close() - Method in class org.elasticsearch.transport.LeakTracker.Leak
-
Stop tracking the object that this leak was created for.
- close() - Method in class org.elasticsearch.transport.RemoteClusterConnection
- close() - Method in class org.elasticsearch.transport.RemoteClusterService
- close() - Method in class org.elasticsearch.transport.RemoteConnectionManager
- close() - Method in class org.elasticsearch.transport.RemoteConnectionStrategy
- close() - Method in class org.elasticsearch.transport.ReuseBuffersLZ4BlockOutputStream
- close() - Method in class org.elasticsearch.transport.TcpTransport.NodeChannels
- close() - Method in interface org.elasticsearch.transport.Transport.Connection
- close() - Method in class org.elasticsearch.transport.TransportDecompressor
- close() - Method in class org.elasticsearch.watcher.ResourceWatcherService
- close(Runnable) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource
- close(String, boolean, Executor, ActionListener<Void>) - Method in class org.elasticsearch.index.IndexService
- close(String, boolean, Executor, ActionListener<Void>) - Method in class org.elasticsearch.index.shard.IndexShard
- close(CloseIndexRequest) - Method in class org.elasticsearch.client.internal.IndicesAdminClient
- close(CloseIndexRequest, ActionListener<CloseIndexResponse>) - Method in class org.elasticsearch.client.internal.IndicesAdminClient
- CLOSE - Enum constant in enum class org.elasticsearch.cluster.metadata.IndexMetadata.State
- CloseableChannel - Interface in org.elasticsearch.common.network
- CloseableConnection - Class in org.elasticsearch.transport
-
Abstract Transport.Connection that provides common close logic.
- CloseableConnection() - Constructor for class org.elasticsearch.transport.CloseableConnection
- closeChannel(C) - Static method in interface org.elasticsearch.common.network.CloseableChannel
-
Closes the channel without blocking.
- closeChannel(C, boolean) - Static method in interface org.elasticsearch.common.network.CloseableChannel
-
Closes the channel.
- closeChannels(List<C>, boolean) - Static method in interface org.elasticsearch.common.network.CloseableChannel
-
Closes the channels.
- closeContexts(DiscoveryNodes, SearchTransportService, Collection<SearchContextIdForNode>, ActionListener<Integer>) - Static method in class org.elasticsearch.action.search.ClearScrollController
-
Closes the given context id and reports the number of freed contexts via the listener
- closed - Variable in class org.elasticsearch.index.translog.TranslogReader
- closed - Variable in class org.elasticsearch.index.translog.TranslogWriter
- closed() - Method in class org.elasticsearch.common.component.Lifecycle
-
Returns
true
if the state is closed. - CLOSED - Enum constant in enum class org.elasticsearch.common.component.Lifecycle.State
- CLOSED - Enum constant in enum class org.elasticsearch.index.shard.IndexShardState
- CLOSED - Enum constant in enum class org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices.IndexRemovalReason
-
The index has been closed.
- closedTimeMillis() - Method in record class org.elasticsearch.http.HttpStats.ClientStats
-
Returns the value of the
closedTimeMillis
record component. - CloseIndexClusterStateUpdateRequest - Record Class in org.elasticsearch.action.admin.indices.close
-
Cluster state update request that allows to close one or more indices
- CloseIndexClusterStateUpdateRequest(TimeValue, TimeValue, long, ActiveShardCount, Index[]) - Constructor for record class org.elasticsearch.action.admin.indices.close.CloseIndexClusterStateUpdateRequest
-
Creates an instance of a
CloseIndexClusterStateUpdateRequest
record class. - CloseIndexRequest - Class in org.elasticsearch.action.admin.indices.close
-
A request to close an index.
- CloseIndexRequest() - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
- CloseIndexRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
-
Constructs a new close index request for the specified index.
- CloseIndexRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
- CloseIndexRequestBuilder - Class in org.elasticsearch.action.admin.indices.close
-
Builder for close index request
- CloseIndexRequestBuilder(ElasticsearchClient, String...) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
- CloseIndexResponse - Class in org.elasticsearch.action.admin.indices.close
- CloseIndexResponse(boolean, boolean, List<CloseIndexResponse.IndexResult>) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexResponse
- CloseIndexResponse.IndexResult - Class in org.elasticsearch.action.admin.indices.close
- CloseIndexResponse.ShardResult - Class in org.elasticsearch.action.admin.indices.close
- CloseIndexResponse.ShardResult.Failure - Exception in org.elasticsearch.action.admin.indices.close
- closeIndices(CloseIndexClusterStateUpdateRequest, ActionListener<CloseIndexResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexStateService
-
Closes one or more indices.
- closeInternal() - Method in class org.elasticsearch.cluster.coordination.PublicationTransportHandler.PublicationContext
- closeInternal() - Method in class org.elasticsearch.env.ShardLock
- closeInternal() - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
- closeInternal() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- closeInternal() - Method in class org.elasticsearch.repositories.SnapshotIndexCommit
- closeInternal() - Method in class org.elasticsearch.transport.CloseableConnection
- closeInternal() - Method in class org.elasticsearch.transport.InboundMessage
- closeIntoReader() - Method in class org.elasticsearch.index.translog.TranslogWriter
-
Closes this writer and transfers its underlying file channel to a new immutable
TranslogReader
- closeNoBlock() - Method in class org.elasticsearch.transport.ClusterConnectionManager
- closeNoBlock() - Method in interface org.elasticsearch.transport.ConnectionManager
- closeNoBlock() - Method in class org.elasticsearch.transport.RemoteConnectionManager
- closeNoLock(String, CountDownLatch) - Method in class org.elasticsearch.index.engine.Engine
-
Closes the engine without acquiring any refs or locks.
- closeNoLock(String, CountDownLatch) - Method in class org.elasticsearch.index.engine.InternalEngine
- closeNoLock(String, CountDownLatch) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- closeOnTragicEvent(Exception) - Method in class org.elasticsearch.index.translog.Translog
-
Closes the translog if the current translog writer experienced a tragic exception.
- closePeers() - Method in class org.elasticsearch.discovery.PeerFinder
- ClosePointInTimeRequest - Class in org.elasticsearch.action.search
- ClosePointInTimeRequest(BytesReference) - Constructor for class org.elasticsearch.action.search.ClosePointInTimeRequest
- ClosePointInTimeRequest(StreamInput) - Constructor for class org.elasticsearch.action.search.ClosePointInTimeRequest
- ClosePointInTimeResponse - Class in org.elasticsearch.action.search
- ClosePointInTimeResponse(boolean, int) - Constructor for class org.elasticsearch.action.search.ClosePointInTimeResponse
- CloseUtils - Class in org.elasticsearch.index
-
Utilities to help with closing shards and indices
- closingBefore(ActionListener<T>) - Method in class org.elasticsearch.repositories.SnapshotIndexCommit
-
Returns a listener which closes this commit before completing the delegate listener, marshalling exceptions to the delegate as appropriate.
- cluster() - Method in class org.elasticsearch.client.internal.AdminClient
- Cluster(String, String, boolean) - Constructor for class org.elasticsearch.action.search.SearchResponse.Cluster
-
Create a Cluster object representing the initial RUNNING state of a Cluster.
- Cluster(String, String, boolean, SearchResponse.Cluster.Status, Integer, Integer, Integer, Integer, List<ShardSearchFailure>, TimeValue, boolean) - Constructor for class org.elasticsearch.action.search.SearchResponse.Cluster
- Cluster(String, String, boolean, SearchResponse.Cluster.Status, List<ShardSearchFailure>) - Constructor for class org.elasticsearch.action.search.SearchResponse.Cluster
-
Create a Cluster with a new Status and one or more ShardSearchFailures.
- Cluster(StreamInput) - Constructor for class org.elasticsearch.action.search.SearchResponse.Cluster
- CLUSTER - Enum constant in enum class org.elasticsearch.action.ClusterStatsLevel
- CLUSTER_AUTO_SHARDING_MAX_WRITE_THREADS - Static variable in class org.elasticsearch.action.datastreams.autosharding.DataStreamAutoShardingService
-
Represents the maximum number of write threads we expect a node to have in the environments where auto sharding will be enabled.
- CLUSTER_AUTO_SHARDING_MIN_WRITE_THREADS - Static variable in class org.elasticsearch.action.datastreams.autosharding.DataStreamAutoShardingService
-
Represents the minimum number of write threads we expect a node to have in the environments where auto sharding will be enabled.
- CLUSTER_AUTO_SHRINK_VOTING_CONFIGURATION - Static variable in class org.elasticsearch.cluster.coordination.Reconfigurator
-
The cluster usually requires a vote from at least half of the master nodes in order to commit a cluster state update, and to achieve the best resilience it makes automatic adjustments to the voting configuration as master nodes join or leave the cluster.
- CLUSTER_COORDINATION - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
-
Important management tasks that keep the cluster from falling apart.
- CLUSTER_FEATURES_ADDED_VERSION - Static variable in class org.elasticsearch.features.FeatureService
- CLUSTER_FOLLOWER_LAG_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.LagDetector
- CLUSTER_INDICES_CLOSE_ENABLE_SETTING - Static variable in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
- CLUSTER_LIFECYCLE_DEFAULT_ROLLOVER_SETTING - Static variable in class org.elasticsearch.cluster.metadata.DataStreamLifecycle
- CLUSTER_NAME - Static variable in interface org.elasticsearch.telemetry.tracing.Tracer.AttributeKeys
- CLUSTER_NAME_SETTING - Static variable in class org.elasticsearch.cluster.ClusterName
- CLUSTER_NODE_RECONNECT_INTERVAL_SETTING - Static variable in class org.elasticsearch.cluster.NodeConnectionsService
- CLUSTER_READ_ONLY_ALLOW_DELETE_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- CLUSTER_READ_ONLY_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- CLUSTER_RECOVERED - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of a full cluster recovery.
- CLUSTER_ROUTING_ALLOCATION_ALLOW_REBALANCE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider
- CLUSTER_ROUTING_ALLOCATION_AWARENESS_ATTRIBUTE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
- CLUSTER_ROUTING_ALLOCATION_AWARENESS_FORCE_GROUP_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
- CLUSTER_ROUTING_ALLOCATION_CLUSTER_CONCURRENT_REBALANCE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ConcurrentRebalanceAllocationDecider
- CLUSTER_ROUTING_ALLOCATION_DISK_FLOOD_STAGE_FROZEN_MAX_HEADROOM_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- CLUSTER_ROUTING_ALLOCATION_DISK_FLOOD_STAGE_FROZEN_WATERMARK_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- CLUSTER_ROUTING_ALLOCATION_DISK_FLOOD_STAGE_MAX_HEADROOM_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- CLUSTER_ROUTING_ALLOCATION_DISK_FLOOD_STAGE_WATERMARK_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- CLUSTER_ROUTING_ALLOCATION_DISK_THRESHOLD_ENABLED_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- CLUSTER_ROUTING_ALLOCATION_ENABLE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
- CLUSTER_ROUTING_ALLOCATION_HIGH_DISK_MAX_HEADROOM_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- CLUSTER_ROUTING_ALLOCATION_HIGH_DISK_WATERMARK_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- CLUSTER_ROUTING_ALLOCATION_LOW_DISK_MAX_HEADROOM_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- CLUSTER_ROUTING_ALLOCATION_LOW_DISK_WATERMARK_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- CLUSTER_ROUTING_ALLOCATION_NODE_CONCURRENT_INCOMING_RECOVERIES_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
- CLUSTER_ROUTING_ALLOCATION_NODE_CONCURRENT_OUTGOING_RECOVERIES_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
- CLUSTER_ROUTING_ALLOCATION_NODE_CONCURRENT_RECOVERIES_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
- CLUSTER_ROUTING_ALLOCATION_NODE_INITIAL_PRIMARIES_RECOVERIES_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
- CLUSTER_ROUTING_ALLOCATION_REROUTE_INTERVAL_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- CLUSTER_ROUTING_ALLOCATION_SAME_HOST_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.SameShardAllocationDecider
- CLUSTER_ROUTING_EXCLUDE_GROUP_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
- CLUSTER_ROUTING_INCLUDE_GROUP_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
- CLUSTER_ROUTING_REBALANCE_ENABLE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
- CLUSTER_ROUTING_REQUIRE_GROUP_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
- CLUSTER_SERVICE_SLOW_TASK_LOGGING_THRESHOLD_SETTING - Static variable in class org.elasticsearch.cluster.service.ClusterApplierService
- CLUSTER_SERVICE_SLOW_TASK_THREAD_DUMP_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.service.ClusterApplierService
- CLUSTER_STATE - Enum constant in enum class org.elasticsearch.cluster.metadata.DesiredNodes.SerializationContext
- CLUSTER_STATE - Enum constant in enum class org.elasticsearch.common.blobstore.OperationPurpose
- CLUSTER_TASKS_ALLOCATION_ENABLE_SETTING - Static variable in class org.elasticsearch.persistent.decider.EnableAssignmentDecider
- CLUSTER_TASKS_ALLOCATION_RECHECK_INTERVAL_SETTING - Static variable in class org.elasticsearch.persistent.PersistentTasksClusterService
- CLUSTER_THROTTLE - Static variable in class org.elasticsearch.cluster.routing.allocation.Explanations.Rebalance
- CLUSTER_TOTAL_SHARDS_PER_NODE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
-
Controls the maximum number of shards per node on a global level.
- CLUSTER_UPDATE_THREAD_NAME - Static variable in class org.elasticsearch.cluster.service.ClusterApplierService
- clusterAdmin - Variable in class org.elasticsearch.client.internal.AdminClient
- ClusterAdminClient - Class in org.elasticsearch.client.internal
-
Administrative actions/operations against indices.
- ClusterAdminClient(ElasticsearchClient) - Constructor for class org.elasticsearch.client.internal.ClusterAdminClient
- clusterAlias - Variable in class org.elasticsearch.transport.RemoteConnectionStrategy
- clusterAlias() - Method in record class org.elasticsearch.action.search.SearchShard
-
Returns the value of the
clusterAlias
record component. - clusterAlias() - Method in class org.elasticsearch.action.search.SearchShardsRequest
- clusterAlias() - Method in record class org.elasticsearch.transport.RemoteConnectionManager.RemoteClusterAliasWithCredentials
-
Returns the value of the
clusterAlias
record component. - ClusterAllocationExplainRequest - Class in org.elasticsearch.action.admin.cluster.allocation
-
A request to explain the allocation of a shard in the cluster
- ClusterAllocationExplainRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
- ClusterAllocationExplainRequest(TimeValue) - Constructor for class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Create a new allocation explain request to explain any unassigned shard in the cluster.
- ClusterAllocationExplainResponse - Class in org.elasticsearch.action.admin.cluster.allocation
-
Explanation response for a shard in the cluster
- ClusterAllocationExplainResponse(ClusterAllocationExplanation) - Constructor for class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainResponse
- ClusterAllocationExplainResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainResponse
- ClusterAllocationExplanation - Class in org.elasticsearch.action.admin.cluster.allocation
-
A
ClusterAllocationExplanation
is an explanation of why a shard is unassigned, or if it is not unassigned, then which nodes it could possibly be relocated to. - ClusterAllocationExplanation(boolean, ShardRouting, DiscoveryNode, DiscoveryNode, ClusterInfo, ShardAllocationDecision) - Constructor for class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
- ClusterAllocationExplanation(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
- ClusterApplier - Interface in org.elasticsearch.cluster.service
- ClusterApplierRecordingService - Class in org.elasticsearch.cluster.service
- ClusterApplierRecordingService() - Constructor for class org.elasticsearch.cluster.service.ClusterApplierRecordingService
- ClusterApplierRecordingService.Stats - Class in org.elasticsearch.cluster.service
- ClusterApplierRecordingService.Stats.Recording - Class in org.elasticsearch.cluster.service
- ClusterApplierService - Class in org.elasticsearch.cluster.service
- ClusterApplierService(String, Settings, ClusterSettings, ThreadPool) - Constructor for class org.elasticsearch.cluster.service.ClusterApplierService
- ClusterBalanceStats - Record Class in org.elasticsearch.cluster.routing.allocation.allocator
- ClusterBalanceStats(int, int, Map<String, ClusterBalanceStats.TierBalanceStats>, Map<String, ClusterBalanceStats.NodeBalanceStats>) - Constructor for record class org.elasticsearch.cluster.routing.allocation.allocator.ClusterBalanceStats
-
Creates an instance of a
ClusterBalanceStats
record class. - ClusterBalanceStats.MetricStats - Record Class in org.elasticsearch.cluster.routing.allocation.allocator
- ClusterBalanceStats.NodeBalanceStats - Record Class in org.elasticsearch.cluster.routing.allocation.allocator
- ClusterBalanceStats.TierBalanceStats - Record Class in org.elasticsearch.cluster.routing.allocation.allocator
- clusterBlock() - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction.ShardRequest
- clusterBlock() - Method in class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction.ShardRequest
- ClusterBlock - Class in org.elasticsearch.cluster.block
- ClusterBlock(int, String, boolean, boolean, boolean, RestStatus, EnumSet<ClusterBlockLevel>) - Constructor for class org.elasticsearch.cluster.block.ClusterBlock
- ClusterBlock(int, String, String, boolean, boolean, boolean, RestStatus, EnumSet<ClusterBlockLevel>) - Constructor for class org.elasticsearch.cluster.block.ClusterBlock
- ClusterBlock(StreamInput) - Constructor for class org.elasticsearch.cluster.block.ClusterBlock
- ClusterBlockException - Exception in org.elasticsearch.cluster.block
- ClusterBlockException(Map<String, Set<ClusterBlock>>) - Constructor for exception org.elasticsearch.cluster.block.ClusterBlockException
- ClusterBlockException(Set<ClusterBlock>) - Constructor for exception org.elasticsearch.cluster.block.ClusterBlockException
- ClusterBlockException(StreamInput) - Constructor for exception org.elasticsearch.cluster.block.ClusterBlockException
- ClusterBlockLevel - Enum Class in org.elasticsearch.cluster.block
- ClusterBlocks - Class in org.elasticsearch.cluster.block
-
Represents current cluster level blocks to block dirty operations done against the cluster.
- ClusterBlocks.Builder - Class in org.elasticsearch.cluster.block
- ClusterBootstrapService - Class in org.elasticsearch.cluster.coordination
- ClusterBootstrapService(Settings, TransportService, Supplier<Iterable<DiscoveryNode>>, BooleanSupplier, Consumer<CoordinationMetadata.VotingConfiguration>) - Constructor for class org.elasticsearch.cluster.coordination.ClusterBootstrapService
- clusterChanged(ClusterChangedEvent) - Method in interface org.elasticsearch.cluster.ClusterStateListener
-
Called when cluster state changes.
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.cluster.coordination.CoordinationDiagnosticsService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.cluster.coordination.MasterHistory
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.cluster.features.NodeFeaturesFixupListener
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.cluster.InternalClusterInfoService
- clusterChanged(ClusterChangedEvent) - Method in interface org.elasticsearch.cluster.LocalNodeMasterListener
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.cluster.metadata.SystemIndexMetadataUpgradeService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.cluster.metadata.TemplateUpgradeService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.cluster.routing.DelayedAllocationService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.cluster.service.CompatibilityVersionsFixupListener
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.common.file.MasterNodeFileWatchingService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.gateway.GatewayService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.health.HealthPeriodicLogger
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.health.node.HealthInfoCache
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.health.node.LocalHealthMonitor
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.indices.recovery.PeerRecoverySourceService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.indices.store.IndicesStore
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.indices.SystemIndexMappingUpdateService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.node.ResponseCollectorService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.persistent.PersistentTasksClusterService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.persistent.PersistentTasksNodeService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.readiness.ReadinessService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.shutdown.PluginShutdownService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.snapshots.InternalSnapshotsInfoService
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.snapshots.SnapshotShardsService
- ClusterChangedEvent - Class in org.elasticsearch.cluster
-
An event received by the local node, signaling that the cluster state has changed.
- ClusterChangedEvent(String, ClusterState, ClusterState) - Constructor for class org.elasticsearch.cluster.ClusterChangedEvent
- ClusterConnectionManager - Class in org.elasticsearch.transport
-
This class manages node connections within a cluster.
- ClusterConnectionManager(Settings, Transport, ThreadContext) - Constructor for class org.elasticsearch.transport.ClusterConnectionManager
- ClusterConnectionManager(ConnectionProfile, Transport, ThreadContext) - Constructor for class org.elasticsearch.transport.ClusterConnectionManager
- ClusterCoordinationPlugin - Interface in org.elasticsearch.plugins
- ClusterCoordinationPlugin.PersistedClusterStateServiceFactory - Interface in org.elasticsearch.plugins
- ClusterCoordinationPlugin.PersistedStateFactory - Interface in org.elasticsearch.plugins
- ClusterCoordinationPlugin.ReconfiguratorFactory - Interface in org.elasticsearch.plugins
- clusterFeatures() - Method in class org.elasticsearch.cluster.ClusterState
- ClusterFeatures - Class in org.elasticsearch.cluster
-
Stores information on what features are present throughout the cluster
- ClusterFeatures(Map<String, Set<String>>) - Constructor for class org.elasticsearch.cluster.ClusterFeatures
- ClusterFormationFailureHelper - Class in org.elasticsearch.cluster.coordination
-
Handles periodic debug logging of information regarding why the cluster has failed to form.
- ClusterFormationFailureHelper(Settings, Supplier<ClusterFormationFailureHelper.ClusterFormationState>, ThreadPool, Runnable) - Constructor for class org.elasticsearch.cluster.coordination.ClusterFormationFailureHelper
-
Works with the
JoinHelper
to log the latest node-join attempt failure and cluster state debug information. - ClusterFormationFailureHelper.ClusterFormationState - Record Class in org.elasticsearch.cluster.coordination
-
This record provides node state information that can be used to determine why cluster formation has failed.
- ClusterFormationInfoAction - Class in org.elasticsearch.action.admin.cluster.coordination
-
This class is used to fetch the ClusterFormationState from another node.
- ClusterFormationInfoAction.Request - Class in org.elasticsearch.action.admin.cluster.coordination
- ClusterFormationInfoAction.Response - Class in org.elasticsearch.action.admin.cluster.coordination
- ClusterFormationInfoAction.TransportAction - Class in org.elasticsearch.action.admin.cluster.coordination
-
This transport action fetches the ClusterFormationState from a remote node.
- ClusterFormationState(List<String>, DiscoveryNode, Map<String, DiscoveryNode>, long, long, CoordinationMetadata.VotingConfiguration, CoordinationMetadata.VotingConfiguration, List<TransportAddress>, List<DiscoveryNode>, Set<DiscoveryNode>, long, boolean, StatusInfo, List<JoinStatus>) - Constructor for record class org.elasticsearch.cluster.coordination.ClusterFormationFailureHelper.ClusterFormationState
-
Creates an instance of a
ClusterFormationState
record class. - ClusterFormationState(StreamInput) - Constructor for record class org.elasticsearch.cluster.coordination.ClusterFormationFailureHelper.ClusterFormationState
- ClusterFormationState(Settings, ClusterState, List<TransportAddress>, List<DiscoveryNode>, Set<DiscoveryNode>, long, ElectionStrategy, StatusInfo, List<JoinStatus>) - Constructor for record class org.elasticsearch.cluster.coordination.ClusterFormationFailureHelper.ClusterFormationState
- ClusterGetSettingsAction - Class in org.elasticsearch.action.admin.cluster.settings
- ClusterGetSettingsAction() - Constructor for class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsAction
- ClusterGetSettingsAction.Request - Class in org.elasticsearch.action.admin.cluster.settings
-
Request to retrieve the cluster settings
- ClusterGetSettingsAction.Response - Class in org.elasticsearch.action.admin.cluster.settings
-
Response for cluster settings
- clusterHasFeature(ClusterState, NodeFeature) - Method in class org.elasticsearch.features.FeatureService
-
Returns
true
if all nodes instate
support featurefeature
. - clusterHasFeature(NodeFeature) - Method in class org.elasticsearch.cluster.ClusterFeatures
-
true
iffeature
is present on all nodes in the cluster. - clusterHasRequiredFeatures(Predicate<NodeFeature>) - Method in class org.elasticsearch.action.admin.cluster.desirednodes.UpdateDesiredNodesRequest
- clusterHasRequiredFeatures(Predicate<NodeFeature>) - Method in class org.elasticsearch.cluster.metadata.DesiredNode
- ClusterHealthRequest - Class in org.elasticsearch.action.admin.cluster.health
- ClusterHealthRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- ClusterHealthRequest(TimeValue) - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- ClusterHealthRequest(TimeValue, String...) - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- ClusterHealthRequestBuilder - Class in org.elasticsearch.action.admin.cluster.health
- ClusterHealthRequestBuilder(ElasticsearchClient, TimeValue) - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- ClusterHealthResponse - Class in org.elasticsearch.action.admin.cluster.health
- ClusterHealthResponse() - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- ClusterHealthResponse(String, String[], ClusterState) - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
-
needed for plugins BWC
- ClusterHealthResponse(String, String[], ClusterState, int, int, int, TimeValue) - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- ClusterHealthResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- ClusterHealthStatus - Enum Class in org.elasticsearch.cluster.health
- ClusterIdConverter - Class in org.elasticsearch.common.logging
-
Pattern converter to format the cluster_id variable into JSON fields
cluster.id
. - ClusterIdConverter() - Constructor for class org.elasticsearch.common.logging.ClusterIdConverter
- ClusterIndexHealth - Class in org.elasticsearch.cluster.health
- ClusterIndexHealth(IndexMetadata, IndexRoutingTable) - Constructor for class org.elasticsearch.cluster.health.ClusterIndexHealth
- ClusterIndexHealth(StreamInput) - Constructor for class org.elasticsearch.cluster.health.ClusterIndexHealth
- clusterInfo() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- ClusterInfo - Class in org.elasticsearch.cluster
-
ClusterInfo is an object representing a map of nodes to
DiskUsage
and a map of shard ids to shard sizes, seeInternalClusterInfoService.shardIdentifierFromRouting(String)
for the key used in the shardSizes map - ClusterInfo() - Constructor for class org.elasticsearch.cluster.ClusterInfo
- ClusterInfo(Map<String, DiskUsage>, Map<String, DiskUsage>, Map<String, Long>, Map<ShardId, Long>, Map<ClusterInfo.NodeAndShard, String>, Map<ClusterInfo.NodeAndPath, ClusterInfo.ReservedSpace>) - Constructor for class org.elasticsearch.cluster.ClusterInfo
-
Creates a new ClusterInfo instance.
- ClusterInfo(StreamInput) - Constructor for class org.elasticsearch.cluster.ClusterInfo
- ClusterInfo.NodeAndPath - Record Class in org.elasticsearch.cluster
-
Represents a data path on a node
- ClusterInfo.NodeAndShard - Record Class in org.elasticsearch.cluster
- ClusterInfo.ReservedSpace - Record Class in org.elasticsearch.cluster
-
Represents the total amount of "reserved" space on a particular data path, together with the set of shards considered.
- ClusterInfo.ReservedSpace.Builder - Class in org.elasticsearch.cluster
- ClusterInfoRequest<Request extends ClusterInfoRequest<Request>> - Class in org.elasticsearch.action.support.master.info
- ClusterInfoRequest() - Constructor for class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- ClusterInfoRequest(IndicesOptions) - Constructor for class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- ClusterInfoRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- ClusterInfoRequestBuilder<Request extends ClusterInfoRequest<Request>,
Response extends ActionResponse, Builder extends ClusterInfoRequestBuilder<Request, Response, Builder>> - Class in org.elasticsearch.action.support.master.info - ClusterInfoRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.support.master.info.ClusterInfoRequestBuilder
- ClusterInfoService - Interface in org.elasticsearch.cluster
-
Interface for a class used to gather information about a cluster periodically.
- ClusterInfoSimulator - Class in org.elasticsearch.cluster
- ClusterInfoSimulator(RoutingAllocation) - Constructor for class org.elasticsearch.cluster.ClusterInfoSimulator
- CLUSTERING - Enum constant in enum class org.elasticsearch.inference.InputType
- clusterMetadata - Variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService.ShardAllocationStatus
- clusterMetadata() - Method in class org.elasticsearch.repositories.FinalizeSnapshotContext
- ClusterModule - Class in org.elasticsearch.cluster
-
Configures classes and services that affect the entire cluster.
- ClusterModule(Settings, ClusterService, List<ClusterPlugin>, ClusterInfoService, SnapshotsInfoService, ThreadPool, SystemIndices, WriteLoadForecaster, TelemetryProvider) - Constructor for class org.elasticsearch.cluster.ClusterModule
- clusterName - Variable in class org.elasticsearch.transport.TransportService
- ClusterName - Class in org.elasticsearch.cluster
- ClusterName(String) - Constructor for class org.elasticsearch.cluster.ClusterName
- ClusterName(StreamInput) - Constructor for class org.elasticsearch.cluster.ClusterName
- ClusterNameExpressionResolver - Class in org.elasticsearch.cluster.metadata
-
Resolves cluster names from an expression.
- ClusterNameExpressionResolver() - Constructor for class org.elasticsearch.cluster.metadata.ClusterNameExpressionResolver
- ClusterPlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
implementations to customer behavior of cluster management. - ClusterRebalanceAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This
AllocationDecider
controls re-balancing operations based on the cluster wide active shard state. - ClusterRebalanceAllocationDecider(ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider
- ClusterRebalanceAllocationDecider.ClusterRebalanceType - Enum Class in org.elasticsearch.cluster.routing.allocation.decider
-
An enum representation for the configured re-balance type.
- clusterRecovered() - Method in class org.elasticsearch.cluster.ClusterState
- ClusterRerouteRequest - Class in org.elasticsearch.action.admin.cluster.reroute
-
Request to submit cluster reroute allocation commands
- ClusterRerouteRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
- ClusterRerouteRequest(TimeValue, TimeValue) - Constructor for class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
- ClusterRerouteResponse - Class in org.elasticsearch.action.admin.cluster.reroute
-
Response returned after a cluster reroute request
- Clusters(int, int, int) - Constructor for class org.elasticsearch.action.search.SearchResponse.Clusters
-
Used for searches that are either not cross-cluster.
- Clusters(Map<String, SearchResponse.Cluster>) - Constructor for class org.elasticsearch.action.search.SearchResponse.Clusters
- Clusters(OriginalIndices, Map<String, OriginalIndices>, boolean, Predicate<String>) - Constructor for class org.elasticsearch.action.search.SearchResponse.Clusters
-
For use with cross-cluster searches.
- Clusters(StreamInput) - Constructor for class org.elasticsearch.action.search.SearchResponse.Clusters
- ClusterSearchShardsGroup - Class in org.elasticsearch.action.admin.cluster.shards
- ClusterSearchShardsGroup(ShardId, ShardRouting[]) - Constructor for class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
- ClusterSearchShardsRequest - Class in org.elasticsearch.action.admin.cluster.shards
- ClusterSearchShardsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- ClusterSearchShardsRequest(TimeValue, String...) - Constructor for class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- ClusterSearchShardsResponse - Class in org.elasticsearch.action.admin.cluster.shards
- ClusterSearchShardsResponse(ClusterSearchShardsGroup[], DiscoveryNode[], Map<String, AliasFilter>) - Constructor for class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- ClusterSearchShardsResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- clusterService - Variable in class org.elasticsearch.action.bulk.TransportAbstractBulkAction
- clusterService - Variable in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
- clusterService - Variable in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- clusterService - Variable in class org.elasticsearch.action.support.broadcast.unpromotable.TransportBroadcastUnpromotableAction
- clusterService - Variable in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- clusterService - Variable in class org.elasticsearch.action.support.nodes.TransportNodesAction
- clusterService - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- clusterService - Variable in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- clusterService - Variable in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- clusterService - Variable in class org.elasticsearch.action.support.tasks.TransportTasksAction
- clusterService - Variable in class org.elasticsearch.action.support.TransportLocalClusterStateAction
- clusterService - Variable in class org.elasticsearch.cluster.metadata.TemplateUpgradeService
- clusterService - Variable in class org.elasticsearch.health.node.action.TransportHealthNodeAction
- clusterService() - Method in record class org.elasticsearch.index.IndexSettingProvider.Parameters
-
Returns the value of the
clusterService
record component. - clusterService() - Method in class org.elasticsearch.indices.IndicesService
- clusterService() - Method in record class org.elasticsearch.inference.InferenceServiceExtension.InferenceServiceFactoryContext
-
Returns the value of the
clusterService
record component. - clusterService() - Method in record class org.elasticsearch.node.PluginServiceInstances
-
Returns the value of the
clusterService
record component. - clusterService() - Method in interface org.elasticsearch.plugins.Plugin.PluginServices
-
A service to allow watching and updating cluster state
- clusterService(ClusterService) - Method in class org.elasticsearch.indices.IndicesServiceBuilder
- ClusterService - Class in org.elasticsearch.cluster.service
- ClusterService(Settings, ClusterSettings, MasterService, ClusterApplierService) - Constructor for class org.elasticsearch.cluster.service.ClusterService
- ClusterService(Settings, ClusterSettings, ThreadPool, TaskManager) - Constructor for class org.elasticsearch.cluster.service.ClusterService
- ClusterSettings - Class in org.elasticsearch.common.settings
-
Encapsulates all valid cluster level settings.
- ClusterSettings(Settings, Set<Setting<?>>) - Constructor for class org.elasticsearch.common.settings.ClusterSettings
- ClusterShardHealth - Class in org.elasticsearch.cluster.health
- ClusterShardHealth(int, IndexShardRoutingTable) - Constructor for class org.elasticsearch.cluster.health.ClusterShardHealth
- ClusterShardHealth(StreamInput) - Constructor for class org.elasticsearch.cluster.health.ClusterShardHealth
- ClusterSnapshotStats - Record Class in org.elasticsearch.cluster
- ClusterSnapshotStats(int, int, int, int, List<ClusterSnapshotStats.PerRepositoryStats>) - Constructor for record class org.elasticsearch.cluster.ClusterSnapshotStats
-
Creates an instance of a
ClusterSnapshotStats
record class. - clusterState() - Method in record class org.elasticsearch.action.admin.indices.rollover.MetadataRolloverService.RolloverResult
-
Returns the value of the
clusterState
record component. - clusterState() - Method in record class org.elasticsearch.cluster.routing.allocation.AllocationService.CommandsResult
-
Returns the value of the
clusterState
record component. - clusterState(Environment, PersistedClusterStateService.OnDiskState) - Static method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- ClusterState - Class in org.elasticsearch.cluster
-
Represents the state of the cluster, held in memory on all nodes in the cluster with updates coordinated by the elected master.
- ClusterState(long, String, ClusterState) - Constructor for class org.elasticsearch.cluster.ClusterState
- ClusterState(ClusterName, long, String, Metadata, RoutingTable, DiscoveryNodes, Map<String, CompatibilityVersions>, ClusterFeatures, ClusterBlocks, Map<String, ClusterState.Custom>, boolean, RoutingNodes) - Constructor for class org.elasticsearch.cluster.ClusterState
- ClusterState.Builder - Class in org.elasticsearch.cluster
- ClusterState.Custom - Interface in org.elasticsearch.cluster
- ClusterState.Metric - Enum Class in org.elasticsearch.cluster
- ClusterStateAckListener - Interface in org.elasticsearch.cluster
-
Interface that a cluster state update task can implement to indicate that it wishes to be notified when the update has been acked by (some subset of) the nodes in the cluster.
- ClusterStateAction - Class in org.elasticsearch.action.admin.cluster.state
- ClusterStateApplier - Interface in org.elasticsearch.cluster
-
A component that is in charge of applying an incoming cluster state to the node internal data structures.
- ClusterStateHealth - Class in org.elasticsearch.cluster.health
- ClusterStateHealth(int, int, int, int, int, int, int, int, double, ClusterHealthStatus, Map<String, ClusterIndexHealth>) - Constructor for class org.elasticsearch.cluster.health.ClusterStateHealth
-
For ClusterHealthResponse's XContent Parser
- ClusterStateHealth(ClusterState) - Constructor for class org.elasticsearch.cluster.health.ClusterStateHealth
-
Creates a new
ClusterStateHealth
instance considering the current cluster state and all indices in the cluster. - ClusterStateHealth(ClusterState, String[]) - Constructor for class org.elasticsearch.cluster.health.ClusterStateHealth
-
Creates a new
ClusterStateHealth
instance considering the current cluster state and the provided index names. - ClusterStateHealth(StreamInput) - Constructor for class org.elasticsearch.cluster.health.ClusterStateHealth
- ClusterStateListener - Interface in org.elasticsearch.cluster
-
A listener to be notified when a cluster state changes.
- ClusterStateObserver - Class in org.elasticsearch.cluster
-
A utility class which simplifies interacting with the cluster state in cases where one tries to take action based on the current state but may want to wait for a new state and retry upon failure.
- ClusterStateObserver(long, ClusterApplierService, TimeValue, Logger, ThreadContext) - Constructor for class org.elasticsearch.cluster.ClusterStateObserver
- ClusterStateObserver(ClusterState, ClusterService, TimeValue, Logger, ThreadContext) - Constructor for class org.elasticsearch.cluster.ClusterStateObserver
- ClusterStateObserver(ClusterService, TimeValue, Logger, ThreadContext) - Constructor for class org.elasticsearch.cluster.ClusterStateObserver
- ClusterStateObserver.Listener - Interface in org.elasticsearch.cluster
- clusterStateProcessed(ClusterState, ClusterState) - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
-
Called when the result of the
ClusterStateUpdateTask.execute(org.elasticsearch.cluster.ClusterState)
method has been processed properly by all listeners. - clusterStateProcessed(ClusterState, ClusterState) - Method in class org.elasticsearch.cluster.metadata.SystemIndexMetadataUpgradeService.SystemIndexMetadataUpdateTask
- clusterStateProcessed(ClusterState, ClusterState) - Method in class org.elasticsearch.upgrades.MigrationResultsUpdateTask
- ClusterStatePublicationEvent - Class in org.elasticsearch.cluster
-
Represents a cluster state update computed by the
MasterService
for publication to the cluster. - ClusterStatePublicationEvent(BatchSummary, ClusterState, ClusterState, Task, long, long) - Constructor for class org.elasticsearch.cluster.ClusterStatePublicationEvent
- clusterStatePublished() - Method in class org.elasticsearch.cluster.SimpleBatchedAckListenerTaskExecutor
-
Called after the new cluster state is published.
- clusterStatePublished() - Method in class org.elasticsearch.cluster.SimpleBatchedExecutor
-
Called after the new cluster state is published.
- clusterStatePublished() - Method in class org.elasticsearch.reservedstate.service.ReservedStateUpdateTaskExecutor
- clusterStatePublished(ClusterState) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardFailedClusterStateTaskExecutor
- clusterStatePublished(ClusterState) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardStartedClusterStateTaskExecutor
- clusterStatePublished(ClusterState) - Method in interface org.elasticsearch.cluster.ClusterStateTaskExecutor
-
Callback invoked after new cluster state is published.
- clusterStatePublished(ClusterState) - Method in class org.elasticsearch.cluster.SimpleBatchedAckListenerTaskExecutor
- clusterStatePublished(ClusterState) - Method in class org.elasticsearch.cluster.SimpleBatchedExecutor
- ClusterStatePublisher - Interface in org.elasticsearch.cluster.coordination
- ClusterStatePublisher.AckListener - Interface in org.elasticsearch.cluster.coordination
- ClusterStateRequest - Class in org.elasticsearch.action.admin.cluster.state
- ClusterStateRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- ClusterStateRequest(TimeValue) - Constructor for class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- ClusterStateRequestBuilder - Class in org.elasticsearch.action.admin.cluster.state
- ClusterStateRequestBuilder(ElasticsearchClient, TimeValue) - Constructor for class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
- ClusterStateResponse - Class in org.elasticsearch.action.admin.cluster.state
-
The response for getting the cluster state.
- ClusterStateResponse(ClusterName, ClusterState, boolean) - Constructor for class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
- ClusterStateResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
- ClusterStateSerializationStats - Class in org.elasticsearch.cluster.coordination
- ClusterStateSerializationStats(long, long, long, long, long, long) - Constructor for class org.elasticsearch.cluster.coordination.ClusterStateSerializationStats
- ClusterStateSerializationStats(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.ClusterStateSerializationStats
- ClusterStateTaskExecutor<T extends ClusterStateTaskListener> - Interface in org.elasticsearch.cluster
-
An executor for batches of cluster state update tasks.
- ClusterStateTaskExecutor.BatchExecutionContext<T extends ClusterStateTaskListener> - Record Class in org.elasticsearch.cluster
-
Encapsulates the context in which a batch of tasks executes.
- ClusterStateTaskExecutor.TaskContext<T extends ClusterStateTaskListener> - Interface in org.elasticsearch.cluster
-
A task to be executed, along with callbacks for the executor to record the outcome of this task's execution.
- ClusterStateTaskListener - Interface in org.elasticsearch.cluster
- clusterStateUpdate() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.AllocationActionListener
- ClusterStateUpdaters - Class in org.elasticsearch.gateway
- ClusterStateUpdaters() - Constructor for class org.elasticsearch.gateway.ClusterStateUpdaters
- ClusterStateUpdateStats - Class in org.elasticsearch.cluster.service
-
Various statistics (timing information etc) about cluster state updates coordinated by this node.
- ClusterStateUpdateStats(long, long, long, long, long, long, long, long, long, long, long, long, long, long, long, long, long, long, long) - Constructor for class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- ClusterStateUpdateStats(StreamInput) - Constructor for class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- ClusterStateUpdateTask - Class in org.elasticsearch.cluster
-
A task that can update the cluster state.
- ClusterStateUpdateTask() - Constructor for class org.elasticsearch.cluster.ClusterStateUpdateTask
- ClusterStateUpdateTask(Priority) - Constructor for class org.elasticsearch.cluster.ClusterStateUpdateTask
- ClusterStateUpdateTask(Priority, TimeValue) - Constructor for class org.elasticsearch.cluster.ClusterStateUpdateTask
- ClusterStateUpdateTask(TimeValue) - Constructor for class org.elasticsearch.cluster.ClusterStateUpdateTask
- clusterStateVersion() - Method in record class org.elasticsearch.cluster.coordination.ClusterFormationFailureHelper.ClusterFormationState
-
Returns the value of the
clusterStateVersion
record component. - clusterStateVersion() - Method in record class org.elasticsearch.cluster.metadata.Manifest
-
Returns the value of the
clusterStateVersion
record component. - clusterStateVersion() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- clusterStateVersion() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- clusterStateVersion() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- clusterStateVersion() - Method in class org.elasticsearch.indices.recovery.StatelessPrimaryRelocationAction.Request
- clusterStats(ClusterStatsRequest, ActionListener<ClusterStatsResponse>) - Method in class org.elasticsearch.client.internal.ClusterAdminClient
- ClusterStatsFeatures - Class in org.elasticsearch.action.admin.cluster.stats
-
Spec for cluster stats features.
- ClusterStatsFeatures() - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsFeatures
- ClusterStatsIndices - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsIndices(List<ClusterStatsNodeResponse>, MappingStats, AnalysisStats, VersionStats) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- ClusterStatsIndices.ShardStats - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsLevel - Enum Class in org.elasticsearch.action
- ClusterStatsNodeRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction.ClusterStatsNodeRequest
- ClusterStatsNodeResponse - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsNodeResponse(DiscoveryNode, ClusterHealthStatus, NodeInfo, NodeStats, ShardStats[], SearchUsageStats, RepositoryUsageStats, CCSTelemetrySnapshot) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
- ClusterStatsNodeResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
- ClusterStatsNodes - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsNodes.Counts - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsNodes.JvmStats - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsNodes.JvmVersion - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsNodes.OsStats - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsNodes.ProcessStats - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsRequest - Class in org.elasticsearch.action.admin.cluster.stats
-
A request to get cluster level stats.
- ClusterStatsRequest(boolean, String...) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequest
- ClusterStatsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequest
-
Get stats from nodes based on the nodes ids specified.
- ClusterStatsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsRequestBuilder(ElasticsearchClient) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequestBuilder
- ClusterStatsResponse - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsResponse(long, String, ClusterName, List<ClusterStatsNodeResponse>, List<FailedNodeException>, MappingStats, AnalysisStats, VersionStats, ClusterSnapshotStats, Map<String, ClusterStatsResponse.RemoteClusterStats>) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- ClusterStatsResponse.RemoteClusterStats - Record Class in org.elasticsearch.action.admin.cluster.stats
-
Represents the information about a remote cluster.
- clusterStatus() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
-
Cluster Health Status, only populated on master nodes.
- clusterSupportsFeature - Variable in class org.elasticsearch.search.retriever.RetrieverParserContext
- clusterSupportsFeature(NodeFeature) - Method in class org.elasticsearch.search.retriever.RetrieverParserContext
- clusterTransportVersion() - Method in class org.elasticsearch.index.mapper.MappingParserContext
- ClusterUpdateSettingsAction - Class in org.elasticsearch.action.admin.cluster.settings
- ClusterUpdateSettingsRequest - Class in org.elasticsearch.action.admin.cluster.settings
-
Request for an update cluster settings action
- ClusterUpdateSettingsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- ClusterUpdateSettingsRequest(TimeValue, TimeValue) - Constructor for class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- ClusterUpdateSettingsRequest.Factory - Interface in org.elasticsearch.action.admin.cluster.settings
- ClusterUpdateSettingsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.settings
-
Builder for a cluster update settings request
- ClusterUpdateSettingsRequestBuilder(ElasticsearchClient, TimeValue, TimeValue) - Constructor for class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
- ClusterUpdateSettingsResponse - Class in org.elasticsearch.action.admin.cluster.settings
-
A response for a cluster update settings action.
- clusterUUID - Variable in class org.elasticsearch.gateway.PersistedClusterStateService.OnDiskState
- clusterUUID() - Method in record class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse.RemoteClusterStats
-
Returns the value of the
clusterUUID
record component. - clusterUUID() - Method in class org.elasticsearch.cluster.metadata.Metadata
- clusterUUID() - Method in record class org.elasticsearch.gateway.PersistedClusterStateService.OnDiskStateMetadata
-
Returns the value of the
clusterUUID
record component. - clusterUUID(String) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- clusterUUIDCommitted - Variable in class org.elasticsearch.gateway.PersistedClusterStateService.OnDiskState
- clusterUUIDCommitted() - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Whether the current node with the given cluster state is locked into the cluster with the UUID returned by
Metadata.clusterUUID()
, meaning that it will not accept any cluster state with a different clusterUUID. - clusterUUIDCommitted() - Method in record class org.elasticsearch.gateway.PersistedClusterStateService.OnDiskStateMetadata
-
Returns the value of the
clusterUUIDCommitted
record component. - clusterUUIDCommitted(boolean) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- CMP - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- codec(String) - Method in interface org.elasticsearch.index.codec.CodecProvider
- codec(String) - Method in class org.elasticsearch.index.codec.CodecService
- CodecProvider - Interface in org.elasticsearch.index.codec
-
Abstracts codec lookup by name, to make CodecService extensible.
- CodecService - Class in org.elasticsearch.index.codec
-
Since Lucene 4.0 low level index segments are read and written through a codec layer that allows to use use-case specific file formats & data-structures per field.
- CodecService(MapperService, BigArrays) - Constructor for class org.elasticsearch.index.codec.CodecService
- CodecService.DeduplicateFieldInfosCodec - Class in org.elasticsearch.index.codec
- coerce - Variable in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper
- coerce - Variable in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- coerce() - Method in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper
- COERCE - Enum constant in enum class org.elasticsearch.index.query.GeoValidationMethod
- COERCE_SETTING - Static variable in class org.elasticsearch.index.mapper.FieldMapper
- COERCE_SETTING - Static variable in class org.elasticsearch.index.mapper.NumberFieldMapper
- coerceParam(Function<FieldMapper, Explicit<Boolean>>, boolean) - Static method in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper
- collapse() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- collapse() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- collapse() - Method in class org.elasticsearch.search.internal.SearchContext
- collapse() - Method in class org.elasticsearch.search.internal.SubSearchContext
- collapse() - Method in class org.elasticsearch.search.rank.RankSearchContext
-
Collapse is not supported by ranking.
- collapse(CollapseBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- COLLAPSE - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- COLLAPSE_FIELD - Static variable in class org.elasticsearch.index.query.InnerHitBuilder
- COLLAPSE_FIELD - Static variable in class org.elasticsearch.search.retriever.StandardRetrieverBuilder
- CollapseBuilder - Class in org.elasticsearch.search.collapse
-
A builder that enables field collapsing on search request.
- CollapseBuilder(String) - Constructor for class org.elasticsearch.search.collapse.CollapseBuilder
-
Public constructor
- CollapseBuilder(StreamInput) - Constructor for class org.elasticsearch.search.collapse.CollapseBuilder
- CollapseContext - Class in org.elasticsearch.search.collapse
-
Context used for field collapsing
- CollapseContext(String, MappedFieldType) - Constructor for class org.elasticsearch.search.collapse.CollapseContext
- collapseField() - Method in record class org.elasticsearch.action.search.SearchPhaseController.SortedTopDocs
-
Returns the value of the
collapseField
record component. - collapseType() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- collapseType() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns the collapse type of the field CollapseType.NONE means the field can'be used for collapsing.
- collapseType() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- collapseValues() - Method in record class org.elasticsearch.action.search.SearchPhaseController.SortedTopDocs
-
Returns the value of the
collapseValues
record component. - COLLATE_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- COLLATE_MATCH - Static variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- COLLATE_QUERY_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- COLLATE_QUERY_PARAMS - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- COLLATE_QUERY_PRUNE - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- collateMatch() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- collateParams() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
gets additional params for collate script
- collateParams(Map<String, Object>) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Adds additional parameters for collate scripts.
- collatePrune() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Gets whether to prune suggestions after collation
- collatePrune(boolean) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets whether to prune suggestions after collation
- collateQuery() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
gets the query used for filtering out suggested phrases (collation).
- collateQuery(String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets a query used for filtering out suggested phrases (collation).
- collateQuery(Script) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets a query used for filtering out suggested phrases (collation).
- collect(int) - Method in class org.elasticsearch.action.search.MaxScoreCollector
- collect(int) - Method in class org.elasticsearch.lucene.grouping.SinglePassGroupingCollector
- collect(int) - Method in class org.elasticsearch.search.aggregations.LeafBucketCollector
- collect(int, long) - Method in class org.elasticsearch.search.aggregations.LeafBucketCollector
-
Collect the given
doc
in the bucket owned byowningBucketOrd
. - collect(int, long) - Method in class org.elasticsearch.search.aggregations.LeafBucketCollectorBase
- collect(int, long) - Method in class org.elasticsearch.search.profile.aggregation.ProfilingLeafBucketCollector
- collect(int, long) - Method in class org.elasticsearch.search.sort.BucketedSort.Leaf
-
Collect this doc, returning
true
if it is competitive. - collect(long, long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLog
- collect(long, long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
-
Collect a value in the given bucket
- collect(long, long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractLinearCounting
- collect(long, long) - Method in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- COLLECT - Enum constant in enum class org.elasticsearch.search.profile.aggregation.AggregationTimingType
- collectableSubAggregators - Variable in class org.elasticsearch.search.aggregations.AggregatorBase
- collectBucket(LeafBucketCollector, int, long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Utility method to collect the given doc in the given bucket (identified by the bucket ordinal)
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregator
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregator
-
Called for each bucket with a value so the state can be modified based on the key and metric value for this bucket
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregator
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.MaxBucketPipelineAggregator
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.MinBucketPipelineAggregator
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregator
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.StatsBucketPipelineAggregator
- collectBucketValue(String, Double) - Method in class org.elasticsearch.search.aggregations.pipeline.SumBucketPipelineAggregator
- collectData(Map<String, String>) - Method in interface org.elasticsearch.plugins.internal.LoggingDataProvider
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Collect debug information to add to the profiling results.
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregator
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.DeferableBucketAggregator
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterByFilterAggregator
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator
- collectDebugInfo(BiConsumer<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator.CollectorSource
-
Collect debug information to add to the profiling results.
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator.ValuesSourceCollectorSource
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.NumericTermsAggregator
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- collectDebugInfo(BiConsumer<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.GlobalOrdCardinalityAggregator
- collectEncoded(long, int) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLog
- collectExistingBucket(LeafBucketCollector, int, long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Same as
BucketsAggregator.collectBucket(LeafBucketCollector, int, long)
, but doesn't check if the docCounts needs to be re-sized. - collectFieldTypes(Collection<RuntimeField>) - Static method in interface org.elasticsearch.index.mapper.RuntimeField
-
Collect and return all
MappedFieldType
exposed by the providedRuntimeField
s. - COLLECTION_STATISTICS - Enum constant in enum class org.elasticsearch.search.profile.dfs.DfsTimingType
- collectionStatistics(String) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- collectionStrategy - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- collectionToCommaDelimitedString(Iterable<?>) - Static method in class org.elasticsearch.common.Strings
-
Convenience method to return a Collection as a CSV String.
- collectionToDelimitedString(Iterable<?>, String) - Static method in class org.elasticsearch.common.Strings
-
Convenience method to return a Collection as a delimited (e.g.
- collectionToDelimitedString(Iterable<?>, String, String, String) - Static method in class org.elasticsearch.common.Strings
-
Convenience method to return a Collection as a delimited (e.g.
- collectionToDelimitedString(Iterable<?>, String, String, String, StringBuilder) - Static method in class org.elasticsearch.common.Strings
- collectionToDelimitedStringWithLimit(Iterable<?>, String, String, String, int, StringBuilder) - Static method in class org.elasticsearch.common.Strings
-
Converts a collection of items to a string like
Strings.collectionToDelimitedString(Iterable, String, String, String, StringBuilder)
except that it stops if the string gets too long and just indicates how many items were omitted. - CollectionUtils - Class in org.elasticsearch.common.util
-
Collections-related utility methods.
- CollectionUtils() - Constructor for class org.elasticsearch.common.util.CollectionUtils
- collectMappings(ClusterState, String, String) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Collect the given v2 template into an ordered list of mappings.
- collectMappings(ComposableIndexTemplate, Map<String, ComponentTemplate>, String) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Collect the given v2 template into an ordered list of mappings.
- collectMode - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- collectMode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Expert: get the collection mode.
- collectMode(Aggregator.SubAggCollectionMode) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Expert: set the collection mode.
- collectNodes(Set<String>, ActionListener<BiFunction<String, String, DiscoveryNode>>) - Method in class org.elasticsearch.transport.RemoteClusterService
-
Collects all nodes of the given clusters and returns / passes a (clusterAlias, nodeId) to
DiscoveryNode
function on success. - COLLECTOR - Static variable in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- collectorResult() - Method in record class org.elasticsearch.search.query.QueryPhaseResult
-
Returns the value of the
collectorResult
record component. - CollectorResult - Class in org.elasticsearch.search.profile.query
-
Public interface and serialization container for profiled timings of the Collectors used in the search.
- CollectorResult(String, String, long, List<CollectorResult>) - Constructor for class org.elasticsearch.search.profile.query.CollectorResult
- CollectorResult(StreamInput) - Constructor for class org.elasticsearch.search.profile.query.CollectorResult
-
Read from a stream.
- collectSearchShards(String, IntConsumer) - Method in class org.elasticsearch.cluster.routing.IndexRouting
-
Collect all of the shard ids that *may* contain documents with the provided
routing
. - collectSearchShards(String, IntConsumer) - Method in class org.elasticsearch.cluster.routing.IndexRouting.ExtractFromSource
- collectUnmapped(Map<String, DocumentField>, Source) - Method in class org.elasticsearch.search.fetch.subphase.UnmappedFieldFetcher
-
Collect unmapped fields from a Source
- collectV2Mappings(String, ClusterState, String, NamedXContentRegistry, String) - Static method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
- columnAtATimeReader(LeafReaderContext) - Method in class org.elasticsearch.index.mapper.BlockDocValuesReader.DocValuesBlockLoader
- columnAtATimeReader(LeafReaderContext) - Method in interface org.elasticsearch.index.mapper.BlockLoader
- columnAtATimeReader(LeafReaderContext) - Method in class org.elasticsearch.index.mapper.BlockLoader.Delegating
- columnAtATimeReader(LeafReaderContext) - Method in class org.elasticsearch.index.mapper.BlockSourceReader.LongsBlockLoader
- columnAtATimeReader(LeafReaderContext) - Method in class org.elasticsearch.index.mapper.BlockStoredFieldsReader.IdBlockLoader
- columnAtATimeReader(LeafReaderContext) - Method in class org.elasticsearch.index.mapper.SourceFieldBlockLoader
- combine(double, double, double) - Method in enum class org.elasticsearch.common.lucene.search.function.CombineFunction
- combine(float, float) - Method in enum class org.elasticsearch.search.rescore.QueryRescoreMode
- combine(GetFeatureUpgradeStatusResponse.UpgradeStatus...) - Static method in enum class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.UpgradeStatus
- combine(SingleNodeShutdownMetadata.Status...) - Static method in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Status
-
Merges multiple statuses into a single, final, status For example, if called with NOT_STARTED, IN_PROGRESS, and STALLED, the returned state is STALLED.
- Combine(List<IntervalsSourceProvider>, boolean, int, IntervalsSourceProvider.IntervalFilter) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.Combine
- Combine(StreamInput) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.Combine
- CombinedBitSet - Class in org.elasticsearch.lucene.util
-
A
BitSet
implementation that combines two instances ofBitSet
andBits
to provide a single merged view. - CombinedBitSet(BitSet, Bits) - Constructor for class org.elasticsearch.lucene.util.CombinedBitSet
- CombinedDeletionPolicy - Class in org.elasticsearch.index.engine
-
An
IndexDeletionPolicy
that coordinates between Lucene's commits and the retention of translog generation files, making sure that all translog files that are needed to recover from the Lucene commit are not deleted. - combinedFieldsQuery(Object, String...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a combined fields query for the provided field names and text.
- CombinedFieldsQueryBuilder - Class in org.elasticsearch.index.query
-
A query that matches on multiple text fields, as if the field contents had been indexed into a single combined field.
- CombinedFieldsQueryBuilder(Object, String...) - Constructor for class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
-
Constructs a new text query.
- CombinedFieldsQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
-
Read from a stream.
- CombinedRateLimiter - Class in org.elasticsearch.common.util
-
A rate limiter designed for multiple concurrent users.
- CombinedRateLimiter(ByteSizeValue) - Constructor for class org.elasticsearch.common.util.CombinedRateLimiter
- CombineFunction - Enum Class in org.elasticsearch.common.lucene.search.function
- combineInnerRetrieverResults(List<ScoreDoc[]>) - Method in class org.elasticsearch.search.retriever.CompoundRetrieverBuilder
-
Combines the provided
rankResults
to return the final top documents. - combineQueryPhaseResults(List<TopDocs>) - Method in class org.elasticsearch.search.rank.context.QueryPhaseRankShardContext
-
This is used to reduce the number of required results that are serialized to the coordinating node.
- combineQueryPhaseResults(List<TopDocs>) - Method in class org.elasticsearch.search.rank.rerank.RerankingQueryPhaseRankShardContext
- combineScript(Script) - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
-
Set the
combine
script. - CombineScript(Map<String, Object>, Map<String, Object>) - Constructor for class org.elasticsearch.script.ScriptedMetricAggContexts.CombineScript
- combineSources(List<IntervalsSource>, int, boolean) - Static method in class org.elasticsearch.index.query.IntervalBuilder
- combineUnpromotableShardResponses(List<ActionResponse.Empty>) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportUnpromotableShardRefreshAction
- combineUnpromotableShardResponses(List<Response>) - Method in class org.elasticsearch.action.support.broadcast.unpromotable.TransportBroadcastUnpromotableAction
- commaDelimitedListToSet(String) - Static method in class org.elasticsearch.common.Strings
-
Convenience method to convert a CSV string list to a set.
- commaDelimitedListToStringArray(String) - Static method in class org.elasticsearch.common.Strings
-
Convert a CSV list into an array of Strings.
- command() - Method in class org.elasticsearch.cluster.routing.allocation.RerouteExplanation
- COMMAND_NAME_FIELD - Static variable in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
- COMMAND_NAME_FIELD - Static variable in class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand
- COMMAND_NAME_FIELD - Static variable in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
- COMMAND_NAME_FIELD - Static variable in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- COMMAND_NAME_FIELD - Static variable in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- commands() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Get the commands wrapped by this instance
- commands(AllocationCommands) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Set the allocation commands to execute.
- CommandsResult(RoutingExplanations, ClusterState) - Constructor for record class org.elasticsearch.cluster.routing.allocation.AllocationService.CommandsResult
-
Creates an instance of a
CommandsResult
record class. - COMMIT_STATE_ACTION_NAME - Static variable in class org.elasticsearch.cluster.coordination.Coordinator
- commitDescription(IndexCommit) - Static method in class org.elasticsearch.index.engine.CombinedDeletionPolicy
-
Returns a description for a given
IndexCommit
. - commitIndexWriter(IndexWriter, Translog) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Commits the specified index writer.
- CommitInfo(long, long) - Constructor for record class org.elasticsearch.index.seqno.SequenceNumbers.CommitInfo
-
Creates an instance of a
CommitInfo
record class. - commitStats() - Method in class org.elasticsearch.index.engine.Engine
-
get commits stats for the last commit
- commitStats() - Method in class org.elasticsearch.index.shard.IndexShard
- CommitStats - Class in org.elasticsearch.index.engine
-
a class the returns dynamic information with respect to the last commit point of this shard
- CommitStats(SegmentInfos) - Constructor for class org.elasticsearch.index.engine.CommitStats
- committed - Variable in class org.elasticsearch.index.engine.Segment
- commitUserData() - Method in record class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns the value of the
commitUserData
record component. - COMMON_TERMS_QUERY_DEPRECATION_MSG - Static variable in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- CommonFields() - Constructor for class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- CommonFields() - Constructor for class org.elasticsearch.search.aggregations.AggregationBuilder.CommonFields
- CommonStats - Class in org.elasticsearch.action.admin.indices.stats
- CommonStats() - Constructor for class org.elasticsearch.action.admin.indices.stats.CommonStats
- CommonStats(CommonStatsFlags) - Constructor for class org.elasticsearch.action.admin.indices.stats.CommonStats
- CommonStats(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.stats.CommonStats
- CommonStatsFlags - Class in org.elasticsearch.action.admin.indices.stats
-
Contains flags that can be used to regulate the presence and calculation of different stat fields in
CommonStats
. - CommonStatsFlags(CommonStatsFlags.Flag...) - Constructor for class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- CommonStatsFlags(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- CommonStatsFlags.Flag - Enum Class in org.elasticsearch.action.admin.indices.stats
- CommonTermsQueryBuilder - Class in org.elasticsearch.index.query
- CommonTermsQueryBuilder() - Constructor for class org.elasticsearch.index.query.CommonTermsQueryBuilder
- comparator() - Method in class org.elasticsearch.search.aggregations.BucketOrder
-
Build a comparator for fully built buckets.
- comparator() - Method in class org.elasticsearch.search.aggregations.InternalOrder.Aggregation
- comparator() - Method in class org.elasticsearch.search.aggregations.InternalOrder.CompoundOrder
- COMPARATOR - Static variable in class org.elasticsearch.search.suggest.Suggest
- Comparators - Enum Class in org.elasticsearch.common.util
-
Comparator
-related utility methods. - compare(int) - Method in class org.elasticsearch.common.util.BigArrays.DoubleBinarySearcher
- compare(int) - Method in class org.elasticsearch.common.util.BinarySearcher
- compare(long, long) - Method in interface org.elasticsearch.search.aggregations.Aggregator.BucketComparator
-
Compare two buckets by their ordinal.
- compare(String, String) - Static method in class org.elasticsearch.cluster.routing.allocation.DataTier
-
Compares the provided tiers for coldness order (eg.
- compare(ShardRouting, ShardRouting) - Method in class org.elasticsearch.gateway.PriorityComparator
- compare(Suggest.Suggestion.Entry.Option, Suggest.Suggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Frequency
- compare(Suggest.Suggestion.Entry.Option, Suggest.Suggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Score
- COMPARE_BY_NAME - Static variable in class org.elasticsearch.index.Index
- compareAndEnqueue(T, T) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.ContinuousComputation
-
enqueues
input
ifexpectedLatestKnownInput
is the latest known input. - compareAndExchangeRegister(OperationPurpose, String, BytesReference, BytesReference, ActionListener<OptionalBytesReference>) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Atomically sets the value stored at the given key to
updated
if thecurrent value == expected
. - compareAndExchangeRegister(OperationPurpose, String, BytesReference, BytesReference, ActionListener<OptionalBytesReference>) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- compareAndExchangeRegister(OperationPurpose, String, BytesReference, BytesReference, ActionListener<OptionalBytesReference>) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- compareAndSetRegister(OperationPurpose, String, BytesReference, BytesReference, ActionListener<Boolean>) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Atomically sets the value stored at the given key to
updated
if thecurrent value == expected
. - compareAndSetRegister(OperationPurpose, String, BytesReference, BytesReference, ActionListener<Boolean>) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- compareAnyValueToMissing(int) - Method in enum class org.elasticsearch.search.aggregations.bucket.composite.MissingOrder
- compareDiscardNaN(double, double, boolean) - Static method in enum class org.elasticsearch.common.util.Comparators
- compareKey(InternalComposite.InternalBucket) - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite.InternalBucket
- compareKey(InternalDateHistogram.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- compareKey(InternalHistogram.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- compareKey(InternalVariableWidthHistogram.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- compareKey(InternalIpPrefix.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.prefix.InternalIpPrefix.Bucket
- compareKey(DoubleTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms.Bucket
- compareKey(LongRareTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms.Bucket
- compareKey(LongTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- compareKey(StringRareTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms.Bucket
- compareKey(StringTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- compareKey(T) - Method in interface org.elasticsearch.search.aggregations.KeyComparable
-
Compare this
MultiBucketsAggregation.Bucket
skey
with another bucket. - compareTo(IndicesShardStoresResponse.StoreStatus) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
- compareTo(ErrorEntry) - Method in record class org.elasticsearch.action.datastreams.lifecycle.ErrorEntry
-
Compares two error entries by the number of retries, in reversed order by default.
- compareTo(SearchShard) - Method in record class org.elasticsearch.action.search.SearchShard
- compareTo(SearchShardIterator) - Method in class org.elasticsearch.action.search.SearchShardIterator
- compareTo(DesiredNode) - Method in class org.elasticsearch.cluster.metadata.DesiredNode
- compareTo(DesiredNodeWithStatus) - Method in record class org.elasticsearch.cluster.metadata.DesiredNodeWithStatus
- compareTo(DiscoveryNodeRole) - Method in class org.elasticsearch.cluster.node.DiscoveryNodeRole
- compareTo(NodeAllocationResult) - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- compareTo(ShardIterator) - Method in class org.elasticsearch.cluster.routing.PlainShardIterator
- compareTo(BytesReference) - Method in class org.elasticsearch.common.bytes.AbstractBytesReference
- compareTo(BytesReference) - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- compareTo(SpatialPoint) - Method in interface org.elasticsearch.common.geo.SpatialPoint
- compareTo(Text) - Method in class org.elasticsearch.common.text.Text
- compareTo(ByteSizeValue) - Method in class org.elasticsearch.common.unit.ByteSizeValue
- compareTo(DistanceUnit.Distance) - Method in class org.elasticsearch.common.unit.DistanceUnit.Distance
- compareTo(Processors) - Method in class org.elasticsearch.common.unit.Processors
- compareTo(SizeValue) - Method in class org.elasticsearch.common.unit.SizeValue
- compareTo(PrioritizedCallable<T>) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedCallable
- compareTo(PrioritizedRunnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedRunnable
- compareTo(ShardId) - Method in class org.elasticsearch.index.shard.ShardId
- compareTo(BaseTranslogReader) - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- compareTo(Translog.Location) - Method in record class org.elasticsearch.index.translog.Translog.Location
- compareTo(SystemIndexDescriptor) - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- compareTo(SystemIndexDescriptor.MappingsVersion) - Method in record class org.elasticsearch.indices.SystemIndexDescriptor.MappingsVersion
- compareTo(ProcessorInfo) - Method in class org.elasticsearch.ingest.ProcessorInfo
- compareTo(ScriptContextStats) - Method in record class org.elasticsearch.script.ScriptContextStats
- compareTo(InternalGeoGridBucket) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- compareTo(RankDoc) - Method in class org.elasticsearch.search.rank.RankDoc
- compareTo(SearchShardTarget) - Method in class org.elasticsearch.search.SearchShardTarget
- compareTo(SortValue) - Method in class org.elasticsearch.search.sort.SortValue
- compareTo(Correction) - Method in class org.elasticsearch.search.suggest.phrase.Correction
-
Lower scores sorts first; if scores are equal, than later terms (zzz) sort first .
- compareTo(DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
-
Lower scores sort first; if scores are equal, then later (zzz) terms sort first
- compareTo(SnapshotId) - Method in class org.elasticsearch.snapshots.SnapshotId
- compareTo(SnapshotInfo) - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Compares two snapshots by their start time; if the start times are the same, then compares the two snapshots by their snapshot ids.
- compareTo(ThreadPoolStats.Stats) - Method in record class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- compareTo(T) - Method in interface org.elasticsearch.common.VersionId
- compareToSameType(SortValue) - Method in class org.elasticsearch.search.sort.SortValue
-
Compare this sort value to another sort value of the same type.
- COMPATIBILITY - Static variable in record class org.elasticsearch.reservedstate.service.ReservedStateVersion
- compatibilityVersions() - Method in class org.elasticsearch.cluster.ClusterState.Builder
- compatibilityVersions() - Method in class org.elasticsearch.cluster.ClusterState
- compatibilityVersions() - Method in record class org.elasticsearch.cluster.coordination.JoinTask.NodeJoinTask
-
Returns the value of the
compatibilityVersions
record component. - CompatibilityVersions - Record Class in org.elasticsearch.cluster.version
-
Wraps component version numbers for cluster state
- CompatibilityVersions(TransportVersion, Map<String, SystemIndexDescriptor.MappingsVersion>) - Constructor for record class org.elasticsearch.cluster.version.CompatibilityVersions
-
Creates an instance of a
CompatibilityVersions
record class. - CompatibilityVersionsFixupListener - Class in org.elasticsearch.cluster.service
-
This fixes up the compatibility versions (transport version and system index mapping versions) in cluster state.
- CompatibilityVersionsFixupListener(ClusterService, ClusterAdminClient, FeatureService, ThreadPool) - Constructor for class org.elasticsearch.cluster.service.CompatibilityVersionsFixupListener
- compatible(Level, String, String, Object...) - Method in class org.elasticsearch.common.logging.DeprecationLogger
-
Used for handling previous version RestApiCompatible logic.
- COMPATIBLE_API - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- compatibleCritical(String, String, Object...) - Method in class org.elasticsearch.common.logging.DeprecationLogger
-
Used for handling previous version RestApiCompatible logic.
- compatibleDeprecationMessage(String, String, String, String, Object...) - Static method in class org.elasticsearch.common.logging.DeprecatedMessage
- compatibleWith() - Method in record class org.elasticsearch.reservedstate.service.ReservedStateVersion
-
Returns the value of the
compatibleWith
record component. - CompensatedSum - Class in org.elasticsearch.search.aggregations.metrics
-
Used to calculate sums using the Kahan summation algorithm.
- CompensatedSum() - Constructor for class org.elasticsearch.search.aggregations.metrics.CompensatedSum
- CompensatedSum(double, double) - Constructor for class org.elasticsearch.search.aggregations.metrics.CompensatedSum
-
Used to calculate sums using the Kahan summation algorithm.
- competitiveIterator() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingLeafBucketCollector
- compilationContexts - Variable in class org.elasticsearch.script.ScriptService.ContextSettings
- compilationLimitTriggered() - Method in record class org.elasticsearch.script.ScriptContextStats
-
Returns the value of the
compilationLimitTriggered
record component. - compilationLimitTriggered() - Method in record class org.elasticsearch.script.ScriptStats
-
Returns the value of the
compilationLimitTriggered
record component. - CompilationRate(Integer, TimeValue) - Constructor for class org.elasticsearch.script.ScriptCache.CompilationRate
- CompilationRate(String) - Constructor for class org.elasticsearch.script.ScriptCache.CompilationRate
-
Parses a string as a non-negative int count and a
TimeValue
as arguments split by a slash - CompilationRate(Tuple<Integer, TimeValue>) - Constructor for class org.elasticsearch.script.ScriptCache.CompilationRate
- compilationRateLimited - Variable in class org.elasticsearch.script.ScriptContext
-
Is compilation rate limiting enabled for this context?
- compilations() - Method in record class org.elasticsearch.script.ScriptContextStats
-
Returns the value of the
compilations
record component. - compilations() - Method in record class org.elasticsearch.script.ScriptStats
-
Returns the value of the
compilations
record component. - compilationsHistory() - Method in record class org.elasticsearch.script.ScriptContextStats
-
Returns the value of the
compilationsHistory
record component. - compilationsHistory() - Method in record class org.elasticsearch.script.ScriptStats
-
Returns the value of the
compilationsHistory
record component. - compile(String, String) - Static method in class org.elasticsearch.common.regex.Regex
- compile(String, String, ScriptContext<FactoryType>, Map<String, String>) - Method in interface org.elasticsearch.script.ScriptEngine
-
Compiles a script.
- compile(String, Script, ScriptCompiler) - Method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- compile(Script, ScriptContext<FactoryType>) - Method in class org.elasticsearch.index.query.FilteredSearchExecutionContext
- compile(Script, ScriptContext<FactoryType>) - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Compile script using script service
- compile(Script, ScriptContext<FactoryType>) - Method in class org.elasticsearch.script.ScriptService
-
Compiles a script using the given context.
- compile(Script, ScriptContext<FactoryType>) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Compile a script.
- compile(Script, ScriptContext<FactoryType>) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- compile(Script, ScriptContext<T>) - Method in interface org.elasticsearch.script.ScriptCompiler
-
Takes a Script definition and returns a compiled script factory
- compileTemplate(String, String, String, String, ScriptService) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- COMPLEMENT - Enum constant in enum class org.elasticsearch.index.query.RegexpFlag
-
Enables complement expression of the form:
~<expression>
- complete - Variable in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- complete(long) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.PendingListenersQueue
- COMPLETE - Enum constant in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Status
- completeAllAsNotMaster() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.PendingListenersQueue
- completed() - Method in enum class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Returns true if snapshot completed (successfully or not)
- completed() - Method in enum class org.elasticsearch.cluster.RestoreInProgress.State
-
Returns true if restore process completed (either successfully or with failure)
- completed() - Method in enum class org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- completed() - Method in enum class org.elasticsearch.cluster.SnapshotsInProgress.State
- completed() - Method in enum class org.elasticsearch.snapshots.SnapshotState
-
Returns true if snapshot completed (successfully or not)
- completed() - Method in record class org.elasticsearch.threadpool.ThreadPoolStats.Stats
-
Returns the value of the
completed
record component. - completed(Collection<SnapshotsInProgress.ShardSnapshotStatus>) - Static method in class org.elasticsearch.cluster.SnapshotsInProgress
-
Checks if all shards in the list have completed
- completed(Map<ShardId, RestoreInProgress.ShardRestoreStatus>) - Static method in class org.elasticsearch.snapshots.RestoreService
- COMPLETED - Enum constant in enum class org.elasticsearch.persistent.AllocatedPersistentTask.State
- completedNodes() - Method in class org.elasticsearch.cluster.coordination.Publication
- completePersistentTask(String, long, Exception, ActionListener<PersistentTasksCustomMetadata.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksClusterService
-
Restarts a record about a running persistent task from cluster state
- completeRelocationHandoff() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Marks a relocation handoff attempt as successful.
- completeToLastConvergedIndex() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceShardsAllocator
- completeWith(ActionListener<Response>, CheckedSupplier<Response, ? extends Exception>) - Static method in interface org.elasticsearch.action.ActionListener
-
Completes the given listener with the result from the provided supplier accordingly.
- completingElection(Stream<JoinTask.NodeJoinTask>, long) - Static method in record class org.elasticsearch.cluster.coordination.JoinTask
- completion - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- completion() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- completion(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- Completion - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- COMPLETION - Enum constant in enum class org.elasticsearch.inference.TaskType
- completionDataFields() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- completionDataFields(String...) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- CompletionFieldMapper - Class in org.elasticsearch.index.mapper
-
Mapper for completion field.
- CompletionFieldMapper(String, MappedFieldType, FieldMapper.BuilderParams, CompletionFieldMapper.Builder) - Constructor for class org.elasticsearch.index.mapper.CompletionFieldMapper
- CompletionFieldMapper.Builder - Class in org.elasticsearch.index.mapper
-
Builder for
CompletionFieldMapper
- CompletionFieldMapper.CompletionFieldType - Class in org.elasticsearch.index.mapper
- CompletionFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- CompletionFieldMapper.Fields - Class in org.elasticsearch.index.mapper
- completionFields() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- completionFields(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- CompletionFieldType(String, NamedAnalyzer, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- CompletionPersistentTaskAction - Class in org.elasticsearch.persistent
-
ActionType that is used by executor node to indicate that the persistent action finished or failed on the node and needs to be removed from the cluster state in case of successful completion or restarted on some other node in case of failure.
- CompletionPersistentTaskAction.Request - Class in org.elasticsearch.persistent
- CompletionPersistentTaskAction.TransportAction - Class in org.elasticsearch.persistent
- completionStats(String...) - Method in class org.elasticsearch.index.engine.Engine
-
Returns the
CompletionStats
for this engine - completionStats(String...) - Method in class org.elasticsearch.index.engine.InternalEngine
- completionStats(String...) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- completionStats(String...) - Method in class org.elasticsearch.index.shard.IndexShard
- CompletionStats - Class in org.elasticsearch.search.suggest.completion
- CompletionStats() - Constructor for class org.elasticsearch.search.suggest.completion.CompletionStats
- CompletionStats(long, FieldMemoryStats) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionStats
- CompletionStats(StreamInput) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionStats
- CompletionStatsCache - Class in org.elasticsearch.index.engine
- CompletionStatsCache(Supplier<Engine.Searcher>) - Constructor for class org.elasticsearch.index.engine.CompletionStatsCache
- CompletionSuggester - Class in org.elasticsearch.search.suggest.completion
- completionSuggestion(String) - Static method in class org.elasticsearch.search.suggest.SuggestBuilders
-
Creates a completion suggestion lookup query with the provided
field
- CompletionSuggestion - Class in org.elasticsearch.search.suggest.completion
-
Suggestion response for
CompletionSuggester
results Response format for each entry: { "text" : STRING "score" : FLOAT "contexts" : CONTEXTS } CONTEXTS : { "CONTEXT_NAME" : ARRAY, .. - CompletionSuggestion(String, int, boolean) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion
-
Creates a completion suggestion given its name, size and whether it should skip duplicates
- CompletionSuggestion(StreamInput) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- CompletionSuggestion.Entry - Class in org.elasticsearch.search.suggest.completion
- CompletionSuggestion.Entry.Option - Class in org.elasticsearch.search.suggest.completion
- CompletionSuggestionBuilder - Class in org.elasticsearch.search.suggest.completion
-
Defines a suggest command based on a prefix, typically to provide "auto-complete" functionality for users as they type search terms.
- CompletionSuggestionBuilder(String) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- CompletionSuggestionBuilder(StreamInput) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Read from a stream.
- CompletionSuggestionContext - Class in org.elasticsearch.search.suggest.completion
- CompletionSuggestionContext(SearchExecutionContext) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
- COMPONENT_TEMPLATE - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Response
- COMPONENT_TEMPLATES - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Response
- component2D - Variable in class org.elasticsearch.lucene.spatial.Component2DVisitor
- Component2DVisitor - Class in org.elasticsearch.lucene.spatial
-
A
TriangleTreeVisitor.TriangleTreeDecodedVisitor
implementation forComponent2D
geometries. - componentId() - Method in interface org.elasticsearch.action.admin.cluster.node.info.ComponentVersionNumber
-
Returns the component id to report this number under.
- componentNameFromReservedName(String) - Static method in class org.elasticsearch.action.admin.indices.template.reservedstate.ReservedComposableIndexTemplateAction
-
Removes the reserved cluster state prefix from the component template name
- COMPONENTS - Static variable in class org.elasticsearch.action.admin.indices.template.reservedstate.ReservedComposableIndexTemplateAction
- componentTemplate() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction.Request
- componentTemplate(ComponentTemplate) - Method in class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction.Request
-
The component template that will be inserted into the cluster state
- ComponentTemplate - Class in org.elasticsearch.cluster.metadata
-
A component template is a re-usable
Template
as well as metadata about the template. - ComponentTemplate(Template, Long, Map<String, Object>) - Constructor for class org.elasticsearch.cluster.metadata.ComponentTemplate
- ComponentTemplate(Template, Long, Map<String, Object>, Boolean) - Constructor for class org.elasticsearch.cluster.metadata.ComponentTemplate
- ComponentTemplate(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.ComponentTemplate
- ComponentTemplateMetadata - Class in org.elasticsearch.cluster.metadata
-
ComponentTemplateMetadata
is a customMetadata
implementation for storing a map of component templates and their names. - ComponentTemplateMetadata(Map<String, ComponentTemplate>) - Constructor for class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- ComponentTemplateMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- componentTemplates() - Method in class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- componentTemplates() - Method in class org.elasticsearch.cluster.metadata.Metadata
- componentTemplates(List<String>) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.Builder
- componentTemplates(Map<String, ComponentTemplate>) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- ComponentVersionNumber - Interface in org.elasticsearch.action.admin.cluster.node.info
-
Represents a version number of a subsidiary component to be reported in node info
- COMPOSABLE_PREFIX - Static variable in class org.elasticsearch.action.admin.indices.template.reservedstate.ReservedComposableIndexTemplateAction
- composableIndexNameFromReservedName(String) - Static method in class org.elasticsearch.action.admin.indices.template.reservedstate.ReservedComposableIndexTemplateAction
-
Removes the reserved cluster state prefix from the composable index template name
- ComposableIndexTemplate - Class in org.elasticsearch.cluster.metadata
-
An index template consists of a set of index patterns, an optional template, and a list of ids corresponding to component templates that should be composed in order when creating a new index.
- ComposableIndexTemplate(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- ComposableIndexTemplate.Builder - Class in org.elasticsearch.cluster.metadata
- ComposableIndexTemplate.DataStreamTemplate - Class in org.elasticsearch.cluster.metadata
- ComposableIndexTemplateMetadata - Class in org.elasticsearch.cluster.metadata
-
The
ComposableIndexTemplateMetadata
class is a customMetadata.Custom
implementation that stores a map of ids toComposableIndexTemplate
templates. - ComposableIndexTemplateMetadata(Map<String, ComposableIndexTemplate>) - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- ComposableIndexTemplateMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- COMPOSABLES - Static variable in class org.elasticsearch.action.admin.indices.template.reservedstate.ReservedComposableIndexTemplateAction
- composeDataLifecycles(List<DataStreamLifecycle>) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
This method composes a series of lifecycles to a final one.
- composedOf() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- composite(String, List<CompositeValuesSourceBuilder<?>>) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
CompositeAggregationBuilder
aggregation with the given name. - CompositeAggregation - Interface in org.elasticsearch.search.aggregations.bucket.composite
- CompositeAggregation.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.composite
- CompositeAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.composite
- CompositeAggregationBuilder(String, List<CompositeValuesSourceBuilder<?>>) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- CompositeAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- CompositeAggregationBuilder(CompositeAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- CompositeAggregator - Class in org.elasticsearch.search.aggregations.bucket.composite
- CompositeBytesReference - Class in org.elasticsearch.common.bytes
-
A composite
BytesReference
that allows joining multiple bytes references into one without copying. - CompositeFieldScript - Class in org.elasticsearch.script
-
A script that emits a map of multiple values, that can then be accessed by child runtime fields.
- CompositeFieldScript(String, Map<String, Object>, SearchLookup, OnScriptError, LeafReaderContext) - Constructor for class org.elasticsearch.script.CompositeFieldScript
- CompositeFieldScript.EmitField - Class in org.elasticsearch.script
- CompositeFieldScript.EmitMap - Class in org.elasticsearch.script
- CompositeFieldScript.Factory - Interface in org.elasticsearch.script
- CompositeFieldScript.LeafFactory - Interface in org.elasticsearch.script
- CompositeIndexFoldersDeletionListener - Class in org.elasticsearch.indices.store
- CompositeIndexFoldersDeletionListener(List<IndexStorePlugin.IndexFoldersDeletionListener>) - Constructor for class org.elasticsearch.indices.store.CompositeIndexFoldersDeletionListener
- CompositeIndicesRequest - Interface in org.elasticsearch.action
-
Marker interface that needs to be implemented by all
ActionRequest
subclasses that are composed of multiple sub-requests which relate to one or more indices. - CompositeListener(List<IndexingOperationListener>, Logger) - Constructor for class org.elasticsearch.index.shard.IndexingOperationListener.CompositeListener
- CompositeRuntimeField - Class in org.elasticsearch.index.mapper
-
A runtime field of type object.
- CompositeSyntheticFieldLoader - Class in org.elasticsearch.index.mapper
-
A
SourceLoader.SyntheticFieldLoader
that uses a set of sub-loaders to produce synthetic source for the field. - CompositeSyntheticFieldLoader(String, String, Collection<CompositeSyntheticFieldLoader.Layer>) - Constructor for class org.elasticsearch.index.mapper.CompositeSyntheticFieldLoader
- CompositeSyntheticFieldLoader(String, String, CompositeSyntheticFieldLoader.Layer...) - Constructor for class org.elasticsearch.index.mapper.CompositeSyntheticFieldLoader
- CompositeSyntheticFieldLoader.DocValuesLayer - Interface in org.elasticsearch.index.mapper
- CompositeSyntheticFieldLoader.Layer - Interface in org.elasticsearch.index.mapper
-
Represents one layer of loading synthetic source values for a field as a part of
CompositeSyntheticFieldLoader
. - CompositeSyntheticFieldLoader.MalformedValuesLayer - Class in org.elasticsearch.index.mapper
-
Layer that loads malformed values stored in a dedicated field with a conventional name.
- CompositeSyntheticFieldLoader.StoredFieldLayer - Class in org.elasticsearch.index.mapper
-
Layer that loads field values from a provided stored field.
- CompositeValuesSourceBuilder<AB extends CompositeValuesSourceBuilder<AB>> - Class in org.elasticsearch.search.aggregations.bucket.composite
-
A
ValuesSource
builder forCompositeAggregationBuilder
- CompositeValuesSourceConfig - Class in org.elasticsearch.search.aggregations.bucket.composite
- CompositeValuesSourceConfig.SingleDimensionValuesSourceProvider - Interface in org.elasticsearch.search.aggregations.bucket.composite
- CompositeValuesSourceParserHelper - Class in org.elasticsearch.search.aggregations.bucket.composite
- CompositeValuesSourceParserHelper() - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceParserHelper
- compound - Variable in class org.elasticsearch.index.engine.Segment
- compound(List<BucketOrder>) - Static method in class org.elasticsearch.search.aggregations.BucketOrder
-
Creates a bucket ordering strategy which sorts buckets based on multiple criteria.
- compound(BucketOrder...) - Static method in class org.elasticsearch.search.aggregations.BucketOrder
-
Creates a bucket ordering strategy which sorts buckets based on multiple criteria.
- CompoundProcessor - Class in org.elasticsearch.ingest
-
A Processor that executes a list of other "processors".
- CompoundProcessor(boolean, List<Processor>, List<Processor>) - Constructor for class org.elasticsearch.ingest.CompoundProcessor
- CompoundProcessor(Processor...) - Constructor for class org.elasticsearch.ingest.CompoundProcessor
- CompoundRetrieverBuilder<T extends CompoundRetrieverBuilder<T>> - Class in org.elasticsearch.search.retriever
-
This abstract retriever defines a compound retriever.
- CompoundRetrieverBuilder(List<CompoundRetrieverBuilder.RetrieverSource>, int) - Constructor for class org.elasticsearch.search.retriever.CompoundRetrieverBuilder
- CompoundRetrieverBuilder.RetrieverSource - Record Class in org.elasticsearch.search.retriever
- compress() - Method in class org.elasticsearch.search.aggregations.metrics.TDigestState
- compress(BytesReference) - Method in interface org.elasticsearch.common.compress.Compressor
-
Compress bytes into a newly allocated buffer.
- compress(BytesReference) - Method in class org.elasticsearch.common.compress.DeflateCompressor
- COMPRESS_SETTING - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
When set to true metadata files are stored in compressed format.
- compressed() - Method in class org.elasticsearch.common.compress.CompressedXContent
-
Return the compressed bytes.
- compressedReference() - Method in class org.elasticsearch.common.compress.CompressedXContent
-
Return the compressed bytes as a
BytesReference
. - CompressedXContent - Class in org.elasticsearch.common.compress
-
Similar class to the
String
class except that it internally stores data using a compressed representation in order to require less permanent memory. - CompressedXContent(byte[]) - Constructor for class org.elasticsearch.common.compress.CompressedXContent
- CompressedXContent(String) - Constructor for class org.elasticsearch.common.compress.CompressedXContent
- CompressedXContent(Map<String, Object>) - Constructor for class org.elasticsearch.common.compress.CompressedXContent
- CompressedXContent(BytesReference) - Constructor for class org.elasticsearch.common.compress.CompressedXContent
-
Create a
CompressedXContent
out of a serializedToXContent
that may already be compressed. - CompressedXContent(ToXContent) - Constructor for class org.elasticsearch.common.compress.CompressedXContent
- CompressedXContent(ToXContent, ToXContent.Params) - Constructor for class org.elasticsearch.common.compress.CompressedXContent
-
Create a
CompressedXContent
out of aToXContent
instance. - compression() - Method in record class org.elasticsearch.http.HttpHandlingSettings
-
Returns the value of the
compression
record component. - compression() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
-
Deprecated.
- compression() - Method in class org.elasticsearch.search.aggregations.metrics.TDigestState
- compression(double) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
-
Deprecated.
- compression(double) - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
-
Set the compression factor of the t-digest sketches used
- Compression - Class in org.elasticsearch.transport
- Compression() - Constructor for class org.elasticsearch.transport.Compression
- COMPRESSION_FIELD - Static variable in enum class org.elasticsearch.search.aggregations.metrics.PercentilesMethod
- Compression.Enabled - Enum Class in org.elasticsearch.transport
- Compression.Scheme - Enum Class in org.elasticsearch.transport
- compressionLevel() - Method in record class org.elasticsearch.http.HttpHandlingSettings
-
Returns the value of the
compressionLevel
record component. - compressionScheme - Variable in class org.elasticsearch.transport.NetworkMessage
- compressor(BytesReference) - Static method in class org.elasticsearch.common.compress.CompressorFactory
- Compressor - Interface in org.elasticsearch.common.compress
- COMPRESSOR - Static variable in class org.elasticsearch.common.compress.CompressorFactory
- CompressorFactory - Class in org.elasticsearch.common.compress
- CompressorFactory() - Constructor for class org.elasticsearch.common.compress.CompressorFactory
- computationActive() - Method in record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceStats
-
Returns the value of the
computationActive
record component. - computationConverged() - Method in record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceStats
-
Returns the value of the
computationConverged
record component. - computationExecuted() - Method in record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceStats
-
Returns the value of the
computationExecuted
record component. - computationIterations() - Method in record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceStats
-
Returns the value of the
computationIterations
record component. - computationsConverged - Variable in class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceShardsAllocator
- computationsExecuted - Variable in class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceShardsAllocator
- computationsSubmitted - Variable in class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceShardsAllocator
- computationSubmitted() - Method in record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceStats
-
Returns the value of the
computationSubmitted
record component. - compute(DesiredBalance, DesiredBalanceInput, Queue<List<MoveAllocationCommand>>, Predicate<DesiredBalanceInput>) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceComputer
- COMPUTE_MAX_SCORE - Enum constant in enum class org.elasticsearch.search.profile.query.QueryTimingType
- computedGlobalCheckpoint() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Returns the global checkpoint computed on the primary shard.
- ComputedNodeStats(String, int, int, double, double) - Constructor for class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- computedShardMovements - Variable in class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceShardsAllocator
- computedShardMovements() - Method in record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceStats
-
Returns the value of the
computedShardMovements
record component. - computeIfAbsent(K, CacheLoader<K, V>) - Method in class org.elasticsearch.common.cache.Cache
-
If the specified key is not already associated with a value (or is mapped to null), attempts to compute its value using the given mapping function and enters it into this map unless null.
- computeMedianAbsoluteDeviation(TDigestState) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalMedianAbsoluteDeviation
- computeNorm(FieldInvertState) - Method in class org.elasticsearch.index.similarity.NonNegativeScoresSimilarity
- computeNorm(FieldInvertState) - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity
- computeNorm(FieldInvertState) - Method in class org.elasticsearch.lucene.similarity.LegacyBM25Similarity
-
Deprecated.
- computeNxys(long, long, long, long, String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
- computeRankScoresForGlobalResults(List<RankFeatureResult>, ActionListener<RankFeatureDoc[]>) - Method in class org.elasticsearch.search.rank.context.RankFeaturePhaseRankCoordinatorContext
-
This method is responsible for ranking the global results based on the provided rank feature results from each shard.
- computeRecoveryPlan(ShardId, String, Store.MetadataSnapshot, Store.MetadataSnapshot, long, int, IndexVersion, boolean, boolean, ActionListener<ShardRecoveryPlan>) - Method in class org.elasticsearch.indices.recovery.plan.PeerOnlyRecoveryPlannerService
- computeRecoveryPlan(ShardId, String, Store.MetadataSnapshot, Store.MetadataSnapshot, long, int, IndexVersion, boolean, boolean, ActionListener<ShardRecoveryPlan>) - Method in interface org.elasticsearch.indices.recovery.plan.RecoveryPlannerService
- computeScores(RankFeatureDoc[], ActionListener<float[]>) - Method in class org.elasticsearch.search.rank.context.RankFeaturePhaseRankCoordinatorContext
-
Computes the updated scores for a list of features (i.e.
- computeSlices(List<LeafReaderContext>, int, int) - Static method in class org.elasticsearch.search.internal.ContextIndexSearcher
-
Each computed slice contains at least 10% of the total data in the leaves with a minimum given by the
minDocsPerSlice
parameter and the final number ofIndexSearcher.LeafSlice
will be equal or lower than the max number of slices. - computeSquaredMagnitude(VectorData) - Method in enum class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.ElementType
- computeUsages(FieldInfo[]) - Static method in class org.elasticsearch.index.codec.FieldInfosWithUsages
- computeWaitForCheckpoint(Map<String, long[]>, ShardId, int) - Static method in class org.elasticsearch.search.internal.ShardSearchRequest
- concat(Iterator<? extends T>...) - Static method in class org.elasticsearch.common.collect.Iterators
- concat(T[], T[]) - Static method in class org.elasticsearch.common.util.ArrayUtils
-
Concatenates 2 arrays
- concatLists(List<E>, Collection<E>) - Static method in class org.elasticsearch.common.util.CollectionUtils
- concatStringArrays(String[], String[]) - Static method in class org.elasticsearch.common.Strings
-
Concatenate two string arrays into a third
- CONCRETE_INDEX - Enum constant in enum class org.elasticsearch.cluster.metadata.IndexAbstraction.Type
-
An index abstraction that refers to a single concrete index.
- concreteIndex() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- concreteIndex() - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction.InternalRequest
- ConcreteIndex(IndexMetadata) - Constructor for class org.elasticsearch.cluster.metadata.IndexAbstraction.ConcreteIndex
- ConcreteIndex(IndexMetadata, DataStream) - Constructor for class org.elasticsearch.cluster.metadata.IndexAbstraction.ConcreteIndex
- concreteIndexNames(ClusterState, IndicesRequest) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Same as
IndexNameExpressionResolver.concreteIndexNames(ClusterState, IndicesOptions, String...)
, but the index expressions and options are encapsulated in the specified request. - concreteIndexNames(ClusterState, IndicesOptions, boolean, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- concreteIndexNames(ClusterState, IndicesOptions, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Translates the provided index expression into actual concrete indices, properly deduplicated.
- concreteIndexNames(ClusterState, IndicesOptions, IndicesRequest) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- concreteIndexNamesWithSystemIndexAccess(ClusterState, IndicesRequest) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Same as
IndexNameExpressionResolver.concreteIndexNames(ClusterState, IndicesRequest)
, but access to system indices is always allowed. - concreteIndices(ClusterState, IndicesRequest) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Same as
IndexNameExpressionResolver.concreteIndices(ClusterState, IndicesOptions, String...)
, but the index expressions and options are encapsulated in the specified request and resolves data streams. - concreteIndices(ClusterState, IndicesRequest, long) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Translates the provided index expression into actual concrete indices, properly deduplicated.
- concreteIndices(ClusterState, IndicesOptions, boolean, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- concreteIndices(ClusterState, IndicesOptions, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Translates the provided index expression into actual concrete indices, properly deduplicated.
- ConcreteReplicaRequest(Writeable.Reader<R>, StreamInput) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteReplicaRequest
- ConcreteReplicaRequest(R, String, long, long, long) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteReplicaRequest
- ConcreteShardRequest(Writeable.Reader<R>, StreamInput) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- ConcreteShardRequest(R, String, long) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- ConcreteShardRequest(R, String, long, boolean, boolean) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- concreteSingleIndex(ClusterState, IndicesRequest) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Utility method that allows to resolve an index expression to its corresponding single concrete index.
- concreteTargetOptions() - Method in record class org.elasticsearch.action.support.IndicesOptions
-
Returns the value of the
concreteTargetOptions
record component. - concreteTargetOptions(IndicesOptions.ConcreteTargetOptions) - Method in class org.elasticsearch.action.support.IndicesOptions.Builder
- ConcreteTargetOptions(boolean) - Constructor for record class org.elasticsearch.action.support.IndicesOptions.ConcreteTargetOptions
-
Creates an instance of a
ConcreteTargetOptions
record class. - concreteWriteIndex(ClusterState, IndicesRequest) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Utility method that allows to resolve an index expression to its corresponding single write index.
- concreteWriteIndex(ClusterState, IndicesOptions, String, boolean, boolean) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Utility method that allows to resolve an index expression to its corresponding single write index.
- concurrent(Recycler.Factory<T>, int) - Static method in enum class org.elasticsearch.common.recycler.Recyclers
-
Create a concurrent implementation that can support concurrent access from
concurrencyLevel
threads with little contention. - CONCURRENT - Enum constant in enum class org.elasticsearch.common.util.PageCacheRecycler.Type
- CONCURRENT_REPOSITORY_WRITERS - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- ConcurrentCollections - Class in org.elasticsearch.common.util.concurrent
- concurrentDeque(Recycler.C<T>, int) - Static method in enum class org.elasticsearch.common.recycler.Recyclers
-
Return a concurrent recycler based on a deque.
- ConcurrentDequeRecycler<T> - Class in org.elasticsearch.common.recycler
- ConcurrentDequeRecycler(Recycler.C<T>, int) - Constructor for class org.elasticsearch.common.recycler.ConcurrentDequeRecycler
- ConcurrentRebalanceAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
Similar to the
ClusterRebalanceAllocationDecider
thisAllocationDecider
controls the number of currently in-progress re-balance (relocation) operations and restricts node allocations if the configured threshold is reached. - ConcurrentRebalanceAllocationDecider(ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ConcurrentRebalanceAllocationDecider
- ConcurrentSnapshotExecutionException - Exception in org.elasticsearch.snapshots
-
Thrown when a user tries to multiple conflicting snapshot/restore operations at the same time.
- ConcurrentSnapshotExecutionException(String, String, String) - Constructor for exception org.elasticsearch.snapshots.ConcurrentSnapshotExecutionException
- ConcurrentSnapshotExecutionException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.ConcurrentSnapshotExecutionException
- ConcurrentSnapshotExecutionException(Snapshot, String) - Constructor for exception org.elasticsearch.snapshots.ConcurrentSnapshotExecutionException
- condition() - Method in record class org.elasticsearch.action.admin.indices.rollover.Condition.Result
-
Returns the value of the
condition
record component. - Condition<T> - Class in org.elasticsearch.action.admin.indices.rollover
-
Base class for rollover request conditions
- Condition(String, Condition.Type) - Constructor for class org.elasticsearch.action.admin.indices.rollover.Condition
- CONDITION_FIELD - Static variable in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- Condition.Result - Record Class in org.elasticsearch.action.admin.indices.rollover
-
Holder for evaluated condition result
- Condition.Stats - Record Class in org.elasticsearch.action.admin.indices.rollover
-
Holder for index stats used to evaluate conditions
- Condition.Type - Enum Class in org.elasticsearch.action.admin.indices.rollover
- ConditionalProcessor - Class in org.elasticsearch.ingest
-
A wrapping processor that adds 'if' logic around the wrapped processor.
- confidence() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the
PhraseSuggestionBuilder.confidence()
parameter - confidence(float) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets the confidence level for this suggester.
- CONFIDENCE_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- confidenceInterval - Variable in class org.elasticsearch.index.codec.vectors.ES814ScalarQuantizedVectorsFormat
-
Controls the confidence interval used to scalar quantize the vectors the default value is calculated as `1-1/(vector_dimensions + 1)`
- config - Variable in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
- config() - Method in class org.elasticsearch.action.downsample.DownsampleTask
- config() - Method in record class org.elasticsearch.cluster.metadata.DataStreamLifecycle.Downsampling.Round
-
Returns the value of the
config
record component. - config() - Method in class org.elasticsearch.index.engine.Engine
- Config(CorsHandler.Config.Builder) - Constructor for class org.elasticsearch.http.CorsHandler.Config
- configDir() - Method in record class org.elasticsearch.bootstrap.ServerArgs
-
Returns the value of the
configDir
record component. - configFile() - Method in class org.elasticsearch.env.Environment
-
The config directory.
- configs - Variable in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
- ConfigurableTypeParser(Function<MappingParserContext, MetadataFieldMapper>, Function<MappingParserContext, MetadataFieldMapper.Builder>) - Constructor for class org.elasticsearch.index.mapper.MetadataFieldMapper.ConfigurableTypeParser
- ConfigurationException - Exception in org.elasticsearch.injection.guice
-
Thrown when a programming error such as a misplaced annotation, illegal binding, or unsupported scope is found.
- ConfigurationException(Iterable<Message>) - Constructor for exception org.elasticsearch.injection.guice.ConfigurationException
-
Creates a ConfigurationException containing
messages
. - ConfigurationUtils - Class in org.elasticsearch.ingest
- configure() - Method in class org.elasticsearch.action.ActionModule
- configure() - Method in class org.elasticsearch.cluster.ClusterModule
- configure() - Method in class org.elasticsearch.discovery.DiscoveryModule
- configure() - Method in class org.elasticsearch.gateway.GatewayModule
- configure() - Method in class org.elasticsearch.indices.IndicesModule
- configure() - Method in class org.elasticsearch.injection.guice.AbstractModule
-
Configures a
Binder
via the exposed methods. - configure(Environment, boolean) - Static method in class org.elasticsearch.common.logging.LogConfigurator
-
Configure logging reading from any log4j2.properties found in the config directory and its subdirectories from the specified environment.
- configure(Binder) - Method in class org.elasticsearch.common.settings.SettingsModule
- configure(Binder) - Method in class org.elasticsearch.injection.guice.AbstractModule
- configure(Binder) - Method in interface org.elasticsearch.injection.guice.Module
-
Contributes bindings and other configurations for this module to
binder
. - configure(Binder) - Method in class org.elasticsearch.injection.guice.multibindings.MapBinder.RealMapBinder
- configure(Binder) - Method in class org.elasticsearch.injection.guice.multibindings.Multibinder.RealMultibinder
- ConfiguredHostsResolver - Interface in org.elasticsearch.discovery
- configureESLogging() - Static method in class org.elasticsearch.common.logging.LogConfigurator
- configureNodeAndClusterIdStateListener(ClusterService) - Method in class org.elasticsearch.node.Node
- configureWithoutConfig(Settings) - Static method in class org.elasticsearch.common.logging.LogConfigurator
-
Configure logging without reading a log4j2.properties file, effectively configuring the status logger and all loggers to the console.
- confirm(Terminal, String) - Static method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- CONFLICT - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The request could not be completed due to a conflict with the current state of the resource.
- conflicts(String, Set<String>) - Method in record class org.elasticsearch.cluster.metadata.ReservedStateMetadata
-
Creates a set intersection between cluster state keys set by a given
ReservedClusterStateHandler
and the input set. - Conflicts(String) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.Conflicts
- CONNECT - Enum constant in enum class org.elasticsearch.rest.RestRequest.Method
- CONNECT_TIMEOUT - Static variable in class org.elasticsearch.transport.TransportSettings
- connectImpl(ActionListener<Void>) - Method in class org.elasticsearch.transport.ProxyConnectionStrategy
- connectImpl(ActionListener<Void>) - Method in class org.elasticsearch.transport.RemoteConnectionStrategy
- connectImpl(ActionListener<Void>) - Method in class org.elasticsearch.transport.SniffConnectionStrategy
- connection() - Method in record class org.elasticsearch.transport.Transport.ResponseContext
-
Returns the value of the
connection
record component. - connectionManager - Variable in class org.elasticsearch.transport.RemoteConnectionStrategy
- connectionManager - Variable in class org.elasticsearch.transport.TransportService
- ConnectionManager - Interface in org.elasticsearch.transport
- ConnectionManager.ConnectionValidator - Interface in org.elasticsearch.transport
- ConnectionManager.DelegatingNodeConnectionListener - Class in org.elasticsearch.transport
- ConnectionProfile - Class in org.elasticsearch.transport
-
A connection profile describes how many connection are established to specific node for each of the available request types.
- ConnectionProfile.Builder - Class in org.elasticsearch.transport
-
A builder to build a new
ConnectionProfile
- CONNECTIONS_PER_NODE_BULK - Static variable in class org.elasticsearch.transport.TransportSettings
- CONNECTIONS_PER_NODE_PING - Static variable in class org.elasticsearch.transport.TransportSettings
- CONNECTIONS_PER_NODE_RECOVERY - Static variable in class org.elasticsearch.transport.TransportSettings
- CONNECTIONS_PER_NODE_REG - Static variable in class org.elasticsearch.transport.TransportSettings
- CONNECTIONS_PER_NODE_STATE - Static variable in class org.elasticsearch.transport.TransportSettings
- connectionValidator(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService
- connectToNode(DiscoveryNode, ActionListener<Releasable>) - Method in class org.elasticsearch.transport.TransportService
-
Connect to the specified node with the given connection profile.
- connectToNode(DiscoveryNode, ConnectionProfile, ActionListener<Releasable>) - Method in class org.elasticsearch.transport.TransportService
-
Connect to the specified node with the given connection profile.
- connectToNode(DiscoveryNode, ConnectionProfile, ConnectionManager.ConnectionValidator, ActionListener<Releasable>) - Method in class org.elasticsearch.transport.ClusterConnectionManager
-
Connects to the given node, or acquires another reference to an existing connection to the given node if a connection already exists.
- connectToNode(DiscoveryNode, ConnectionProfile, ConnectionManager.ConnectionValidator, ActionListener<Releasable>) - Method in interface org.elasticsearch.transport.ConnectionManager
- connectToNode(DiscoveryNode, ConnectionProfile, ConnectionManager.ConnectionValidator, ActionListener<Releasable>) - Method in class org.elasticsearch.transport.RemoteConnectionManager
-
Remote cluster connections have a different lifecycle from intra-cluster connections.
- connectToNodes(DiscoveryNodes, Runnable) - Method in class org.elasticsearch.cluster.NodeConnectionsService
-
Connect to all the given nodes, but do not disconnect from any extra nodes.
- connectToNodesAndWait(ClusterState) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- connectToNodesAsync(ClusterState, Runnable) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- connectToRemoteClusterNode(DiscoveryNode, ConnectionManager.ConnectionValidator, ActionListener<Void>) - Method in class org.elasticsearch.transport.RemoteConnectionManager
- connectToRemoteMasterNode(TransportAddress, ActionListener<ProbeConnectionResult>) - Method in class org.elasticsearch.discovery.HandshakingTransportAddressConnector
- connectToRemoteMasterNode(TransportAddress, ActionListener<ProbeConnectionResult>) - Method in interface org.elasticsearch.discovery.TransportAddressConnector
-
Identify the node at the given address and, if it is a master node and not the local node then establish a full connection to it.
- ConnectTransportException - Exception in org.elasticsearch.transport
- ConnectTransportException(DiscoveryNode, String) - Constructor for exception org.elasticsearch.transport.ConnectTransportException
- ConnectTransportException(DiscoveryNode, String, String) - Constructor for exception org.elasticsearch.transport.ConnectTransportException
- ConnectTransportException(DiscoveryNode, String, String, Throwable) - Constructor for exception org.elasticsearch.transport.ConnectTransportException
- ConnectTransportException(DiscoveryNode, String, Throwable) - Constructor for exception org.elasticsearch.transport.ConnectTransportException
- ConnectTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.ConnectTransportException
- Consistent - Enum constant in enum class org.elasticsearch.common.settings.Setting.Property
-
Secure setting values equal on all nodes
- ConsistentSettingsService - Class in org.elasticsearch.common.settings
-
Used to publish secure setting hashes in the cluster state and to validate those hashes against the local values of those same settings.
- ConsistentSettingsService(Settings, ClusterService, Collection<Setting<?>>) - Constructor for class org.elasticsearch.common.settings.ConsistentSettingsService
- Console(PrintStream, Supplier<Integer>, Boolean, Charset) - Constructor for record class org.elasticsearch.bootstrap.ConsoleLoader.Console
-
Creates an instance of a
Console
record class. - ConsoleCtrlHandler - Interface in org.elasticsearch.bootstrap
- ConsoleLoader - Class in org.elasticsearch.bootstrap
-
Dynamically loads an "AnsiPrintStream" from the jANSI library on a separate class loader (so that the server classpath does not need to include jansi.jar)
- ConsoleLoader() - Constructor for class org.elasticsearch.bootstrap.ConsoleLoader
- ConsoleLoader.Console - Record Class in org.elasticsearch.bootstrap
- ConsoleThrowablePatternConverter - Class in org.elasticsearch.common.logging
-
Outputs a very short version of exceptions for an interactive console, pointing to full log for details.
- CONSTANT_KEYWORD_SYNTHETIC_SOURCE_WRITE_FIX - Static variable in class org.elasticsearch.index.mapper.MapperFeatures
- CONSTANT_NULLS - Static variable in interface org.elasticsearch.index.mapper.BlockLoader
-
Load blocks with only null.
- CONSTANT_SCORE - Static variable in class org.elasticsearch.index.query.support.QueryParsers
- CONSTANT_SCORE_BLENDED - Static variable in class org.elasticsearch.index.query.support.QueryParsers
- CONSTANT_SCORE_BOOLEAN - Static variable in class org.elasticsearch.index.query.support.QueryParsers
- constantBackoff(TimeValue, int) - Static method in class org.elasticsearch.action.bulk.BackoffPolicy
-
Creates an new constant backoff policy with the provided configuration.
- ConstantBucketCountThresholds(long, long, int, int) - Constructor for record class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.ConstantBucketCountThresholds
-
Creates an instance of a
ConstantBucketCountThresholds
record class. - constantBytes(BytesRef) - Method in interface org.elasticsearch.index.mapper.BlockLoader.BlockFactory
-
Build a block that contains
value
repeatedsize
times. - constantBytes(BytesRef) - Static method in interface org.elasticsearch.index.mapper.BlockLoader
-
Load blocks with only
value
. - ConstantFieldType - Class in org.elasticsearch.index.mapper
-
A
MappedFieldType
that has the same value for all documents. - ConstantFieldType(String, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.ConstantFieldType
- ConstantIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- ConstantIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
- constantNulls() - Method in interface org.elasticsearch.index.mapper.BlockLoader.BlockFactory
-
Build a block that contains only
null
. - ConstantNullsReader() - Constructor for class org.elasticsearch.index.mapper.BlockLoader.ConstantNullsReader
- constantScoreQuery(QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that wraps another query and simply returns a constant score equal to the query boost for every document in the query.
- ConstantScoreQueryBuilder - Class in org.elasticsearch.index.query
-
A query that wraps a filter and simply returns a constant score equal to the query boost for every document in the filter.
- ConstantScoreQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.ConstantScoreQueryBuilder
-
Read from a stream.
- ConstantScoreQueryBuilder(QueryBuilder) - Constructor for class org.elasticsearch.index.query.ConstantScoreQueryBuilder
-
A query that wraps another query and simply returns a constant score equal to the query boost for every document in the query.
- ConstantScoreTextFieldType(String) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.ConstantScoreTextFieldType
- ConstantScoreTextFieldType(String, boolean, boolean, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.ConstantScoreTextFieldType
- ConstantScoreTextFieldType(String, boolean, boolean, TextSearchInfo, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.ConstantScoreTextFieldType
- ConstructionContext<T> - Class in org.elasticsearch.injection.guice.internal
-
Context of a dependency construction.
- ConstructionContext() - Constructor for class org.elasticsearch.injection.guice.internal.ConstructionContext
- ConstructorBinding<T> - Interface in org.elasticsearch.injection.guice.spi
-
A binding to the constructor of a concrete clss.
- constSqrt(double) - Static method in class org.elasticsearch.index.codec.vectors.BQVectorUtils
- consumeAll() - Method in class org.elasticsearch.search.query.QuerySearchResult
- consumeBucketCountAndMaybeBreak(int) - Method in class org.elasticsearch.search.aggregations.AggregationReduceContext
- consumeBucketCountAndMaybeBreak(int) - Method in class org.elasticsearch.search.aggregations.AggregationReduceContext.ForFinal
- consumeBucketCountAndMaybeBreak(int) - Method in class org.elasticsearch.search.aggregations.AggregationReduceContext.ForPartial
- consumeBucketsAndMaybeBreak(int) - Method in class org.elasticsearch.search.aggregations.AggregationReduceContext
-
Adds
count
buckets to the global count for the request and fails if this number is greater than the maximum number of buckets allowed in a response - consumeFully(InputStream) - Static method in class org.elasticsearch.common.io.Streams
-
Fully consumes the input stream, throwing the bytes away.
- consumeInferenceFieldMap() - Method in class org.elasticsearch.action.bulk.BulkShardRequest
-
Consumes the inference metadata to execute inference on the bulk items just once.
- consumeProfileResult() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns and nulls out the profiled results for this search, or potentially null if result was empty.
- consumer() - Method in record class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.DefaultMalformedValueHandler
-
Returns the value of the
consumer
record component. - consumeResult(SearchPhaseResult, Runnable) - Method in class org.elasticsearch.action.search.QueryPhaseResultConsumer
- consumeTopDocs() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns and nulls out the top docs for this search results.
- CONTACT_SUPPORT - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- CONTACT_SUPPORT - Static variable in class org.elasticsearch.cluster.coordination.StableMasterHealthIndicatorService
- contain(double) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DoubleBounds
- contain(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.LongBounds
- containPhysicalIndexFile(String) - Method in class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
-
Returns true if this snapshot contains a file with a given original name
- contains(long) - Method in class org.elasticsearch.search.slice.SliceQuery
- contains(long) - Method in class org.elasticsearch.transport.Transport.ResponseHandlers
-
Returns
true
if the give request ID has a context associated with it. - contains(Object) - Method in class org.elasticsearch.common.collect.EvictingQueue
- contains(Object) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- contains(String) - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
-
Returns true if the given node is marked as shutting down with any shutdown type.
- contains(String) - Method in class org.elasticsearch.index.seqno.RetentionLeases
-
Checks if this retention lease collection contains a retention lease with the specified
RetentionLease.id()
. - contains(String) - Method in record class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns true iff this metadata contains the given file.
- contains(String, SingleNodeShutdownMetadata.Type) - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- contains(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlock
- contains(ShardSearchContextId) - Method in class org.elasticsearch.action.search.SearchContextId
- contains(SnapshotId) - Method in class org.elasticsearch.snapshots.RegisteredPolicySnapshots
- CONTAINS - Enum constant in enum class org.elasticsearch.common.geo.ShapeRelation
- CONTAINS - Enum constant in enum class org.elasticsearch.lucene.queries.BinaryDocValuesRangeQuery.QueryType
- containsAll(Collection) - Method in class org.elasticsearch.index.query.TermsQueryBuilder.BinaryValues
- containsAll(Collection<?>) - Method in class org.elasticsearch.common.collect.EvictingQueue
- containsAll(Collection<?>) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- containsAllShardRanges() - Method in class org.elasticsearch.index.shard.IndexLongFieldRange
- containsBrokenAnalysis() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
- containsBrokenAnalysis(String) - Method in class org.elasticsearch.index.query.FilteredSearchExecutionContext
- containsBrokenAnalysis(String) - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Does the index analyzer for this field have token filters that may produce backwards offsets in term vectors
- containsBrokenAnalysis(String) - Method in class org.elasticsearch.search.fetch.FetchContext
-
Does the index analyzer for this field have token filters that may produce backwards offsets in term vectors
- containsDimensions() - Method in class org.elasticsearch.index.mapper.PassThroughObjectMapper
- containsField(String) - Method in class org.elasticsearch.common.FieldMemoryStats
-
Returns
true
iff the given field is in the stats - containsHeader(String) - Method in interface org.elasticsearch.http.HttpResponse
- containsIndex(String) - Method in class org.elasticsearch.cluster.metadata.DataStream.DataStreamIndices
- containsIndex(Index) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
-
Returns true if the graveyard contains a tombstone for the given index.
- containsJoinVoteFor(DiscoveryNode) - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- containsKey(Object) - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap
- containsKey(Object) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
Returns
true
if this container has an association to a value for the given key. - containsKey(Object) - Method in class org.elasticsearch.common.util.CopyOnFirstWriteMap
- containsKey(Object) - Method in class org.elasticsearch.script.CtxMap
- containsKey(Object) - Method in class org.elasticsearch.script.DynamicMap
- containsKey(Object) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- containsKey(Object) - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- containsKey(String) - Method in class org.elasticsearch.script.Metadata
-
Does the metadata contain the key?
- containsKey(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- containsProcessor(String) - Method in class org.elasticsearch.ingest.IngestInfo
- containsQuery(String, Object, Object, boolean, boolean) - Method in enum class org.elasticsearch.index.mapper.RangeType
- containsShardId(ShardId) - Method in record class org.elasticsearch.cluster.ClusterInfo.ReservedSpace
- containsTerm(SetBackedScalingCuckooFilter, B) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- containsTerm(SetBackedScalingCuckooFilter, LongRareTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms
- containsTerm(SetBackedScalingCuckooFilter, StringRareTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms
- containsUtcMillis(long) - Method in class org.elasticsearch.common.LocalTimeOffset
-
Does this offset contain the provided time?
- containsUtcMillis(long) - Method in class org.elasticsearch.common.LocalTimeOffset.Transition
- containsValue(Object) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- containsValue(Object) - Method in class org.elasticsearch.common.util.CopyOnFirstWriteMap
- containsValue(Object) - Method in class org.elasticsearch.script.CtxMap
- containsValue(Object) - Method in class org.elasticsearch.script.DynamicMap
- containsValue(Object) - Method in class org.elasticsearch.script.Metadata
-
Does the metadata contain the value.
- containsValue(Object) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- containsValue(Object) - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- containsVoteFor(DiscoveryNode) - Method in class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- content() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- content() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- content() - Method in class org.elasticsearch.rest.RestRequest
- content() - Method in class org.elasticsearch.rest.RestResponse
- content(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
-
Set the script source and the content type of the bytes.
- CONTENT_FIELD_NAME_CONTEXTS - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- CONTENT_FIELD_NAME_INPUT - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- CONTENT_FIELD_NAME_WEIGHT - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.BinaryFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.BooleanFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.CompositeRuntimeField
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.DateFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.DocCountFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.FieldAliasMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.IdFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.IgnoredFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.IndexFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.IndexModeFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.IpFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.KeywordFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.LegacyTypeFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.LookupRuntimeFieldType
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.NestedObjectMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.ObjectMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.PassThroughObjectMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.RoutingFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.SourceFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.TextFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.TimeSeriesIdFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.vectors.MultiDenseVectorFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.vectors.SparseVectorFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.VersionFieldMapper
- CONTENT_TYPE_OPTION - Static variable in class org.elasticsearch.script.Script
-
Compiler option for
XContentType
used for templates. - contentLength() - Method in class org.elasticsearch.rest.RestRequest
- contentOrSourceParam() - Method in class org.elasticsearch.rest.RestRequest
-
Get the content of the request or the contents of the
source
param or throw an exception if both are missing. - contentOrSourceParamParser() - Method in class org.elasticsearch.rest.RestRequest
-
A parser for the contents of this request if it has contents, otherwise a parser for the
source
parameter if there is one, otherwise throws anElasticsearchParseException
. - contentParser() - Method in class org.elasticsearch.rest.RestRequest
-
A parser for the contents of this request if there is a body, otherwise throws an
ElasticsearchParseException
. - contentParserConfig() - Method in class org.elasticsearch.rest.RestRequest
-
Get the configuration that should be used to create
XContentParser
from this request. - ContentPath - Class in org.elasticsearch.index.mapper
- ContentPath() - Constructor for class org.elasticsearch.index.mapper.ContentPath
- contents() - Method in record class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownMetadataCustom
-
Returns the value of the
contents
record component. - contentStream() - Method in class org.elasticsearch.rest.RestRequest
- contentType() - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.DateFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.DocCountFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.FieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.IdFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.IgnoredSourceFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.IndexFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.IndexModeFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.IpFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.LegacyTypeFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.NestedPathFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.PlaceHolderFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.TextFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.TimeSeriesIdFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.TimeSeriesRoutingHashFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.vectors.MultiDenseVectorFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.vectors.SparseVectorFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.VersionFieldMapper
- contentType() - Method in class org.elasticsearch.rest.RestResponse
- context - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndSeqNo
- context - Variable in class org.elasticsearch.index.search.MatchQueryParser
- context - Variable in class org.elasticsearch.search.aggregations.AggregatorBase
- context - Variable in class org.elasticsearch.search.aggregations.AggregatorFactory
- context - Variable in class org.elasticsearch.search.fetch.subphase.highlight.FieldHighlightContext
- context - Variable in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- context() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- context() - Method in record class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownMetadataCustom
- context() - Method in class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- context() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- context() - Method in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- context() - Method in class org.elasticsearch.cluster.metadata.DesiredNodesMetadata
- context() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- context() - Method in interface org.elasticsearch.cluster.metadata.Metadata.Custom
- context() - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- context() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
- context() - Method in class org.elasticsearch.ingest.IngestMetadata
- context() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- context() - Method in record class org.elasticsearch.script.ScriptCacheStats
-
Returns the value of the
context
record component. - context() - Method in record class org.elasticsearch.script.ScriptContextStats
-
Returns the value of the
context
record component. - context() - Method in class org.elasticsearch.script.ScriptMetadata
- context() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
- context() - Method in record class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
-
Returns the value of the
context
record component. - context() - Method in class org.elasticsearch.snapshots.RegisteredPolicySnapshots
- context() - Method in class org.elasticsearch.upgrades.FeatureMigrationResults
- context(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- Context(ClusterState, IndicesOptions, long, boolean, boolean, boolean, boolean, SystemIndices.SystemIndexAccessLevel, Predicate<String>, Predicate<String>) - Constructor for class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.Context
- CONTEXT - Static variable in class org.elasticsearch.index.query.IntervalFilterScript
- CONTEXT - Static variable in class org.elasticsearch.script.AggregationScript
- CONTEXT - Static variable in class org.elasticsearch.script.BooleanFieldScript
- CONTEXT - Static variable in class org.elasticsearch.script.BucketAggregationScript
- CONTEXT - Static variable in class org.elasticsearch.script.BucketAggregationSelectorScript
- CONTEXT - Static variable in class org.elasticsearch.script.BytesRefSortScript
- CONTEXT - Static variable in class org.elasticsearch.script.CompositeFieldScript
- CONTEXT - Static variable in class org.elasticsearch.script.DateFieldScript
- CONTEXT - Static variable in class org.elasticsearch.script.DoubleFieldScript
- CONTEXT - Static variable in class org.elasticsearch.script.DoubleValuesScript
- CONTEXT - Static variable in class org.elasticsearch.script.FieldScript
-
The context used to compile
FieldScript
factories. - CONTEXT - Static variable in class org.elasticsearch.script.FilterScript
-
The context used to compile
FilterScript
factories. - CONTEXT - Static variable in class org.elasticsearch.script.GeometryFieldScript
- CONTEXT - Static variable in class org.elasticsearch.script.GeoPointFieldScript
- CONTEXT - Static variable in class org.elasticsearch.script.IngestConditionalScript
-
The context used to compile
IngestConditionalScript
factories. - CONTEXT - Static variable in class org.elasticsearch.script.IngestScript
-
The context used to compile
IngestScript
factories. - CONTEXT - Static variable in class org.elasticsearch.script.IpFieldScript
- CONTEXT - Static variable in class org.elasticsearch.script.LongFieldScript
- CONTEXT - Static variable in class org.elasticsearch.script.NumberSortScript
- CONTEXT - Static variable in class org.elasticsearch.script.ReindexScript
-
The context used to compile
ReindexScript
factories. - CONTEXT - Static variable in class org.elasticsearch.script.ScoreScript
- CONTEXT - Static variable in class org.elasticsearch.script.ScriptedMetricAggContexts.CombineScript
- CONTEXT - Static variable in class org.elasticsearch.script.ScriptedMetricAggContexts.InitScript
- CONTEXT - Static variable in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- CONTEXT - Static variable in class org.elasticsearch.script.ScriptedMetricAggContexts.ReduceScript
- CONTEXT - Static variable in class org.elasticsearch.script.SignificantTermsHeuristicScoreScript
- CONTEXT - Static variable in class org.elasticsearch.script.SimilarityScript
- CONTEXT - Static variable in class org.elasticsearch.script.SimilarityWeightScript
- CONTEXT - Static variable in class org.elasticsearch.script.StringFieldScript
- CONTEXT - Static variable in class org.elasticsearch.script.StringSortScript
- CONTEXT - Static variable in class org.elasticsearch.script.TemplateScript
- CONTEXT - Static variable in class org.elasticsearch.script.TermsSetQueryScript
- CONTEXT - Static variable in class org.elasticsearch.script.UpdateByQueryScript
-
The context used to compile
UpdateByQueryScript
factories. - CONTEXT - Static variable in class org.elasticsearch.script.UpdateScript
-
The context used to compile
UpdateScript
factories. - CONTEXT_MODE_API - Static variable in class org.elasticsearch.cluster.metadata.DesiredNodes
- CONTEXT_MODE_API - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- CONTEXT_MODE_CLUSTER_STATE - Static variable in class org.elasticsearch.cluster.metadata.DesiredNodes
- CONTEXT_MODE_GATEWAY - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- CONTEXT_MODE_PARAM - Static variable in class org.elasticsearch.cluster.metadata.DesiredNodes
- CONTEXT_MODE_PARAM - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- CONTEXT_MODE_SNAPSHOT - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- ContextBuilder<E extends ContextMapping<?>> - Class in org.elasticsearch.search.suggest.completion.context
-
Builder for
ContextMapping
- ContextBuilder(String) - Constructor for class org.elasticsearch.search.suggest.completion.context.ContextBuilder
- contextBytes - Variable in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- contextCompilationKeys() - Method in class org.elasticsearch.script.ScriptService.ContextSettings
-
the context specific max compilation keys
- contextDeprecationMessage(Settings) - Static method in class org.elasticsearch.script.ScriptService
- ContextFields() - Constructor for class org.elasticsearch.action.update.UpdateHelper.ContextFields
- contextId - Variable in class org.elasticsearch.search.SearchPhaseResult
- contextId() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- contextId() - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
- contextId() - Method in class org.elasticsearch.search.query.QuerySearchRequest
- contextId() - Method in class org.elasticsearch.search.rank.feature.RankFeatureShardRequest
- contextId() - Method in exception org.elasticsearch.search.SearchContextMissingException
- ContextIndexSearcher - Class in org.elasticsearch.search.internal
-
Context-aware extension of
IndexSearcher
. - ContextIndexSearcher(IndexReader, Similarity, QueryCache, QueryCachingPolicy, boolean) - Constructor for class org.elasticsearch.search.internal.ContextIndexSearcher
-
constructor for non-concurrent search
- ContextIndexSearcher(IndexReader, Similarity, QueryCache, QueryCachingPolicy, boolean, Executor, int, int) - Constructor for class org.elasticsearch.search.internal.ContextIndexSearcher
-
constructor for concurrent search
- ContextIndexSearcher.TimeExceededException - Exception in org.elasticsearch.search.internal
- ContextMapping<T extends ToXContent> - Class in org.elasticsearch.search.suggest.completion.context
-
A
ContextMapping
defines criteria that can be used to filter and/or boost suggestions at query time forCompletionFieldMapper
. - ContextMapping(ContextMapping.Type, String) - Constructor for class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Define a new context mapping of a specific type
- ContextMapping.InternalQueryContext - Record Class in org.elasticsearch.search.suggest.completion.context
- ContextMapping.Type - Enum Class in org.elasticsearch.search.suggest.completion.context
- ContextMappings - Class in org.elasticsearch.search.suggest.completion.context
-
ContextMappings indexes context-enabled suggestion fields and creates context queries for defined
ContextMapping
s for aCompletionFieldMapper
- ContextMappings(List<ContextMapping<?>>) - Constructor for class org.elasticsearch.search.suggest.completion.context.ContextMappings
- ContextPreservingActionListener<R> - Class in org.elasticsearch.action.support
-
Restores the given
ThreadContext.StoredContext
once the listener is invoked - ContextPreservingActionListener(Supplier<ThreadContext.StoredContext>, ActionListener<R>) - Constructor for class org.elasticsearch.action.support.ContextPreservingActionListener
- ContextRestoreResponseHandler(Supplier<ThreadContext.StoredContext>, TransportResponseHandler<T>) - Constructor for class org.elasticsearch.transport.TransportService.ContextRestoreResponseHandler
- contexts - Variable in class org.elasticsearch.script.ScriptModule
- contexts(Map<String, List<? extends ToXContent>>) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Sets query contexts for completion
- CONTEXTS - Static variable in class org.elasticsearch.script.ScriptLanguagesInfo
- CONTEXTS - Static variable in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- CONTEXTS_ALLOWED_SETTING - Static variable in class org.elasticsearch.script.ScriptService
- contextSettings() - Method in class org.elasticsearch.script.ScriptService.ContextSettings
-
All context specific settings
- ContextSettings(Settings) - Constructor for class org.elasticsearch.script.ScriptService.ContextSettings
- ContextSettings(Settings, Set<String>) - Constructor for class org.elasticsearch.script.ScriptService.ContextSettings
- contextStats() - Method in record class org.elasticsearch.script.ScriptStats
-
Returns the value of the
contextStats
record component. - CONTINUE - Enum constant in enum class org.elasticsearch.index.mapper.OnScriptError
- CONTINUE - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The client SHOULD continue with its request.
- ContinuousComputation<T> - Class in org.elasticsearch.cluster.routing.allocation.allocator
-
Asynchronously runs some computation using at most one thread but expects the input value changes over time as it's running.
- ContinuousComputation(Executor) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.ContinuousComputation
- conversionError(String, Object, TypeLiteral<?>, MatcherAndConverter, RuntimeException) - Method in class org.elasticsearch.injection.guice.internal.Errors
- conversionTypeError(String, Object, TypeLiteral<?>, MatcherAndConverter, Object) - Method in class org.elasticsearch.injection.guice.internal.Errors
- convert(double, DistanceUnit) - Method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Convert a given value into another unit
- convert(double, DistanceUnit, DistanceUnit) - Static method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Converts the given distance from the given DistanceUnit, to the given DistanceUnit
- convert(long) - Method in interface org.elasticsearch.index.mapper.BlockDocValuesReader.ToDouble
- convert(Object) - Static method in class org.elasticsearch.injection.guice.internal.Errors
- convert(String, TypeLiteral<?>) - Method in interface org.elasticsearch.injection.guice.spi.TypeConverter
-
Converts a string value.
- convert(Instant) - Method in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
-
Convert an Instant into a long value in this resolution.
- convert(BytesRef) - Method in class org.elasticsearch.index.mapper.SortedSetDocValuesSyntheticFieldLoaderLayer
-
Convert a
BytesRef
read from the source into bytes to write to the xcontent. - convert(DistanceUnit) - Method in class org.elasticsearch.common.unit.DistanceUnit.Distance
-
Converts a
DistanceUnit.Distance
value given in a specificDistanceUnit
into a value equal to the specified value but in a otherDistanceUnit
. - convert(TimeValue) - Method in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
-
Convert an TimeValue into a long value in this resolution.
- convert(BlockLoader.Block) - Method in interface org.elasticsearch.index.mapper.BlockLoader
-
In support of 'Union Types', we sometimes desire that Blocks loaded from source are immediately converted in some way.
- CONVERT_FAILURE_STORE_OPTIONS_TO_SELECTOR_OPTIONS_INTERNALLY - Static variable in class org.elasticsearch.TransportVersions
- ConvertedConstantBinding<T> - Interface in org.elasticsearch.injection.guice.spi
-
A binding created from converting a bound instance to a new type.
- converterReturnedNull(String, Object, TypeLiteral<?>, MatcherAndConverter) - Method in class org.elasticsearch.injection.guice.internal.Errors
- convertFieldValue(MappedFieldType, Object) - Static method in class org.elasticsearch.search.fetch.subphase.highlight.DefaultHighlighter
- convertFromStringArray(String[]) - Static method in class org.elasticsearch.common.text.Text
- convertLongTermsToDouble(LongTerms, DocValueFormat) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
-
Converts a
LongTerms
into aDoubleTerms
, returning the value of the specified long terms as doubles. - convertNumeric(SortedNumericDocValues, LongUnaryOperator) - Static method in class org.elasticsearch.index.fielddata.IndexNumericFieldData
-
Convert the values in
dvs
using the providedconverter
. - convertToCoordinatorRewriteContext() - Method in class org.elasticsearch.index.query.CoordinatorRewriteContext
- convertToCoordinatorRewriteContext() - Method in class org.elasticsearch.index.query.FilteredSearchExecutionContext
- convertToCoordinatorRewriteContext() - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
Returns an instance of
CoordinatorRewriteContext
if available or null otherwise - convertToDataRewriteContext() - Method in class org.elasticsearch.index.query.DataRewriteContext
- convertToDataRewriteContext() - Method in class org.elasticsearch.index.query.FilteredSearchExecutionContext
- convertToDataRewriteContext() - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
Returns an instance of
DataRewriteContext
if available or null otherwise - convertToDoubleFilter() - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- convertToElastic(Exception) - Static method in class org.elasticsearch.ExceptionsHelper
- convertToIndexMetadataContext() - Method in class org.elasticsearch.index.query.FilteredSearchExecutionContext
- convertToIndexMetadataContext() - Method in class org.elasticsearch.index.query.QueryRewriteContext
- convertToInnerHitsRewriteContext() - Method in class org.elasticsearch.index.query.InnerHitsRewriteContext
- convertToInnerHitsRewriteContext() - Method in class org.elasticsearch.index.query.QueryRewriteContext
- convertToJson(BytesReference, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Deprecated.
- convertToJson(BytesReference, boolean, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Deprecated.
- convertToJson(BytesReference, boolean, boolean, XContentType) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
- convertToJson(BytesReference, boolean, XContentType) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
- convertToLongFilter(DocValueFormat) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- convertToMap(BytesReference, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Deprecated.this method relies on auto-detection of content type. Use
XContentHelper.convertToMap(BytesReference, boolean, XContentType)
instead with the properXContentType
- convertToMap(BytesReference, boolean, XContentType) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
- convertToMap(BytesReference, boolean, XContentType, Set<String>, Set<String>) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Converts the given bytes into a map that is optionally ordered.
- convertToMap(BytesReference, boolean, XContentType, XContentParserDecorator) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Exactly the same as
XContentHelper.convertToMap(BytesReference, boolean, XContentType, Set, Set)
but none of the fields are filtered - convertToMap(XContent, byte[], int, int, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
- convertToMap(XContent, byte[], int, int, boolean, Set<String>, Set<String>) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
- convertToMap(XContent, InputStream, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
The same as
XContentHelper.convertToMap(XContent, byte[], int, int, boolean, Set, Set)
but none of the fields are filtered. - convertToMap(XContent, InputStream, boolean, Set<String>, Set<String>) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
- convertToMap(XContent, String, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
- convertToOrdinalsFilter(DocValueFormat) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- convertToRuntime(Exception) - Static method in class org.elasticsearch.ExceptionsHelper
- convertToSearchExecutionContext() - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
Returns an instance of
SearchExecutionContext
if available or null otherwise - convertToSearchExecutionContext() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- convertToStringFilter(DocValueFormat) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- COOLDOWN_PREVENTED_DECREASE - Enum constant in enum class org.elasticsearch.action.datastreams.autosharding.AutoShardingType
- COOLDOWN_PREVENTED_INCREASE - Enum constant in enum class org.elasticsearch.action.datastreams.autosharding.AutoShardingType
- coolDownRemaining() - Method in record class org.elasticsearch.action.datastreams.autosharding.AutoShardingResult
-
Returns the value of the
coolDownRemaining
record component. - CoordinateEncoder - Class in org.elasticsearch.lucene.spatial
-
Abstract API for classes that help encode double-valued spatial coordinates x/y to their integer-encoded serialized form and decode them back
- CoordinateEncoder() - Constructor for class org.elasticsearch.lucene.spatial.CoordinateEncoder
- CoordinationDiagnosticsAction - Class in org.elasticsearch.action.admin.cluster.coordination
-
This action exposes CoordinationDiagnosticsService#diagnoseMasterStability so that a node can get a remote node's view of coordination diagnostics (including master stability).
- CoordinationDiagnosticsAction.Request - Class in org.elasticsearch.action.admin.cluster.coordination
- CoordinationDiagnosticsAction.Response - Class in org.elasticsearch.action.admin.cluster.coordination
- CoordinationDiagnosticsAction.TransportAction - Class in org.elasticsearch.action.admin.cluster.coordination
-
This transport action calls CoordinationDiagnosticsService#diagnoseMasterStability
- CoordinationDiagnosticsDetails(DiscoveryNode, List<DiscoveryNode>, Exception, Map<String, String>) - Constructor for record class org.elasticsearch.cluster.coordination.CoordinationDiagnosticsService.CoordinationDiagnosticsDetails
- CoordinationDiagnosticsDetails(DiscoveryNode, List<DiscoveryNode>, String, String, Map<String, String>) - Constructor for record class org.elasticsearch.cluster.coordination.CoordinationDiagnosticsService.CoordinationDiagnosticsDetails
-
Creates an instance of a
CoordinationDiagnosticsDetails
record class. - CoordinationDiagnosticsDetails(StreamInput) - Constructor for record class org.elasticsearch.cluster.coordination.CoordinationDiagnosticsService.CoordinationDiagnosticsDetails
- CoordinationDiagnosticsResult(CoordinationDiagnosticsService.CoordinationDiagnosticsStatus, String, CoordinationDiagnosticsService.CoordinationDiagnosticsDetails) - Constructor for record class org.elasticsearch.cluster.coordination.CoordinationDiagnosticsService.CoordinationDiagnosticsResult
-
Creates an instance of a
CoordinationDiagnosticsResult
record class. - CoordinationDiagnosticsResult(StreamInput) - Constructor for record class org.elasticsearch.cluster.coordination.CoordinationDiagnosticsService.CoordinationDiagnosticsResult
- CoordinationDiagnosticsService - Class in org.elasticsearch.cluster.coordination
-
This service reports the health of master stability.
- CoordinationDiagnosticsService(ClusterService, TransportService, Coordinator, MasterHistoryService) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationDiagnosticsService
- CoordinationDiagnosticsService.CoordinationDiagnosticsDetails - Record Class in org.elasticsearch.cluster.coordination
- CoordinationDiagnosticsService.CoordinationDiagnosticsResult - Record Class in org.elasticsearch.cluster.coordination
- CoordinationDiagnosticsService.CoordinationDiagnosticsStatus - Enum Class in org.elasticsearch.cluster.coordination
- coordinationMetadata() - Method in class org.elasticsearch.cluster.ClusterState
- coordinationMetadata() - Method in class org.elasticsearch.cluster.metadata.Metadata
- coordinationMetadata(CoordinationMetadata) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- CoordinationMetadata - Class in org.elasticsearch.cluster.coordination
- CoordinationMetadata(long, CoordinationMetadata.VotingConfiguration, CoordinationMetadata.VotingConfiguration, Set<CoordinationMetadata.VotingConfigExclusion>) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationMetadata
- CoordinationMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationMetadata
- CoordinationMetadata.Builder - Class in org.elasticsearch.cluster.coordination
- CoordinationMetadata.VotingConfigExclusion - Class in org.elasticsearch.cluster.coordination
- CoordinationMetadata.VotingConfiguration - Class in org.elasticsearch.cluster.coordination
-
A collection of persistent node ids, denoting the voting configuration for cluster state changes.
- CoordinationState - Class in org.elasticsearch.cluster.coordination
-
The core class of the cluster state coordination algorithm, directly implementing the formal model
- CoordinationState(DiscoveryNode, CoordinationState.PersistedState, ElectionStrategy) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationState
- CoordinationState.PersistedState - Interface in org.elasticsearch.cluster.coordination
-
Pluggable persistence layer for
CoordinationState
. - CoordinationState.VoteCollection - Class in org.elasticsearch.cluster.coordination
-
A collection of votes, used to calculate quorums.
- CoordinationStateRejectedException - Exception in org.elasticsearch.cluster.coordination
-
This exception is thrown when rejecting state transitions on the
CoordinationState
object, for example when receiving a publish request with the wrong term or version. - CoordinationStateRejectedException(String, Object...) - Constructor for exception org.elasticsearch.cluster.coordination.CoordinationStateRejectedException
- CoordinationStateRejectedException(StreamInput) - Constructor for exception org.elasticsearch.cluster.coordination.CoordinationStateRejectedException
- Coordinator - Class in org.elasticsearch.cluster.coordination
- Coordinator(String, Settings, ClusterSettings, TransportService, Client, NamedWriteableRegistry, AllocationService, MasterService, Supplier<CoordinationState.PersistedState>, SeedHostsProvider, ClusterApplier, Collection<BiConsumer<DiscoveryNode, ClusterState>>, Random, RerouteService, ElectionStrategy, NodeHealthService, CircuitBreakerService, Reconfigurator, LeaderHeartbeatService, PreVoteCollector.Factory, CompatibilityVersions, FeatureService) - Constructor for class org.elasticsearch.cluster.coordination.Coordinator
- Coordinator.Mode - Enum Class in org.elasticsearch.cluster.coordination
- Coordinator.PeerFinderListener - Interface in org.elasticsearch.cluster.coordination
- CoordinatorRewriteContext - Class in org.elasticsearch.index.query
-
Context object used to rewrite
QueryBuilder
instances into simplified version in the coordinator. - CoordinatorRewriteContext(XContentParserConfiguration, Client, LongSupplier, DateFieldRangeInfo, String) - Constructor for class org.elasticsearch.index.query.CoordinatorRewriteContext
-
Context for coordinator search rewrites based on time ranges for the @timestamp field and/or 'event.ingested' field
- CoordinatorRewriteContextProvider - Class in org.elasticsearch.index.query
- CoordinatorRewriteContextProvider(XContentParserConfiguration, Client, LongSupplier, Supplier<ClusterState>, Function<Index, DateFieldRangeInfo>) - Constructor for class org.elasticsearch.index.query.CoordinatorRewriteContextProvider
- copy() - Method in class org.elasticsearch.cluster.metadata.DataStream
- copy() - Method in class org.elasticsearch.cluster.metadata.DataStream.DataStreamIndices
- copy() - Method in class org.elasticsearch.common.FieldMemoryStats
-
Creates a deep copy of this stats instance
- copy() - Method in class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues.DenseOffHeapVectorValues
- copy() - Method in interface org.elasticsearch.index.codec.vectors.RandomAccessBinarizedByteVectorValues
- copy() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
-
Returns a full copy of this object
- copy() - Method in class org.elasticsearch.repositories.RepositoryData
- copy() - Method in class org.elasticsearch.search.aggregations.metrics.EmptyDoubleHdrHistogram
- copy(byte[], OutputStream) - Static method in class org.elasticsearch.common.io.Streams
-
Copy the contents of the given byte array to the given OutputStream.
- copy(Reader, Writer) - Static method in class org.elasticsearch.common.io.Streams
-
Copy the contents of the given Reader to the given Writer.
- copy(String) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedAlias
- copy(String) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedDataStream
- copy(String) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedIndex
- copy(String, Writer) - Static method in class org.elasticsearch.common.io.Streams
-
Copy the contents of the given String to the given output Writer.
- copy(String, String, Settings) - Method in class org.elasticsearch.common.settings.Settings.Builder
- copy(String, Settings) - Method in class org.elasticsearch.common.settings.Settings.Builder
- copy(Settings, IndexMetadata) - Method in class org.elasticsearch.common.settings.IndexScopedSettings
- Copy(IndexShardSnapshotStatus.Stage, long, long, int, int, int, long, long, long, String) - Constructor for class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- copyAndResolve(Map<String, Object>) - Method in class org.elasticsearch.ingest.ValueSource.ByteValue
- copyAndResolve(Map<String, Object>) - Method in interface org.elasticsearch.ingest.ValueSource
-
Returns a copy of the value this ValueSource holds and resolves templates if there're any.
- copyAndResolve(Map<String, Object>) - Method in class org.elasticsearch.ingest.ValueSource.ListValue
- copyAndResolve(Map<String, Object>) - Method in class org.elasticsearch.ingest.ValueSource.MapValue
- copyAndResolve(Map<String, Object>) - Method in class org.elasticsearch.ingest.ValueSource.ObjectValue
- copyAndResolve(Map<String, Object>) - Method in class org.elasticsearch.ingest.ValueSource.TemplatedValue
- copyAndUpdate(Consumer<ClusterState.Builder>) - Method in class org.elasticsearch.cluster.ClusterState
- copyAndUpdate(Consumer<Metadata.Builder>) - Method in class org.elasticsearch.cluster.metadata.Metadata
- copyAndUpdateMetadata(Consumer<Metadata.Builder>) - Method in class org.elasticsearch.cluster.ClusterState
- copyBytes() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
-
Like
BytesStreamOutput.bytes()
but copies the bytes to a freshly allocated buffer. - copyCorrectedForCoordinatedOmission(double) - Method in class org.elasticsearch.search.aggregations.metrics.EmptyDoubleHdrHistogram
- copyFor(RoutingNodes) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- copyFrom(TermState) - Method in class org.elasticsearch.index.codec.postings.ES812PostingsFormat.IntBlockTermState
- copyHeaders(Iterable<Map.Entry<String, String>>) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Copies all header key, value pairs into the current context
- copyHeaders(ElasticsearchException) - Method in class org.elasticsearch.rest.RestResponse
- copyIndices() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- copyInto(DoubleHistogram) - Method in class org.elasticsearch.search.aggregations.metrics.EmptyDoubleHdrHistogram
- copyIntoCorrectedForCoordinatedOmission(DoubleHistogram, double) - Method in class org.elasticsearch.search.aggregations.metrics.EmptyDoubleHdrHistogram
- copyMapWithAddedEntry(Map<K, V>, K, V) - Static method in class org.elasticsearch.common.util.Maps
-
Adds an entry to an immutable map by copying the underlying map and adding the new entry.
- copyMapWithAddedOrReplacedEntry(Map<K, V>, K, V) - Static method in class org.elasticsearch.common.util.Maps
-
Adds a new entry to or replaces an existing entry in an immutable map by copying the underlying map and adding the new or replacing the existing entry.
- copyMapWithRemovedEntry(Map<K, V>, K) - Static method in class org.elasticsearch.common.util.Maps
-
Remove the specified key from the provided immutable map by copying the underlying map and filtering out the specified key if that key exists.
- copyNamedQueries() - Method in class org.elasticsearch.index.query.FilteredSearchExecutionContext
- copyNamedQueries() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- copyOf(Map<K, V>, Function<V, V>) - Static method in class org.elasticsearch.common.util.Maps
-
This method creates a copy of the
source
map usingcopyValueFunction
to create a defensive copy of each value. - CopyOnFirstWriteMap<K,
V> - Class in org.elasticsearch.common.util -
This map is designed to be constructed from an immutable map and be copied only if a (rare) mutation operation occurs.
- CopyOnFirstWriteMap(Map<K, V>) - Constructor for class org.elasticsearch.common.util.CopyOnFirstWriteMap
- copyRequestHeadersToThreadContext(HttpPreRequest, ThreadContext) - Method in class org.elasticsearch.action.ActionModule
-
Certain request header values need to be copied in the thread context under which request handlers are to be dispatched.
- copyResults() - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
Make a mutable copy of the aggregation results.
- copySettings() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- copySettings(boolean) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- copyShards() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- copyTo - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
- copyTo() - Method in record class org.elasticsearch.index.mapper.FieldMapper.BuilderParams
-
Returns the value of the
copyTo
record component. - copyTo() - Method in class org.elasticsearch.index.mapper.FieldMapper
-
List of fields where this field should be copied to
- copyTo(AttributeImpl) - Method in class org.elasticsearch.lucene.analysis.miscellaneous.DisableGraphAttributeImpl
- copyTo(AttributeImpl) - Method in class org.elasticsearch.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- copyTo(XContentBuilder) - Method in class org.elasticsearch.common.compress.CompressedXContent
-
Copies the x-content in this instance to the given builder token by token.
- copyToFields() - Method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo
- copyToString(Reader) - Static method in class org.elasticsearch.common.io.Streams
-
Copy the contents of the given Reader into a String.
- copyWith(double, double, long) - Method in class org.elasticsearch.search.aggregations.metrics.InternalCentroid
-
Create a new centroid with by reducing from the sums and total count
- copyWith(double, double, long) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- copyWith(SpatialPoint, long) - Method in class org.elasticsearch.search.aggregations.metrics.InternalCentroid
- copyWith(SpatialPoint, long) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- copyWithFreeBytes(long) - Method in record class org.elasticsearch.cluster.DiskUsage
- copyWithRewritenBuckets(Function<InternalAggregations, InternalAggregations>) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- copyWithRewritenBuckets(Function<InternalAggregations, InternalAggregations>) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Rewrite the sub-aggregations in the buckets in this aggregation.
- copyWithRewritenBuckets(Function<InternalAggregations, InternalAggregations>) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
- CORE_CONTEXTS - Static variable in class org.elasticsearch.script.ScriptModule
- CoreValuesSourceType - Enum Class in org.elasticsearch.search.aggregations.support
-
CoreValuesSourceType
holds theValuesSourceType
implementations for the core aggregations package. - Correction - Class in org.elasticsearch.search.suggest.phrase
- Correction(double, DirectCandidateGenerator.Candidate[]) - Constructor for class org.elasticsearch.search.suggest.phrase.Correction
- correctiveValues - Variable in class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues
- CORRUPTED - Enum constant in enum class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
- CORRUPTED_DEFINITION - Static variable in class org.elasticsearch.snapshots.RepositoryIntegrityHealthIndicatorService
- CORRUPTED_MARKER_NAME_PREFIX - Static variable in class org.elasticsearch.index.store.Store
- CORRUPTED_REPO_GEN - Static variable in class org.elasticsearch.repositories.RepositoryData
-
The generation value indicating that the repository generation could not be determined.
- CORRUPTION - Enum constant in enum class org.elasticsearch.action.admin.cluster.stats.CCSUsageTelemetry.Result
- CorruptStateException - Exception in org.elasticsearch.gateway
-
This exception is thrown when Elasticsearch detects an inconsistency in one of it's persistent states.
- CorruptStateException(String) - Constructor for exception org.elasticsearch.gateway.CorruptStateException
-
Creates a new
CorruptStateException
- CorruptStateException(Throwable) - Constructor for exception org.elasticsearch.gateway.CorruptStateException
-
Creates a new
CorruptStateException
with the given exceptions stacktrace. - corsHandler - Variable in class org.elasticsearch.http.AbstractHttpServerTransport
- CorsHandler - Class in org.elasticsearch.http
-
This file is forked from the https://netty.io project.
- CorsHandler(CorsHandler.Config) - Constructor for class org.elasticsearch.http.CorsHandler
- CorsHandler.Config - Class in org.elasticsearch.http
- corsSettingAsArray(String) - Static method in class org.elasticsearch.rest.RestUtils
-
Return the CORS setting as an array of origins.
- COSINE - Enum constant in enum class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.VectorSimilarity
- COSINE - Enum constant in enum class org.elasticsearch.inference.SimilarityMeasure
- COSINE_MAGNITUDE_FIELD_SUFFIX - Static variable in class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper
- cosineSimilarity() - Method in class org.elasticsearch.script.VectorScoreScriptUtils.ByteCosineSimilarity
- cosineSimilarity() - Method in class org.elasticsearch.script.VectorScoreScriptUtils.CosineSimilarity
- cosineSimilarity() - Method in interface org.elasticsearch.script.VectorScoreScriptUtils.CosineSimilarityInterface
- cosineSimilarity() - Method in class org.elasticsearch.script.VectorScoreScriptUtils.FloatCosineSimilarity
- cosineSimilarity(byte[]) - Method in interface org.elasticsearch.script.field.vectors.DenseVector
-
Get the cosine similarity with the un-normalized query vector
- cosineSimilarity(byte[], float) - Method in class org.elasticsearch.script.field.vectors.BinaryDenseVector
- cosineSimilarity(byte[], float) - Method in class org.elasticsearch.script.field.vectors.BitBinaryDenseVector
- cosineSimilarity(byte[], float) - Method in class org.elasticsearch.script.field.vectors.BitKnnDenseVector
- cosineSimilarity(byte[], float) - Method in class org.elasticsearch.script.field.vectors.ByteBinaryDenseVector
- cosineSimilarity(byte[], float) - Method in class org.elasticsearch.script.field.vectors.ByteKnnDenseVector
- cosineSimilarity(byte[], float) - Method in interface org.elasticsearch.script.field.vectors.DenseVector
-
Get the cosine similarity with the query vector
- cosineSimilarity(byte[], float) - Method in class org.elasticsearch.script.field.vectors.KnnDenseVector
- cosineSimilarity(float[]) - Method in interface org.elasticsearch.script.field.vectors.DenseVector
-
Get the cosine similarity with the un-normalized query vector
- cosineSimilarity(float[], boolean) - Method in class org.elasticsearch.script.field.vectors.BinaryDenseVector
- cosineSimilarity(float[], boolean) - Method in class org.elasticsearch.script.field.vectors.BitBinaryDenseVector
- cosineSimilarity(float[], boolean) - Method in class org.elasticsearch.script.field.vectors.BitKnnDenseVector
- cosineSimilarity(float[], boolean) - Method in class org.elasticsearch.script.field.vectors.ByteBinaryDenseVector
- cosineSimilarity(float[], boolean) - Method in class org.elasticsearch.script.field.vectors.ByteKnnDenseVector
- cosineSimilarity(float[], boolean) - Method in interface org.elasticsearch.script.field.vectors.DenseVector
-
Get the cosine similarity with the query vector
- cosineSimilarity(float[], boolean) - Method in class org.elasticsearch.script.field.vectors.KnnDenseVector
- cosineSimilarity(Object) - Method in interface org.elasticsearch.script.field.vectors.DenseVector
-
Get the cosine similarity with the un-normalized query vector.
- cosineSimilarity(List<Number>) - Method in class org.elasticsearch.script.field.vectors.BinaryDenseVector
- cosineSimilarity(List<Number>) - Method in class org.elasticsearch.script.field.vectors.BitBinaryDenseVector
- cosineSimilarity(List<Number>) - Method in class org.elasticsearch.script.field.vectors.BitKnnDenseVector
- cosineSimilarity(List<Number>) - Method in class org.elasticsearch.script.field.vectors.ByteBinaryDenseVector
- cosineSimilarity(List<Number>) - Method in class org.elasticsearch.script.field.vectors.ByteKnnDenseVector
- cosineSimilarity(List<Number>) - Method in interface org.elasticsearch.script.field.vectors.DenseVector
-
Get the cosine similarity with the un-normalized query vector
- cosineSimilarity(List<Number>) - Method in class org.elasticsearch.script.field.vectors.KnnDenseVector
- CosineSimilarity(ScoreScript, Object, String) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.CosineSimilarity
- cost() - Method in class org.elasticsearch.index.codec.vectors.BinarizedByteVectorValues
- cost() - Method in class org.elasticsearch.index.fielddata.AbstractBinaryDocValues
- cost() - Method in class org.elasticsearch.index.fielddata.AbstractNumericDocValues
- cost() - Method in class org.elasticsearch.index.fielddata.AbstractSortedDocValues
- cost() - Method in class org.elasticsearch.index.fielddata.AbstractSortedNumericDocValues
- cost() - Method in class org.elasticsearch.index.fielddata.AbstractSortedSetDocValues
- cost() - Method in class org.elasticsearch.index.fielddata.AbstractSortingNumericDocValues
- cost() - Method in class org.elasticsearch.index.fielddata.SourceValueFetcherSortedNumericIndexFieldData.SourceValueFetcherSortedNumericDocValues
- count - Variable in class org.elasticsearch.common.io.stream.BytesStreamOutput
- count - Variable in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
- count - Variable in class org.elasticsearch.script.field.AbstractLongDocValuesField
- count - Variable in class org.elasticsearch.script.field.BaseKeywordDocValuesField
- count - Variable in class org.elasticsearch.script.field.ByteDocValuesField
- count - Variable in class org.elasticsearch.script.field.DateMillisDocValuesField
- count - Variable in class org.elasticsearch.script.field.DateNanosDocValuesField
- count - Variable in class org.elasticsearch.script.field.DoubleDocValuesField
- count - Variable in class org.elasticsearch.script.field.FloatDocValuesField
- count - Variable in class org.elasticsearch.script.field.HalfFloatDocValuesField
- count - Variable in class org.elasticsearch.script.field.IntegerDocValuesField
- count - Variable in class org.elasticsearch.script.field.PointDocValuesField
- count - Variable in class org.elasticsearch.script.field.ScaledFloatDocValuesField
- count - Variable in class org.elasticsearch.script.field.ShortDocValuesField
- count - Variable in class org.elasticsearch.script.ScriptCache.CompilationRate
- count - Variable in class org.elasticsearch.search.aggregations.metrics.InternalCentroid
- count - Variable in class org.elasticsearch.search.aggregations.metrics.InternalStats
- count() - Method in class org.elasticsearch.action.admin.cluster.stats.LongMetric.LongMetricValue
- count() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- count() - Method in class org.elasticsearch.common.cache.Cache
-
The number of entries in the cache.
- count() - Method in class org.elasticsearch.common.metrics.CounterMetric
-
Returns the current count of this metric.
- count() - Method in class org.elasticsearch.common.metrics.MeanMetric
-
Returns the current count of this metric.
- count() - Method in class org.elasticsearch.common.unit.Processors
- count() - Method in class org.elasticsearch.index.fielddata.HistogramValue
-
The current count of the histogram
- count() - Method in interface org.elasticsearch.index.mapper.BlockLoader.Docs
- count() - Method in class org.elasticsearch.index.mapper.IgnoreMalformedStoredValues
-
How many values has this field loaded for this document?
- count() - Method in class org.elasticsearch.script.AbstractLongFieldScript
-
The number of results produced the last time
AbstractFieldScript.runForDoc(int)
was called. - count() - Method in class org.elasticsearch.script.DoubleFieldScript
-
The number of results produced the last time
AbstractFieldScript.runForDoc(int)
was called. - count() - Method in class org.elasticsearch.script.GeometryFieldScript
-
The number of results produced the last time
AbstractFieldScript.runForDoc(int)
was called. - count() - Method in class org.elasticsearch.script.GeoPointFieldScript
-
The number of results produced the last time
AbstractFieldScript.runForDoc(int)
was called. - count() - Method in class org.elasticsearch.script.IpFieldScript
-
The number of results produced the last time
AbstractFieldScript.runForDoc(int)
was called. - count() - Method in class org.elasticsearch.script.TimeSeriesCounter
-
The total number of events for all time covered by the counters.
- count() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- count() - Method in interface org.elasticsearch.search.aggregations.metrics.CentroidAggregation
- count() - Method in class org.elasticsearch.search.aggregations.metrics.InternalCentroid
- count() - Method in class org.elasticsearch.synonyms.SynonymSetSummary
- count(boolean) - Static method in class org.elasticsearch.search.aggregations.BucketOrder
-
Creates a bucket ordering strategy that sorts buckets by their document counts (ascending or descending).
- count(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
ValueCount
aggregation with the given name. - count(LeafReaderContext) - Method in class org.elasticsearch.search.profile.query.ProfileWeight
- COUNT - Static variable in class org.elasticsearch.search.aggregations.metrics.InternalCentroid.Fields
- COUNT_FIELD - Static variable in class org.elasticsearch.synonyms.SynonymSetSummary
- COUNT_USAGE_STATS_NAME - Static variable in class org.elasticsearch.repositories.RepositoriesService
- COUNT_WEIGHT - Enum constant in enum class org.elasticsearch.search.profile.query.QueryTimingType
- Countable - Interface in org.elasticsearch.common.util
- countAggregators() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
- countBatch() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- countBulkRetry() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- countChanges(String, long, long) - Method in class org.elasticsearch.index.engine.Engine
-
Counts the number of operations in the range of the given sequence numbers.
- countChanges(String, long, long) - Method in class org.elasticsearch.index.engine.InternalEngine
- countChanges(String, long, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- countChanges(String, long, long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Counts the number of operations in the range of the given sequence numbers.
- countCreated() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- countDeleted() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- countDown() - Method in class org.elasticsearch.common.util.concurrent.CountDown
-
Decrements the count and returns
true
if and only if the count reached zero with this call. - CountDown - Class in org.elasticsearch.common.util.concurrent
-
A simple thread-safe count-down class that does not block, unlike a
CountDownLatch
. - CountDown(int) - Constructor for class org.elasticsearch.common.util.concurrent.CountDown
- CountDownActionListener - Class in org.elasticsearch.action.support
-
Wraps another listener and adds a counter -- each invocation of this listener will decrement the counter, and when the counter has been exhausted the final invocation of this listener will delegate to the wrapped listener.
- CountDownActionListener(int, ActionListener<Void>) - Constructor for class org.elasticsearch.action.support.CountDownActionListener
-
Creates a new listener
- CountedBitSet - Class in org.elasticsearch.index.seqno
-
A
CountedBitSet
wraps aFixedBitSet
but automatically releases the internal bitset when all bits are set to reduce memory usage. - CountedBitSet(short) - Constructor for class org.elasticsearch.index.seqno.CountedBitSet
- CountedTermsAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.countedterms
- CountedTermsAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.countedterms.CountedTermsAggregationBuilder
- CountedTermsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.countedterms.CountedTermsAggregationBuilder
- CountedTermsAggregationBuilder(ValuesSourceAggregationBuilder<CountedTermsAggregationBuilder>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.countedterms.CountedTermsAggregationBuilder
- Counter(long, long) - Constructor for class org.elasticsearch.script.TimeSeriesCounter.Counter
-
Create a Counter that covers duration seconds at the given resolution.
- COUNTER - Enum constant in enum class org.elasticsearch.index.mapper.TimeSeriesParams.MetricType
- COUNTER - Enum constant in enum class org.elasticsearch.search.aggregations.support.TimeSeriesValuesSourceType
- COUNTER_CLOCKWISE - Static variable in enum class org.elasticsearch.common.geo.Orientation
- counterGetAndIncrement() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- CounterMetric - Class in org.elasticsearch.common.metrics
-
A
CounterMetric
is used to track the number of completed and outstanding items, for example, the number of executed refreshes, the currently used memory by indexing, the current pending search requests. - CounterMetric() - Constructor for class org.elasticsearch.common.metrics.CounterMetric
- Counters - Class in org.elasticsearch.common.metrics
-
Simple usage stat counters based on longs.
- Counters(String...) - Constructor for class org.elasticsearch.common.metrics.Counters
- Counters(StreamInput) - Constructor for class org.elasticsearch.common.metrics.Counters
- CountingFilterInputStream - Class in org.elasticsearch.common.io.stream
- CountingFilterInputStream(InputStream) - Constructor for class org.elasticsearch.common.io.stream.CountingFilterInputStream
- CountingStreamOutput - Class in org.elasticsearch.common.io.stream
-
A reusable @link
StreamOutput
that just count how many bytes are written. - CountingStreamOutput() - Constructor for class org.elasticsearch.common.io.stream.CountingStreamOutput
- countInnerBucket(Aggregation) - Static method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
-
Counts the number of inner buckets inside the provided
Aggregation
- countInnerBucket(InternalMultiBucketAggregation.InternalBucket) - Static method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
-
Counts the number of inner buckets inside the provided
InternalMultiBucketAggregation.InternalBucket
- countMapping(Map<MappingMetadata, Integer>, IndexMetadata) - Static method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
- countNoop() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- countSearchRetry - Variable in class org.elasticsearch.index.reindex.ScrollableHitSource
- countSearchRetry() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- countUpdated() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- countVersionConflict() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- Cpu(short, double[]) - Constructor for class org.elasticsearch.monitor.os.OsStats.Cpu
- Cpu(short, long) - Constructor for class org.elasticsearch.monitor.process.ProcessStats.Cpu
- Cpu(StreamInput) - Constructor for class org.elasticsearch.monitor.os.OsStats.Cpu
- Cpu(StreamInput) - Constructor for class org.elasticsearch.monitor.process.ProcessStats.Cpu
- CPU - Enum constant in enum class org.elasticsearch.monitor.jvm.HotThreads.ReportType
- CPU - Enum constant in enum class org.elasticsearch.monitor.jvm.HotThreads.SortOrder
- CPU_STAT_STRING_PARSING - Static variable in class org.elasticsearch.TransportVersions
- CpuStat(BigInteger, BigInteger, BigInteger) - Constructor for class org.elasticsearch.monitor.os.OsStats.Cgroup.CpuStat
- create() - Method in interface org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest.Factory
- create() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction.Request
- create() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- create() - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutComposableIndexTemplateAction.Request
- create() - Method in class org.elasticsearch.cluster.coordination.NodeToolCliProvider
- create() - Static method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Constructs a new keystore with the given password.
- create() - Method in class org.elasticsearch.index.analysis.StandardTokenizerFactory
- create() - Method in interface org.elasticsearch.index.analysis.TokenizerFactory
- create() - Method in class org.elasticsearch.index.shard.ShardToolCliProvider
- create() - Static method in class org.elasticsearch.injection.Injector
- create() - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
-
Creates the pipeline aggregator
- create() - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
-
Creates the pipeline aggregator
- create(boolean) - Method in class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction.Request
-
Set to
true
to force only creation, not an update of an index template. - create(boolean) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Set to
true
to force only creation, not an update of an index template. - create(boolean) - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutComposableIndexTemplateAction.Request
-
Set to
true
to force only creation, not an update of an index template. - create(boolean) - Method in class org.elasticsearch.action.index.IndexRequest
-
Set to
true
to force this index to useDocWriteRequest.OpType.CREATE
. - create(boolean) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutRequest
- create(boolean, Set<String>) - Static method in class org.elasticsearch.index.fieldvisitor.StoredFieldLoader
-
Creates a new StoredFieldLoader
- create(long, long, List<B>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- create(long, long, List<SignificantLongTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms
- create(long, long, List<SignificantStringTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms
- create(long, long, List<UnmappedSignificantTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- create(long, RoutingAllocation) - Static method in record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceInput
- create(Reader) - Method in interface org.elasticsearch.index.analysis.CharFilterFactory
- create(String, int, List<InternalGeoGridBucket>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- create(String, int, List<InternalGeoGridBucket>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
- create(String, int, List<InternalGeoGridBucket>, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoTileGrid
- create(String, long, List<DesiredNodeWithStatus>) - Static method in class org.elasticsearch.cluster.metadata.DesiredNodes
- create(String, List<B>, BucketOrder, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
-
Creates InternalTerms at the end of the merge
- create(String, List<B>, BucketOrder, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- create(String, List<B>, DocValueFormat, boolean, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
- create(String, List<InternalDateRange.Bucket>, DocValueFormat, boolean, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Factory
- create(String, List<InternalGeoDistance.Bucket>, DocValueFormat, boolean, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance.Factory
- create(String, List<DoubleTerms.Bucket>, BucketOrder, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- create(String, List<LongTerms.Bucket>, BucketOrder, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- create(String, List<StringTerms.Bucket>, BucketOrder, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- create(String, List<UnmappedTerms.Bucket>, BucketOrder, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- create(String, Map<String, Object>, Map<String, Processor.Factory>, ScriptService) - Static method in class org.elasticsearch.ingest.Pipeline
- create(List<B>) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- create(List<B>) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
-
Create a new copy of this
Aggregation
with the same settings as thisAggregation
and contains the provided buckets. - create(List<B>, R) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
- create(List<Double>, List<Long>) - Static method in class org.elasticsearch.cluster.metadata.IndexWriteLoad
- create(List<DataStreamAction>) - Method in interface org.elasticsearch.action.datastreams.ModifyDataStreamsAction.Request.Factory
- create(List<InternalComposite.InternalBucket>) - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- create(List<InternalFilters.InternalBucket>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- create(List<InternalGeoGridBucket>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
- create(List<InternalGeoGridBucket>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoTileGrid
- create(List<InternalDateHistogram.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- create(List<InternalHistogram.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- create(List<InternalVariableWidthHistogram.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- create(List<InternalIpPrefix.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.prefix.InternalIpPrefix
- create(List<InternalBinaryRange.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- create(List<InternalDateRange.Bucket>, InternalDateRange) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Factory
- create(List<InternalGeoDistance.Bucket>, InternalGeoDistance) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance.Factory
- create(List<DoubleTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- create(List<LongRareTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms
- create(List<LongTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- create(List<SignificantLongTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms
- create(List<SignificantStringTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms
- create(List<StringRareTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms
- create(List<StringTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- create(List<UnmappedRareTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- create(List<UnmappedSignificantTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- create(List<UnmappedTerms.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- create(Map<String, Processor.Factory>, String, String, Map<String, Object>) - Method in class org.elasticsearch.ingest.DropProcessor.Factory
- create(Map<String, Processor.Factory>, String, String, Map<String, Object>) - Method in class org.elasticsearch.ingest.PipelineProcessor.Factory
- create(Map<String, Processor.Factory>, String, String, Map<String, Object>) - Method in interface org.elasticsearch.ingest.Processor.Factory
-
Creates a processor based on the specified map of maps config.
- create(K, Errors) - Method in class org.elasticsearch.injection.guice.internal.FailableCache
- create(Logger, Level, String, ReferenceDocs) - Static method in class org.elasticsearch.common.logging.ChunkedLoggingStream
-
Create an
OutputStream
which Gzip-compresses the written data, Base64-encodes it, and writes it in fixed-size (2kiB) chunks to the given logger. - create(TokenStream) - Method in class org.elasticsearch.index.analysis.HunspellTokenFilterFactory
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
- create(TokenStream) - Method in class org.elasticsearch.index.analysis.StopTokenFilterFactory
- create(TokenStream) - Method in interface org.elasticsearch.index.analysis.TokenFilterFactory
- create(LatLonGeometry) - Method in class org.elasticsearch.lucene.spatial.LatLonShapeDocValuesQuery
- create(LatLonGeometry[]) - Method in class org.elasticsearch.lucene.spatial.LatLonShapeDocValuesQuery
- create(XYGeometry) - Method in class org.elasticsearch.lucene.spatial.CartesianShapeDocValuesQuery
- create(XYGeometry[]) - Method in class org.elasticsearch.lucene.spatial.CartesianShapeDocValuesQuery
- create(CreateIndexRequest) - Method in class org.elasticsearch.client.internal.IndicesAdminClient
- create(CreateIndexRequest, ActionListener<CreateIndexResponse>) - Method in class org.elasticsearch.client.internal.IndicesAdminClient
- create(HeartbeatStore, ThreadPool, Settings, Consumer<ActionListener<OptionalLong>>) - Static method in class org.elasticsearch.cluster.coordination.stateless.StoreHeartbeatService
- create(RepositoryMetadata) - Method in interface org.elasticsearch.repositories.Repository.Factory
-
Constructs a repository.
- create(RepositoryMetadata, Function<String, Repository.Factory>) - Method in interface org.elasticsearch.repositories.Repository.Factory
- create(ClusterService) - Static method in class org.elasticsearch.health.node.HealthInfoCache
- create(ClusterService, FeatureService, Settings) - Static method in class org.elasticsearch.health.metadata.HealthMetadataService
- create(ClusterService, PersistentTasksService, FeatureService, Settings, ClusterSettings) - Static method in class org.elasticsearch.health.node.selection.HealthNodeTaskExecutor
- create(CircuitBreaker, double) - Static method in class org.elasticsearch.search.aggregations.metrics.TDigestState
-
Default factory for TDigestState.
- create(CircuitBreaker, double, TDigestExecutionHint) - Static method in class org.elasticsearch.search.aggregations.metrics.TDigestState
-
Factory for TDigestState.
- create(ClusterSettings) - Static method in class org.elasticsearch.cluster.metadata.DataStreamGlobalRetentionSettings
-
Creates an instance and initialises the cluster settings listeners
- create(Settings, Class<T>, Environment) - Static method in class org.elasticsearch.indices.analysis.wrappers.SettingsInvocationHandler
- create(Settings, ClusterService, Client, HealthService, TelemetryProvider) - Static method in class org.elasticsearch.health.HealthPeriodicLogger
-
Creates a new HealthPeriodicLogger.
- create(Settings, ClusterService, ThreadPool, Client, FeatureService, List<HealthTracker<?>>) - Static method in class org.elasticsearch.health.node.LocalHealthMonitor
- create(Settings, ThreadPool) - Static method in class org.elasticsearch.action.bulk.WriteAckDelay
-
Creates a potential WriteAckDelay object based on settings.
- create(TimeValue, Boolean, DataStreamLifecycle.Downsampling) - Method in interface org.elasticsearch.action.datastreams.lifecycle.PutDataStreamLifecycleAction.Request.Factory
- create(IndexVersion) - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProviderFactory
- create(IndexVersion) - Method in class org.elasticsearch.index.analysis.PreConfiguredAnalysisComponent
- create(IndexVersion) - Method in class org.elasticsearch.index.analysis.PreConfiguredCharFilter
- create(IndexVersion) - Method in class org.elasticsearch.index.analysis.PreConfiguredTokenFilter
- create(IndexVersion) - Method in class org.elasticsearch.index.analysis.PreConfiguredTokenizer
- create(IndexVersion) - Method in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- create(SearchExecutionContext, Collection<FieldAndFormat>) - Static method in class org.elasticsearch.search.fetch.subphase.FieldFetcher
-
Build a FieldFetcher for a given search context and collection of fields and formats
- create(ShardId, String, long, Path, ChannelFactory, ByteSizeValue, long, long, LongSupplier, LongSupplier, long, TragicExceptionHolder, LongConsumer, BigArrays, DiskIoBufferPool, OperationListener, boolean) - Static method in class org.elasticsearch.index.translog.TranslogWriter
- create(InferenceServiceExtension.InferenceServiceFactoryContext) - Method in interface org.elasticsearch.inference.InferenceServiceExtension.Factory
-
InferenceServices are created from the factory context
- create(Aggregator, CardinalityUpperBound) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
-
Creates the aggregator.
- create(InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
-
Create a new copy of this
Aggregation
with the same settings as thisAggregation
and contains the provided sub-aggregations. - create(MeterRegistry, String, String, String) - Static method in record class org.elasticsearch.telemetry.metric.LongGaugeMetric
- create(TransportService, Runnable, LongConsumer, ElectionStrategy, NodeHealthService, LeaderHeartbeatService) - Method in interface org.elasticsearch.cluster.coordination.PreVoteCollector.Factory
- create(Version) - Method in enum class org.elasticsearch.indices.analysis.PreBuiltTokenizers
- CREATE - Enum constant in enum class org.elasticsearch.action.DocWriteRequest.OpType
-
Creates the resource.
- CREATE - Enum constant in enum class org.elasticsearch.index.translog.Translog.Operation.Type
-
Deprecated.
- CREATE_INDEX - Enum constant in enum class org.elasticsearch.index.IndexService.IndexCreationContext
- CREATE_WEIGHT - Enum constant in enum class org.elasticsearch.search.profile.dfs.DfsTimingType
- CREATE_WEIGHT - Enum constant in enum class org.elasticsearch.search.profile.query.QueryTimingType
- createActionContext(Task, NodesRequest) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
Create an (optional)
TransportNodesAction
: called when starting to execute this action, and the result passed toTransportNodesAction.newResponseAsync(org.elasticsearch.tasks.Task, NodesRequest, ActionContext, java.util.List<NodeResponse>, java.util.List<org.elasticsearch.action.FailedNodeException>, org.elasticsearch.action.ActionListener<NodesResponse>)
on completion. - createActionContext(Task, ClusterStatsRequest) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
- createAggregation(List<MultiBucketsAggregation.Bucket>) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.HistogramFactory
-
Create an
InternalAggregation
object that wraps the given buckets. - createAggregation(List<MultiBucketsAggregation.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- createAggregation(List<MultiBucketsAggregation.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- createAggregation(List<MultiBucketsAggregation.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- createAllocateParser(String) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- createAllocatePrimaryParser(String) - Static method in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
- createAllocationDeciders(Settings, ClusterSettings) - Method in interface org.elasticsearch.plugins.ClusterPlugin
-
Return deciders used to customize where shards are allocated.
- createAllocationDeciders(Settings, ClusterSettings, List<ClusterPlugin>) - Static method in class org.elasticsearch.cluster.ClusterModule
-
Return a new
AllocationDecider
instance with builtin deciders as well as those from plugins. - createAndRegisterListener(ClusterService, RestoreService.RestoreCompletionResponse, ActionListener<RestoreSnapshotResponse>, ThreadContext) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreClusterStateListener
-
Creates a cluster state listener and registers it with the cluster service.
- createAppender(String, Filter) - Static method in class org.elasticsearch.common.logging.HeaderWarningAppender
- createBlobStore() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Creates new BlobStore to read and write data.
- createBlobStore() - Method in class org.elasticsearch.repositories.fs.FsRepository
- createBucket(long, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- createBucket(long, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
- createBucket(long, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoTileGrid
- createBucket(long, InternalAggregations, long, B) - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- createBucket(long, InternalAggregations, long, DoubleTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- createBucket(long, InternalAggregations, long, LongTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- createBucket(long, InternalAggregations, long, StringTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- createBucket(long, InternalAggregations, long, UnmappedTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- createBucket(B, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.FixedMultiBucketAggregatorsReducer
- createBucket(Number, long, InternalAggregations) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.HistogramFactory
-
Create a
MultiBucketsAggregation.Bucket
object that wraps the given key, document count and aggregations. - createBucket(Number, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- createBucket(Number, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- createBucket(Number, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- createBucket(String, double, double, long, InternalAggregations, boolean, DocValueFormat) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Factory
- createBucket(String, double, double, long, InternalAggregations, boolean, DocValueFormat) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance.Factory
- createBucket(String, double, double, long, InternalAggregations, boolean, DocValueFormat) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
- createBucket(InternalAggregations, B) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- createBucket(InternalAggregations, B) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
- createBucket(InternalAggregations, B) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
-
Create a new
InternalMultiBucketAggregation.InternalBucket
using the provided prototype bucket and aggregations. - createBucket(InternalAggregations, InternalComposite.InternalBucket) - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- createBucket(InternalAggregations, InternalFilters.InternalBucket) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- createBucket(InternalAggregations, InternalGeoGridBucket) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
- createBucket(InternalAggregations, InternalGeoGridBucket) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoTileGrid
- createBucket(InternalAggregations, InternalDateHistogram.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- createBucket(InternalAggregations, InternalHistogram.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- createBucket(InternalAggregations, InternalVariableWidthHistogram.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- createBucket(InternalAggregations, InternalIpPrefix.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.prefix.InternalIpPrefix
- createBucket(InternalAggregations, InternalBinaryRange.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- createBucket(InternalAggregations, InternalDateRange.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Factory
- createBucket(InternalAggregations, InternalGeoDistance.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance.Factory
- createBucket(InternalAggregations, DoubleTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- createBucket(InternalAggregations, LongRareTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms
- createBucket(InternalAggregations, LongTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- createBucket(InternalAggregations, SignificantLongTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms
- createBucket(InternalAggregations, SignificantStringTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms
- createBucket(InternalAggregations, StringRareTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms
- createBucket(InternalAggregations, StringTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- createBucket(InternalAggregations, UnmappedRareTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- createBucket(InternalAggregations, UnmappedSignificantTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- createBucket(InternalAggregations, UnmappedTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
-
Create an array to hold some buckets.
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- createBuiltInClusterSettings() - Static method in class org.elasticsearch.common.settings.ClusterSettings
- createBuiltInClusterSettings(Settings) - Static method in class org.elasticsearch.common.settings.ClusterSettings
- createCandidate(BytesRef, boolean) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
- createCandidate(BytesRef, TermStats, double) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
- createCandidate(BytesRef, TermStats, double, boolean) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
- createCandidate(BytesRef, TermStats, double, boolean) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- createCandidate(BytesRef, TermStats, double, boolean) - Method in class org.elasticsearch.search.suggest.phrase.MultiCandidateGeneratorWrapper
- createChildContext(String, boolean, ObjectMapper.Dynamic) - Method in class org.elasticsearch.index.mapper.MapperBuilderContext
-
Creates a new MapperBuilderContext that is a child of this context
- createChildContext(String, ObjectMapper.Dynamic) - Method in class org.elasticsearch.index.mapper.MapperBuilderContext
-
Creates a new MapperBuilderContext that is a child of this context
- createChildContext(String, ObjectMapper.Dynamic) - Method in class org.elasticsearch.index.mapper.MapperMergeContext
-
Creates a new
MapperMergeContext
with a childMapperBuilderContext
. - createChildContext(MapperMergeContext, String) - Method in class org.elasticsearch.index.mapper.NestedObjectMapper
- createChildContext(MapperMergeContext, String) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- createChildContext(MapperMergeContext, String) - Method in class org.elasticsearch.index.mapper.RootObjectMapper
- createChildContext(ObjectMapper) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- createChildRuntimeField(MappingParserContext, String, Function<SearchLookup, CompositeFieldScript.LeafFactory>, OnScriptError) - Method in class org.elasticsearch.index.mapper.AbstractScriptFieldType.Builder
- createChildRuntimeField(MappingParserContext, String, Function<SearchLookup, CompositeFieldScript.LeafFactory>, OnScriptError) - Method in class org.elasticsearch.index.mapper.RuntimeField.Builder
- createComponents(String) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- createComponents(String) - Method in class org.elasticsearch.index.analysis.LowercaseNormalizer
- createComponents(String) - Method in class org.elasticsearch.index.analysis.ReloadableCustomAnalyzer
- createComponents(Plugin.PluginServices) - Method in class org.elasticsearch.plugins.Plugin
-
Returns components added by this plugin.
- createContext(ReaderContext, ShardSearchRequest, SearchShardTask, SearchService.ResultsType, boolean) - Method in class org.elasticsearch.search.SearchService
- createCopyToContext(String, LuceneDocument) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Return a context for copy_to directives
- CREATED - Enum constant in enum class org.elasticsearch.action.DocWriteResponse.Result
- CREATED - Enum constant in enum class org.elasticsearch.index.shard.IndexShardState
- CREATED - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The request has been fulfilled and resulted in a new resource being created.
- CREATED - Enum constant in enum class org.elasticsearch.synonyms.SynonymsManagementAPIService.UpdateSynonymsResultStatus
- CREATED_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- createDataStream(MetadataCreateDataStreamService.CreateDataStreamClusterStateUpdateRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService
- createDataStream(MetadataCreateDataStreamService.CreateDataStreamClusterStateUpdateRequest, ClusterState, ActionListener<Void>, boolean) - Method in class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService
- CreateDataStreamAction - Class in org.elasticsearch.action.datastreams
- CreateDataStreamAction.Request - Class in org.elasticsearch.action.datastreams
- CreateDataStreamClusterStateUpdateRequest(String) - Constructor for record class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService.CreateDataStreamClusterStateUpdateRequest
- CreateDataStreamClusterStateUpdateRequest(String, long, SystemDataStreamDescriptor, TimeValue, TimeValue, boolean) - Constructor for record class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService.CreateDataStreamClusterStateUpdateRequest
-
Creates an instance of a
CreateDataStreamClusterStateUpdateRequest
record class. - CreateDataStreamClusterStateUpdateRequest(String, SystemDataStreamDescriptor, TimeValue, TimeValue, boolean) - Constructor for record class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService.CreateDataStreamClusterStateUpdateRequest
- createDirectory(Path) - Method in class org.elasticsearch.gateway.PersistedClusterStateService
- createDirectSpellChecker() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- createDocumentSizeAccumulator() - Method in interface org.elasticsearch.plugins.internal.DocumentParsingProvider
- createDynamicMapperBuilderContext() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Creates a context to build dynamic mappers
- createDynamicTemplateContext(DateFormatter) - Method in class org.elasticsearch.index.mapper.MappingParserContext
- createEmpty() - Method in class org.elasticsearch.index.store.Store
-
creates an empty lucene index and a corresponding empty translog.
- createEmpty(MapperService) - Static method in class org.elasticsearch.index.mapper.DocumentMapper
-
Create a new
DocumentMapper
that holds empty mappings. - createEmptyMax(String, DocValueFormat, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.metrics.Max
- createEmptyMin(String, DocValueFormat, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.metrics.Min
- createEmptyPercentileRanksAggregator(String, double[], boolean, DocValueFormat, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig
- createEmptyPercentileRanksAggregator(String, double[], boolean, DocValueFormat, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.Hdr
- createEmptyPercentileRanksAggregator(String, double[], boolean, DocValueFormat, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.TDigest
- createEmptyPercentilesAggregator(String, double[], boolean, DocValueFormat, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig
- createEmptyPercentilesAggregator(String, double[], boolean, DocValueFormat, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.Hdr
- createEmptyPercentilesAggregator(String, double[], boolean, DocValueFormat, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.TDigest
- createEmptyTranslog(Path, long, ShardId, long) - Static method in class org.elasticsearch.index.translog.Translog
- createEmptyTranslog(Path, ShardId, long, long, String, ChannelFactory) - Static method in class org.elasticsearch.index.translog.Translog
-
Creates a new empty translog within the specified
location
that contains the giveninitialGlobalCheckpoint
,primaryTerm
andtranslogUUID
. - createEnv(OptionSet, ProcessInfo) - Method in class org.elasticsearch.common.cli.EnvironmentAwareCommand
-
Create an
Environment
for the command to use. - createExactKnnQuery(VectorData, Float) - Method in class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.DenseVectorFieldType
- createFactory(String, ValuesSourceConfig, int, int, int, GeoBoundingBox, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
-
Creates a new instance of the
ValuesSourceAggregatorFactory
-derived class specific to the geo aggregation. - createFactory(String, ValuesSourceConfig, int, int, int, GeoBoundingBox, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- createFactory(String, ValuesSourceConfig, int, int, int, GeoBoundingBox, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregationBuilder
- createFailureStoreIndex(MetadataCreateIndexService, String, Settings, ClusterState, long, String, ComposableIndexTemplate, String, BiConsumer<Metadata.Builder, IndexMetadata>) - Static method in class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService
- createField(DocumentParserContext, IndexRouting.ExtractFromSource.Builder, BytesRef) - Static method in class org.elasticsearch.index.mapper.TsidExtractingIdFieldMapper
- createFields(DocumentParserContext, String, RangeFieldMapper.Range, boolean, boolean, boolean) - Method in enum class org.elasticsearch.index.mapper.RangeType
- createFieldType(String, Factory, Script, Map<String, String>, IndexVersion, OnScriptError) - Method in class org.elasticsearch.index.mapper.AbstractScriptFieldType.Builder
- createFieldType(String, Factory, Script, Map<String, String>, OnScriptError) - Method in class org.elasticsearch.index.mapper.AbstractScriptFieldType.Builder
- createFilter(Filter.Result, Filter.Result) - Static method in class org.elasticsearch.common.logging.RateLimitingFilter
- createFlattenContext(String) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Return a context for flattening subobjects
- createForBalancing(RoutingAllocation, NodeAllocationOrdering) - Static method in class org.elasticsearch.cluster.routing.allocation.allocator.OrderedShardsIterator
- createForFinal() - Method in class org.elasticsearch.search.aggregations.MultiBucketConsumerService
- createForNecessaryMoves(RoutingAllocation, NodeAllocationOrdering) - Static method in class org.elasticsearch.cluster.routing.allocation.allocator.OrderedShardsIterator
- createForPartial() - Method in class org.elasticsearch.search.aggregations.MultiBucketConsumerService
- createFrom(ClusterState, DesiredBalance, ClusterInfo, WriteLoadForecaster) - Static method in record class org.elasticsearch.cluster.routing.allocation.allocator.ClusterBalanceStats
- createFromSpecifications(List<? extends FeatureSpecification>) - Static method in class org.elasticsearch.features.FeatureData
- createGrokThreadWatchdog(Environment, ThreadPool) - Static method in class org.elasticsearch.ingest.IngestService
- CreateHandler() - Constructor for class org.elasticsearch.rest.action.document.RestIndexAction.CreateHandler
- createId(boolean, IndexRouting.ExtractFromSource.Builder, BytesRef, long, byte[]) - Static method in class org.elasticsearch.index.mapper.TsidExtractingIdFieldMapper
- createId(byte[], IntSupplier) - Method in class org.elasticsearch.cluster.routing.IndexRouting.ExtractFromSource.Builder
- createId(int, BytesRef, long) - Static method in class org.elasticsearch.index.mapper.TsidExtractingIdFieldMapper
- createId(Map<String, Object>, byte[]) - Method in class org.elasticsearch.cluster.routing.IndexRouting.ExtractFromSource
- createId(XContentType, BytesReference, byte[]) - Method in class org.elasticsearch.cluster.routing.IndexRouting.ExtractFromSource
- createIncludingStatusFromPreviousVersion(String, long, List<DesiredNode>, DesiredNodes) - Static method in class org.elasticsearch.cluster.metadata.DesiredNodes
- createIndex(IndexMetadata, List<IndexEventListener>, boolean) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
-
Creates a new
IndexService
for the given metadata. - createIndex(IndexMetadata, List<IndexEventListener>, boolean) - Method in class org.elasticsearch.indices.IndicesService
-
Creates a new
IndexService
for the given metadata. - createIndex(TimeValue, TimeValue, TimeValue, CreateIndexClusterStateUpdateRequest, ActionListener<ShardsAcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
-
Creates an index in the cluster state and waits for the specified number of shard copies to become active (as specified in
CreateIndexClusterStateUpdateRequest.waitForActiveShards()
) before sending the response on the listener. - CreateIndexCapabilities - Class in org.elasticsearch.rest.action.admin.indices
-
A
Set
of "capabilities" supported by theRestCreateIndexAction
. - CreateIndexCapabilities() - Constructor for class org.elasticsearch.rest.action.admin.indices.CreateIndexCapabilities
- createIndexClosingBlock() - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexStateService
- CreateIndexClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.create
-
Cluster state update request that allows to create an index
- CreateIndexClusterStateUpdateRequest(String, String, String) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- createIndexMapperServiceForValidation(IndexMetadata) - Method in class org.elasticsearch.indices.IndicesService
-
creates a new mapper service for the given index, in order to do administrative work like mapping updates.
- CreateIndexRequest - Class in org.elasticsearch.action.admin.indices.create
-
A request to create an index.
- CreateIndexRequest() - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- CreateIndexRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Constructs a request to create an index.
- CreateIndexRequest(String, Settings) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Constructs a request to create an index.
- CreateIndexRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Constructs a new request by deserializing an input
- CreateIndexRequestBuilder - Class in org.elasticsearch.action.admin.indices.create
-
Builder for a create index request
- CreateIndexRequestBuilder(ElasticsearchClient) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
- CreateIndexRequestBuilder(ElasticsearchClient, String) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
- CreateIndexResponse - Class in org.elasticsearch.action.admin.indices.create
-
A response for a create index action.
- CreateIndexResponse(boolean, boolean, String) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- CreateIndexResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- createIndicator(HealthStatus, String, HealthIndicatorDetails, Collection<HealthIndicatorImpact>, List<Diagnosis>) - Method in interface org.elasticsearch.health.HealthIndicatorService
-
This method creates a HealthIndicatorResult with the given information.
- createInjector() - Method in class org.elasticsearch.injection.guice.ModulesBuilder
- createInjector(Iterable<? extends Module>) - Static method in class org.elasticsearch.injection.guice.Guice
-
Creates an injector for the given set of modules.
- createInjector(Module...) - Static method in class org.elasticsearch.injection.guice.Guice
-
Creates an injector for the given set of modules.
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.MaxBucketPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.MinBucketPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Deprecated.
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.StatsBucketPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.SumBucketPipelineAggregationBuilder
- createInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
- createInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder.FilterAggregatorFactory
- createInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregatorFactory
- createInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregatorFactory
- createInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregatorFactory
- createInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregatorFactory
- createInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.random.RandomSamplerAggregatorFactory
- createInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregatorFactory
- createInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregatorFactory
- createInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
- createInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
- createInternalReaderManager(ElasticsearchDirectoryReader) - Method in class org.elasticsearch.index.engine.InternalEngine
- createKeyword(String, MappedFieldType, Sort, int, FieldDoc) - Static method in class org.elasticsearch.lucene.grouping.SinglePassGroupingCollector
-
Creates a
SinglePassGroupingCollector
on aSortedDocValues
field. - createKnnQuery(VectorData, Integer, int, Query, Float, BitSetProducer) - Method in class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.DenseVectorFieldType
- createLayout(String, Charset, String[], Configuration) - Static method in class org.elasticsearch.common.logging.ESJsonLayout
-
Deprecated.
- createListener(ThreadPool) - Method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- createLiveVersionMapArchive() - Method in class org.elasticsearch.index.engine.InternalEngine
- createLocal(Settings, TransportAddress, String) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Creates a DiscoveryNode representing the local node.
- createMergeScheduler(ShardId, IndexSettings) - Method in class org.elasticsearch.index.engine.InternalEngine
- createMissingIndicesAndIndexData(Task, BulkRequest, Executor, ActionListener<BulkResponse>, Map<String, CreateIndexRequest>, Set<String>, Set<String>, long) - Method in class org.elasticsearch.action.bulk.TransportBulkAction
-
This method is responsible for creating any missing indices, rolling over data streams and their failure stores when needed, and then indexing the data in the BulkRequest.
- createMissingPeerRecoveryRetentionLeases(ActionListener<Void>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Create any required peer-recovery retention leases that do not currently exist because we just did a rolling upgrade from a version prior to
Version.V_7_4_0
that does not create peer-recovery retention leases. - createMultiFieldContext() - Method in class org.elasticsearch.index.mapper.MappingParserContext
- createNestedContext(NestedObjectMapper) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Return a new context that will be used within a nested document.
- createNewStatus(Metadata) - Method in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
-
Creates a new
ShardsAvailabilityHealthIndicatorService.ShardAllocationStatus
that will be used to track primary and replica availability, providing the color, diagnosis, and messages about the available or unavailable shards in the cluster. - createNumeric(String, MappedFieldType, Sort, int, FieldDoc) - Static method in class org.elasticsearch.lucene.grouping.SinglePassGroupingCollector
-
Creates a
SinglePassGroupingCollector
on aNumericDocValues
field. - createParser(String, TriFunction<String, double[], PercentilesConfig, T>, Supplier<PercentilesConfig>, ParseField) - Static method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
- createParser(String, GeoGridAggregationBuilder.PrecisionParser, Function<String, T>) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- createParser(NamedXContentRegistry, DeprecationHandler, BytesReference) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Deprecated.use
XContentHelper.createParser(XContentParserConfiguration, BytesReference, XContentType)
to avoid content type auto-detection - createParser(NamedXContentRegistry, DeprecationHandler, BytesReference, XContentType) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
- createParser(XContentParserConfiguration, BytesReference) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Deprecated.use
XContentHelper.createParser(XContentParserConfiguration, BytesReference, XContentType)
to avoid content type auto-detection - createParser(XContentParserConfiguration, BytesReference, XContentType) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Creates a parser for the bytes using the supplied content-type
- createParserNotCompressed(XContentParserConfiguration, BytesReference, XContentType) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Same as
XContentHelper.createParser(XContentParserConfiguration, BytesReference, XContentType)
but only supports uncompressedbytes
. - createPercentilesAggregator(String, ValuesSourceConfig, AggregationContext, Aggregator, double[], boolean, DocValueFormat, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig
- createPercentilesAggregator(String, ValuesSourceConfig, AggregationContext, Aggregator, double[], boolean, DocValueFormat, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.Hdr
- createPercentilesAggregator(String, ValuesSourceConfig, AggregationContext, Aggregator, double[], boolean, DocValueFormat, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.TDigest
- createPersistedClusterStateService(Settings, Path[]) - Static method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- createPersistedState(Settings, TransportService, PersistedClusterStateService) - Method in interface org.elasticsearch.plugins.ClusterCoordinationPlugin.PersistedStateFactory
- createPersistentTask(String, String, Params, ActionListener<PersistentTasksCustomMetadata.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksClusterService
-
Creates a new persistent task on master node
- createPhrasePrefixQuery(TokenStream, String, int, int, String, IntPredicate) - Static method in class org.elasticsearch.index.mapper.TextFieldMapper
- createPhraseQuery(TokenStream, String, int, boolean) - Static method in class org.elasticsearch.index.mapper.TextFieldMapper
- createPoint(double, double) - Method in class org.elasticsearch.common.geo.GenericPointParser
- createPoint(double, double) - Method in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.PointParser
- createProfileBreakdown() - Method in class org.elasticsearch.search.profile.AbstractInternalProfileTree
- createProfileBreakdown() - Method in class org.elasticsearch.search.profile.aggregation.InternalAggregationProfileTree
- createProxy(Errors, Class<?>) - Method in class org.elasticsearch.injection.guice.internal.ConstructionContext
- createRangeQuery(String, boolean, Object, Object, boolean, boolean, ShapeRelation) - Method in enum class org.elasticsearch.index.mapper.RangeType
- createRecoveryPlannerService(ShardSnapshotsService) - Method in interface org.elasticsearch.plugins.RecoveryPlannerPlugin
- createRecoveryState(ShardRouting, DiscoveryNode, DiscoveryNode) - Method in class org.elasticsearch.index.IndexService
- createRecycler(Settings, PageCacheRecycler) - Method in class org.elasticsearch.transport.TcpTransport
- createReduced(String, double[], TDigestState, boolean, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks
- createReduced(String, double[], TDigestState, boolean, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- createReduced(String, double[], DoubleHistogram, boolean, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks
- createReduced(String, double[], DoubleHistogram, boolean, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- createRepository(RepositoryMetadata) - Method in class org.elasticsearch.repositories.RepositoriesService
-
Creates a repository holder.
- createRequest(RestRequest) - Static method in class org.elasticsearch.rest.action.admin.cluster.RestClusterRerouteAction
- createResponse(RestStatus, BytesReference) - Method in interface org.elasticsearch.http.HttpRequest
-
Create an http response from this request and the supplied status and content.
- createResponse(RestStatus, ChunkedRestResponseBodyPart) - Method in interface org.elasticsearch.http.HttpRequest
- createRounding() - Method in class org.elasticsearch.action.downsample.DownsampleConfig
-
Create the rounding for this date histogram
- createRounding(String, String) - Static method in class org.elasticsearch.action.downsample.DownsampleConfig
- createRounding(ZoneId, long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- createRuntimeField(MappingParserContext) - Method in class org.elasticsearch.index.mapper.AbstractScriptFieldType.Builder
- createRuntimeField(MappingParserContext) - Method in class org.elasticsearch.index.mapper.RuntimeField.Builder
- createSearchContext(ShardSearchRequest, TimeValue) - Method in class org.elasticsearch.search.SearchService
- createSearchSourceBuilder(PointInTimeBuilder, RetrieverBuilder) - Method in class org.elasticsearch.search.retriever.CompoundRetrieverBuilder
- createSecure() - Static method in class org.elasticsearch.common.Randomness
-
Provides a secure source of randomness.
- createSession() - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker
-
Returns a new session which can be passed to a
FieldUsageTrackingDirectoryReader
to track field usage of a shard. - createShard(ShardRouting, GlobalCheckpointSyncer, RetentionLeaseSyncer) - Method in class org.elasticsearch.index.IndexService
- createShard(ShardRouting, PeerRecoveryTargetService, PeerRecoveryTargetService.RecoveryListener, RepositoriesService, Consumer<IndexShard.ShardFailure>, GlobalCheckpointSyncer, RetentionLeaseSyncer, DiscoveryNode, DiscoveryNode, long) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
-
Creates a shard for the specified shard routing and starts recovery.
- createShard(ShardRouting, PeerRecoveryTargetService, PeerRecoveryTargetService.RecoveryListener, RepositoriesService, Consumer<IndexShard.ShardFailure>, GlobalCheckpointSyncer, RetentionLeaseSyncer, DiscoveryNode, DiscoveryNode, long) - Method in class org.elasticsearch.indices.IndicesService
- createShardSearchRequest(CanMatchNodeRequest.Shard) - Method in class org.elasticsearch.action.search.CanMatchNodeRequest
- createSnapshot(CreateSnapshotRequest) - Method in class org.elasticsearch.client.internal.ClusterAdminClient
- createSnapshot(CreateSnapshotRequest, ActionListener<CreateSnapshotResponse>) - Method in class org.elasticsearch.client.internal.ClusterAdminClient
- createSnapshot(CreateSnapshotRequest, ActionListener<Snapshot>) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Initializes the snapshotting process.
- CreateSnapshotRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.create
-
Create snapshot request
- CreateSnapshotRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- CreateSnapshotRequest(TimeValue) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- CreateSnapshotRequest(TimeValue, String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Constructs a new put repository request with the provided snapshot and repository names
- CreateSnapshotRequestBuilder - Class in org.elasticsearch.action.admin.cluster.snapshots.create
-
Create snapshot request builder
- CreateSnapshotRequestBuilder(ElasticsearchClient, TimeValue, String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Constructs a new create snapshot request builder with specified repository and snapshot names
- CreateSnapshotResponse - Class in org.elasticsearch.action.admin.cluster.snapshots.create
-
Create snapshot response
- CreateSnapshotResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
- CreateSnapshotResponse(SnapshotInfo) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
- createSourceProvider() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- createSubAggregators(Aggregator, CardinalityUpperBound) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
-
Create all aggregators so that they can be consumed with multiple buckets.
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction.NodeStatsRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction.ClusterStatsNodeRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.diskusage.AnalyzeIndexDiskUsageRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveClusterActionRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.downsample.DownsampleAction.Request
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.search.CanMatchNodeRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.search.MultiSearchRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.search.SearchRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.search.SearchScrollRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.search.SearchShardsRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.health.GetHealthAction.Request
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.health.node.action.HealthNodeRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction.Request
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Request
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.search.query.QuerySearchRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.search.rank.feature.RankFeatureShardRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in interface org.elasticsearch.tasks.TaskAwareRequest
-
Returns the task object that should be used to keep track of the processing of the request.
- createTask(long, String, String, TaskId, PersistentTasksCustomMetadata.PersistentTask<HealthNodeTaskParams>, Map<String, String>) - Method in class org.elasticsearch.health.node.selection.HealthNodeTaskExecutor
- createTask(long, String, String, TaskId, PersistentTasksCustomMetadata.PersistentTask<SystemIndexMigrationTaskParams>, Map<String, String>) - Method in class org.elasticsearch.upgrades.SystemIndexMigrationExecutor
- createTask(long, String, String, TaskId, PersistentTasksCustomMetadata.PersistentTask<Params>, Map<String, String>) - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
-
Creates a AllocatedPersistentTask for communicating with task manager
- createTaskQueue(String, Priority, ClusterStateTaskExecutor<T>) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Create a new task queue which can be used to submit tasks for execution by the master service.
- createTaskQueue(String, Priority, ClusterStateTaskExecutor<T>) - Method in class org.elasticsearch.cluster.service.MasterService
-
Create a new task queue which can be used to submit tasks for execution by the master service.
- createThreadPool(Settings) - Static method in class org.elasticsearch.ingest.LogstashInternalBridge
- createThreadPoolExecutor() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- createThreadPoolExecutor() - Method in class org.elasticsearch.cluster.service.MasterService
- createTopDocs(Sort, int, FieldDoc) - Method in class org.elasticsearch.search.collapse.CollapseContext
- createTopDocsCollector(int) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- createTopLevelAggregators() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
- createTsIdLoader(IndexRouting.ExtractFromSource, List<String>) - Static method in interface org.elasticsearch.index.mapper.IdLoader
- createTwoPhaseIterator(IpFieldScript, DocIdSetIterator) - Method in class org.elasticsearch.search.runtime.IpScriptFieldTermsQuery
- createTwoPhaseIterator(StringFieldScript, DocIdSetIterator) - Method in class org.elasticsearch.search.runtime.AbstractStringScriptFieldAutomatonQuery
- createTwoPhaseIterator(S, DocIdSetIterator) - Method in class org.elasticsearch.search.runtime.AbstractScriptFieldQuery
-
Creates the
TwoPhaseIterator
for the current leaf reader. - createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.prefix.IpPrefixAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceRangeAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregatorFactory
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
-
Create an aggregator that won't collect anything but will return an appropriate empty aggregation.
- createUnmapped(Aggregator, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
-
Create the Aggregator for a
ValuesSource
that doesn't have values. - createUsingParamsFrom(TDigestState) - Static method in class org.elasticsearch.search.aggregations.metrics.TDigestState
-
Factory for TDigestState.
- createUUIDBasedBlock(ClusterBlock) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexStateService
- createValuesSource(BigArrays, IndexReader, int, LongConsumer, CompositeValuesSourceConfig) - Method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceConfig.SingleDimensionValuesSourceProvider
- createVerifyingOutput(String, StoreFileMetadata, IOContext) - Method in class org.elasticsearch.index.store.Store
-
The returned IndexOutput validates the files checksum.
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.lucene.queries.BinaryDocValuesRangeQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.lucene.queries.MinDocQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.lucene.queries.SearchAfterSortedDocQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.lucene.queries.SpanMatchNoDocsQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.lucene.spatial.CartesianShapeDocValuesQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.aggregations.bucket.filter.MergedPointRangeQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.random.RandomSamplingQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.retriever.rankdoc.RankDocsQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.retriever.rankdoc.RankDocsQuery.TopQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.runtime.AbstractScriptFieldQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.runtime.GeoPointScriptFieldDistanceFeatureQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.runtime.LongScriptFieldDistanceFeatureQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.slice.DocIdSliceQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.slice.DocValuesSliceQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.slice.TermsSliceQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.vectors.DenseVectorQuery.Bytes
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.vectors.DenseVectorQuery.Floats
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.vectors.KnnScoreDocQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.search.vectors.VectorSimilarityQuery
- createWeight(Query, ScoreMode, float) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- createWithBounds() - Method in class org.elasticsearch.common.geo.BoundingBox.BoundsParser
- createWithBounds() - Method in class org.elasticsearch.common.geo.GeoBoundingBox.GeoBoundsParser
- createWithEnvelope() - Method in class org.elasticsearch.common.geo.BoundingBox.BoundsParser
- createWithEnvelope() - Method in class org.elasticsearch.common.geo.GeoBoundingBox.GeoBoundsParser
- createWithFilter(String, List<B>, SetBackedScalingCuckooFilter) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
- createWithFilter(String, List<LongRareTerms.Bucket>, SetBackedScalingCuckooFilter) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms
- createWithFilter(String, List<StringRareTerms.Bucket>, SetBackedScalingCuckooFilter) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms
- createWithFilter(String, List<UnmappedRareTerms.Bucket>, SetBackedScalingCuckooFilter) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- createWithoutCircuitBreaking(double) - Static method in class org.elasticsearch.search.aggregations.metrics.TDigestState
-
Deprecated.No-op circuit-breaked factory for TDigestState. Used in _search aggregations. Please use the
TDigestState.create(CircuitBreaker, double)
method instead on new usages. - createWithoutCircuitBreaking(double, TDigestExecutionHint) - Static method in class org.elasticsearch.search.aggregations.metrics.TDigestState
-
Deprecated.No-op circuit-breaked factory for TDigestState. Used in _search aggregations. Please use the
TDigestState.create(CircuitBreaker, double, TDigestExecutionHint)
method instead on new usages. - createWriteLoadForecasters(ThreadPool, Settings, ClusterSettings) - Method in interface org.elasticsearch.plugins.ClusterPlugin
- createWriter() - Method in class org.elasticsearch.gateway.PersistedClusterStateService
-
Creates a new disk-based writer for cluster states
- createWriter(Directory, IndexWriterConfig) - Method in class org.elasticsearch.index.engine.InternalEngine
- creationDate(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- CreationException - Exception in org.elasticsearch.injection.guice
-
Thrown when errors occur while creating a
Injector
. - CreationException(Collection<Message>) - Constructor for exception org.elasticsearch.injection.guice.CreationException
-
Creates a CreationException containing
messages
. - credentials() - Method in record class org.elasticsearch.transport.RemoteConnectionManager.RemoteClusterAliasWithCredentials
-
Returns the value of the
credentials
record component. - critical(DeprecationCategory, String, String, Object...) - Method in class org.elasticsearch.common.logging.DeprecationLogger
-
Logs a message at the
DeprecationLogger.CRITICAL
level. - CRITICAL - Static variable in class org.elasticsearch.common.logging.DeprecationLogger
-
Deprecation messages are logged at this level.
- CRITICAL_SYSTEM_INDEX_THREAD_POOLS - Static variable in record class org.elasticsearch.indices.ExecutorNames
-
The thread pools that should be used for critical system index operations.
- CROSS_FIELDS - Enum constant in enum class org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Uses a blended DocumentFrequency to dynamically combine the queried fields into a single field given the configured analysis is identical.
- CROSSES - Enum constant in enum class org.elasticsearch.lucene.queries.BinaryDocValuesRangeQuery.QueryType
- crossesDateline() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileBoundedPredicate
-
Does the provided bounds crosses the dateline
- CS_MISSING_MSG - Static variable in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- CTRL_CLOSE_EVENT - Static variable in interface org.elasticsearch.bootstrap.ConsoleCtrlHandler
- CTRLHANDLER_SETTING - Static variable in class org.elasticsearch.bootstrap.BootstrapSettings
- CTX - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- ctxMap - Variable in class org.elasticsearch.script.WriteScript
- CtxMap<T extends Metadata> - Class in org.elasticsearch.script
-
A scripting ctx map with metadata for write ingest contexts.
- CtxMap(Map<String, Object>, T) - Constructor for class org.elasticsearch.script.CtxMap
-
Create CtxMap from a source and metadata
- CuckooFilter - Class in org.elasticsearch.common.util
-
An approximate set membership datastructure CuckooFilters are similar to Bloom Filters in usage; values are inserted, and the Cuckoo can be asked if it has seen a particular value before.
- cumulativeComputationTime - Variable in class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceShardsAllocator
- cumulativeComputationTime() - Method in record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceStats
-
Returns the value of the
cumulativeComputationTime
record component. - cumulativeReconciliationTime - Variable in class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceShardsAllocator
- cumulativeReconciliationTime() - Method in record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceStats
-
Returns the value of the
cumulativeReconciliationTime
record component. - CumulativeSumPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- CumulativeSumPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
- CumulativeSumPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
-
Read from a stream.
- CumulativeSumPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- curBucket - Variable in class org.elasticsearch.script.TimeSeriesCounter.Counter
- current - Variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- current() - Method in record class org.elasticsearch.action.admin.cluster.allocation.DesiredBalanceResponse.DesiredShards
-
Returns the value of the
current
record component. - current() - Static method in record class org.elasticsearch.Build
- current() - Method in record class org.elasticsearch.common.settings.RotatableSecret.Secrets
-
Returns the value of the
current
record component. - current() - Static method in class org.elasticsearch.env.BuildVersion
-
Get the current build version.
- current() - Method in class org.elasticsearch.index.get.GetStats
- current() - Static method in record class org.elasticsearch.index.IndexVersion
-
Returns the most recent index version.
- current() - Method in class org.elasticsearch.index.warmer.WarmerStats
- current() - Method in class org.elasticsearch.lucene.search.uhighlight.BoundedBreakIteratorScanner
- current() - Method in class org.elasticsearch.search.aggregations.bucket.IteratorAndCurrent
- current() - Static method in record class org.elasticsearch.TransportVersion
-
Reference to the most recent transport version.
- CURRENT - Static variable in record class org.elasticsearch.cluster.node.VersionInformation
- CURRENT - Static variable in class org.elasticsearch.Version
- CURRENT_SNAPSHOT - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- CURRENT_VERSION - Static variable in class org.elasticsearch.common.settings.KeyStoreWrapper
- currentActiveShards() - Method in record class org.elasticsearch.action.support.ActiveShardCount.EnoughShards
-
Returns the value of the
currentActiveShards
record component. - currentAsSource() - Method in class org.elasticsearch.index.recovery.RecoveryStats
-
Number of ongoing recoveries for which a shard serves as a source
- currentAsTarget() - Method in class org.elasticsearch.index.recovery.RecoveryStats
-
Number of ongoing recoveries for which a shard serves as a target
- currentBuildVersion() - Method in interface org.elasticsearch.internal.BuildExtension
-
Returns the
BuildVersion
for the running Elasticsearch code. - currentDiskUsage() - Method in record class org.elasticsearch.cluster.routing.allocation.NodeAllocationStats
-
Returns the value of the
currentDiskUsage
record component. - currentDocFreq - Variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- currentFileGeneration() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the generation of the current transaction log.
- CURRENTLY_SUPPORTED - Static variable in enum class org.elasticsearch.action.search.SearchType
-
Non-deprecated types
- currentMaster() - Method in record class org.elasticsearch.cluster.coordination.CoordinationDiagnosticsService.CoordinationDiagnosticsDetails
-
Returns the value of the
currentMaster
record component. - currentNanoTime() - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
override this to control time based decisions during allocation
- currentNanoTime() - Method in class org.elasticsearch.cluster.routing.DelayedAllocationService
-
override this to control time based decisions during delayed allocation
- currentNodeId() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The current node id the shard is allocated on.
- currentNumberOfShards() - Method in record class org.elasticsearch.action.datastreams.autosharding.AutoShardingResult
-
Returns the value of the
currentNumberOfShards
record component. - currentOrdinal() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns the current ordinal or
0
if this build has not been advanced viaOrdinalsBuilder.nextOrdinal()
. - currentSnapshots(SnapshotsInProgress, String, List<String>) - Static method in class org.elasticsearch.snapshots.SnapshotsService
-
Returns status of the currently running snapshots
- currentSnapshotShards(Snapshot) - Method in class org.elasticsearch.snapshots.SnapshotShardsService
-
Returns status of shards that are snapshotted on the node and belong to the given snapshot
- currentState() - Method in exception org.elasticsearch.index.shard.IllegalIndexShardStateException
- currentTerm - Variable in class org.elasticsearch.gateway.PersistedClusterStateService.OnDiskState
- currentTerm() - Method in record class org.elasticsearch.cluster.coordination.ClusterFormationFailureHelper.ClusterFormationState
-
Returns the value of the
currentTerm
record component. - currentTerm() - Method in record class org.elasticsearch.cluster.metadata.Manifest
-
Returns the value of the
currentTerm
record component. - currentTerm() - Method in record class org.elasticsearch.gateway.PersistedClusterStateService.OnDiskStateMetadata
-
Returns the value of the
currentTerm
record component. - currentTotalTermFreq - Variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- currentUsedShards() - Method in record class org.elasticsearch.indices.ShardLimitValidator.Result
-
Returns the value of the
currentUsedShards
record component. - Cursor() - Constructor for class org.elasticsearch.common.util.LongObjectPagedHashMap.Cursor
- Cursor() - Constructor for class org.elasticsearch.common.util.ObjectObjectPagedHashMap.Cursor
- custom(String) - Method in class org.elasticsearch.cluster.ClusterState
- custom(String) - Method in class org.elasticsearch.cluster.metadata.Metadata
- custom(String, T) - Method in class org.elasticsearch.cluster.ClusterState
- custom(String, T) - Method in class org.elasticsearch.cluster.metadata.Metadata
- CustomAnalyzer - Class in org.elasticsearch.index.analysis
- CustomAnalyzer(TokenizerFactory, CharFilterFactory[], TokenFilterFactory[]) - Constructor for class org.elasticsearch.index.analysis.CustomAnalyzer
- CustomAnalyzer(TokenizerFactory, CharFilterFactory[], TokenFilterFactory[], int, int) - Constructor for class org.elasticsearch.index.analysis.CustomAnalyzer
- CustomAnalyzerProvider - Class in org.elasticsearch.index.analysis
-
A custom analyzer that is built out of a single
Tokenizer
and a list ofTokenFilter
s. - CustomAnalyzerProvider(IndexSettings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CustomAnalyzerProvider
- CustomBinaryDocValuesField(String, byte[]) - Constructor for class org.elasticsearch.index.mapper.BinaryFieldMapper.CustomBinaryDocValuesField
- customDataPath - Variable in class org.elasticsearch.gateway.AsyncShardFetch
- customDataPath() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the customDataPath for this index, if configured.
- CustomDocValuesField - Class in org.elasticsearch.index.mapper
- CustomDocValuesField(String) - Constructor for class org.elasticsearch.index.mapper.CustomDocValuesField
- CustomFieldQuery - Class in org.elasticsearch.lucene.search.vectorhighlight
- CustomFieldQuery(Query, IndexReader, boolean, boolean) - Constructor for class org.elasticsearch.lucene.search.vectorhighlight.CustomFieldQuery
- CustomFieldQuery(Query, IndexReader, FastVectorHighlighter) - Constructor for class org.elasticsearch.lucene.search.vectorhighlight.CustomFieldQuery
- CustomFieldsVisitor - Class in org.elasticsearch.index.fieldvisitor
-
A field visitor that allows to load a selection of the stored fields by exact name.
- CustomFieldsVisitor(Set<String>, boolean) - Constructor for class org.elasticsearch.index.fieldvisitor.CustomFieldsVisitor
- CustomMapFieldsConverter - Class in org.elasticsearch.common.logging
-
Pattern converter to populate CustomMapFields in a pattern.
- CustomMapFieldsConverter() - Constructor for class org.elasticsearch.common.logging.CustomMapFieldsConverter
- CustomNormalizerProvider - Class in org.elasticsearch.index.analysis
-
A custom normalizer that is built out of a char and token filters.
- CustomNormalizerProvider(IndexSettings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CustomNormalizerProvider
- CustomPassageFormatter - Class in org.elasticsearch.lucene.search.uhighlight
-
Custom passage formatter that allows us to: 1) extract different snippets (instead of a single big string) together with their scores (
Snippet
) 2) use theEncoder
implementations that are already used with the other highlighters - CustomPassageFormatter(String, String, Encoder, int) - Constructor for class org.elasticsearch.lucene.search.uhighlight.CustomPassageFormatter
- CustomQueryScorer - Class in org.elasticsearch.search.fetch.subphase.highlight
- CustomQueryScorer(Query) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.CustomQueryScorer
- CustomQueryScorer(Query, String) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.CustomQueryScorer
- customs() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- customs() - Method in class org.elasticsearch.cluster.ClusterState
- customs() - Method in class org.elasticsearch.cluster.metadata.Metadata
- customs(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- customs(Map<String, ClusterState.Custom>) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- customs(Map<String, Metadata.Custom>) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- CUSTOMS - Enum constant in enum class org.elasticsearch.cluster.ClusterState.Metric
- CustomTermFreqField - Class in org.elasticsearch.index.mapper
-
Custom field that allows storing an integer value as a term frequency in lucene.
- CustomTermFreqField(String, CharSequence, int) - Constructor for class org.elasticsearch.index.mapper.CustomTermFreqField
- CustomUnifiedHighlighter - Class in org.elasticsearch.lucene.search.uhighlight
-
Subclass of the
UnifiedHighlighter
that works for a single field in a single document. - CustomUnifiedHighlighter(UnifiedHighlighter.Builder, UnifiedHighlighter.OffsetSource, Locale, String, String, Query, int, int, int, Integer, boolean, boolean) - Constructor for class org.elasticsearch.lucene.search.uhighlight.CustomUnifiedHighlighter
-
Creates a new instance of
CustomUnifiedHighlighter
- customXContentChunks(ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentResponse
- customXContentChunks(ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsResponse
- customXContentChunks(ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- customXContentChunks(ToXContent.Params) - Method in class org.elasticsearch.action.support.broadcast.ChunkedBroadcastResponse
- CUTOFF_FREQUENCY_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- cutoffScore - Variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- CW - Static variable in enum class org.elasticsearch.common.geo.Orientation
D
- daemonize() - Method in record class org.elasticsearch.bootstrap.ServerArgs
-
Returns the value of the
daemonize
record component. - daemonThreadFactory(String) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- daemonThreadFactory(String, String) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- daemonThreadFactory(String, String, boolean) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- daemonThreadFactory(Settings, String) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- DAMERAU_LEVENSHTEIN - Enum constant in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
String distance algorithm based on Damerau-Levenshtein algorithm.
- DANGLING_INDEX_IMPORTED - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of importing a dangling index.
- DanglingIndexInfo - Class in org.elasticsearch.action.admin.indices.dangling
-
Contains information about a dangling index, i.e.
- DanglingIndexInfo(String, String, String, long) - Constructor for class org.elasticsearch.action.admin.indices.dangling.DanglingIndexInfo
- DanglingIndexInfo(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.dangling.DanglingIndexInfo
- DanglingIndicesState - Class in org.elasticsearch.gateway
-
The dangling indices state is responsible for finding new dangling indices (indices that have their state written on disk, but don't exists in the metadata of the cluster).
- DanglingIndicesState(MetaStateService, ClusterService) - Constructor for class org.elasticsearch.gateway.DanglingIndicesState
- DATA - Enum constant in enum class org.elasticsearch.action.support.IndexComponentSelector
- DATA - Static variable in record class org.elasticsearch.action.support.IndicesOptions.SelectorOptions
- DATA_COLD - Static variable in class org.elasticsearch.cluster.routing.allocation.DataTier
- DATA_COLD_NODE_ROLE - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
Represents the role for a cold node.
- DATA_CONTENT - Static variable in class org.elasticsearch.cluster.routing.allocation.DataTier
- DATA_CONTENT_NODE_ROLE - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
Represents the role for a content node.
- DATA_FROZEN - Static variable in class org.elasticsearch.cluster.routing.allocation.DataTier
- DATA_FROZEN_NODE_ROLE - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
Represents the role for a frozen node.
- DATA_HOT - Static variable in class org.elasticsearch.cluster.routing.allocation.DataTier
- DATA_HOT_NODE_ROLE - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
Represents the role for a hot node.
- DATA_PATH_NEW_KEY_VERSION - Static variable in class org.elasticsearch.cluster.ClusterInfo
- DATA_RETENTION_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStreamLifecycle
- DATA_ROLE - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
Represents the role for a data node.
- DATA_SET_SIZE_SIZE_VERSION - Static variable in class org.elasticsearch.cluster.ClusterInfo
- DATA_STREAM - Enum constant in enum class org.elasticsearch.cluster.metadata.IndexAbstraction.Type
-
An index abstraction that refers to a data stream.
- DATA_STREAM_AUTO_SHARDING_FEATURE - Static variable in class org.elasticsearch.action.datastreams.autosharding.DataStreamAutoShardingService
- DATA_STREAM_CONFIGURATION - Enum constant in enum class org.elasticsearch.cluster.metadata.DataStreamLifecycle.RetentionSource
- DATA_STREAM_FAILURE_STORE_MAPPING - Static variable in class org.elasticsearch.cluster.metadata.DataStreamFailureStoreDefinition
- DATA_STREAM_FAILURE_STORE_SETTINGS - Static variable in class org.elasticsearch.cluster.metadata.DataStreamFailureStoreDefinition
- DATA_STREAM_INDEX_VERSION_DEPRECATION_CHECK - Static variable in class org.elasticsearch.TransportVersions
- DATA_STREAM_LAZY_ROLLOVER - Static variable in class org.elasticsearch.action.admin.indices.rollover.LazyRolloverAction
- DATA_STREAM_LIFECYCLE_ORIGIN - Static variable in class org.elasticsearch.cluster.metadata.DataStreamLifecycle
- DATA_STREAM_MAPPING_SNIPPET - Static variable in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
-
A mapping snippet for a backing index with `_data_stream_timestamp` meta field mapper properly configured.
- DATA_STREAM_OPTIONS_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- DATA_STREAMS_AUTO_SHARDING_DECREASE_SHARDS_COOLDOWN - Static variable in class org.elasticsearch.action.datastreams.autosharding.DataStreamAutoShardingService
-
Represents the minimum amount of time between two scaling events if the next event will reduce the number of shards.
- DATA_STREAMS_AUTO_SHARDING_ENABLED - Static variable in class org.elasticsearch.action.datastreams.autosharding.DataStreamAutoShardingService
- DATA_STREAMS_AUTO_SHARDING_EXCLUDES_SETTING - Static variable in class org.elasticsearch.action.datastreams.autosharding.DataStreamAutoShardingService
- DATA_STREAMS_AUTO_SHARDING_INCREASE_SHARDS_COOLDOWN - Static variable in class org.elasticsearch.action.datastreams.autosharding.DataStreamAutoShardingService
-
Represents the minimum amount of time between two scaling events if the next event will increase the number of shards.
- DATA_STREAMS_DEFAULT_RETENTION_SETTING - Static variable in class org.elasticsearch.cluster.metadata.DataStreamGlobalRetentionSettings
- DATA_STREAMS_FIELD - Static variable in class org.elasticsearch.action.datastreams.GetDataStreamAction.Response
- DATA_STREAMS_FIELD - Static variable in class org.elasticsearch.action.datastreams.lifecycle.GetDataStreamLifecycleAction.Response
- DATA_STREAMS_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStreamAlias
- DATA_STREAMS_LIFECYCLE_ONLY_SETTING_NAME - Static variable in class org.elasticsearch.cluster.metadata.DataStreamLifecycle
- DATA_STREAMS_MAX_RETENTION_SETTING - Static variable in class org.elasticsearch.cluster.metadata.DataStreamGlobalRetentionSettings
- DATA_WARM - Static variable in class org.elasticsearch.cluster.routing.allocation.DataTier
- DATA_WARM_NODE_ROLE - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
Represents the role for a warm node.
- dataFiles() - Method in class org.elasticsearch.env.Environment
-
The data location.
- DataOutputStreamOutput - Class in org.elasticsearch.common.io.stream
- DataOutputStreamOutput(DataOutput) - Constructor for class org.elasticsearch.common.io.stream.DataOutputStreamOutput
- DataPath(Path) - Constructor for class org.elasticsearch.env.NodeEnvironment.DataPath
- dataPaths() - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns an array of all of the
NodeEnvironment.DataPath
s. - dataPathUsesList(Settings) - Static method in class org.elasticsearch.env.Environment
-
Returns true if the data path is a list, false otherwise
- dataRetention(long) - Method in class org.elasticsearch.cluster.metadata.DataStreamLifecycle.Builder
- dataRetention(DataStreamLifecycle.Retention) - Method in class org.elasticsearch.cluster.metadata.DataStreamLifecycle.Builder
- dataRetention(TimeValue) - Method in class org.elasticsearch.cluster.metadata.DataStreamLifecycle.Builder
- DataRewriteContext - Class in org.elasticsearch.index.query
-
Context object used to rewrite
QueryBuilder
instances into simplified version on the datanode where the request is going to be executed. - DataRewriteContext(XContentParserConfiguration, Client, LongSupplier) - Constructor for class org.elasticsearch.index.query.DataRewriteContext
- dataStream(String) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- DataStream - Class in org.elasticsearch.cluster.metadata
- DataStream(String, List<Index>, long, Map<String, Object>, boolean, boolean, boolean, boolean, IndexMode, DataStreamLifecycle, DataStreamOptions, List<Index>, boolean, DataStreamAutoShardingEvent) - Constructor for class org.elasticsearch.cluster.metadata.DataStream
- DataStream.Builder - Class in org.elasticsearch.cluster.metadata
- DataStream.DataStreamIndices - Class in org.elasticsearch.cluster.metadata
- DataStream.DataStreamIndices.Builder - Class in org.elasticsearch.cluster.metadata
- DataStream.TimestampError - Exception in org.elasticsearch.cluster.metadata
-
This is a specialised error to capture that a document does not have a valid timestamp to index a document.
- dataStreamAccessException(ThreadContext, Collection<String>) - Static method in class org.elasticsearch.indices.SystemIndices
- DataStreamAction - Class in org.elasticsearch.cluster.metadata
-
Operations on data streams.
- DataStreamAction(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.DataStreamAction
- DataStreamAction.Type - Enum Class in org.elasticsearch.cluster.metadata
- DataStreamAlias - Class in org.elasticsearch.cluster.metadata
- DataStreamAlias(String, List<String>, String, Map<String, Map<String, Object>>) - Constructor for class org.elasticsearch.cluster.metadata.DataStreamAlias
- DataStreamAlias(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.DataStreamAlias
- dataStreamAliases() - Method in class org.elasticsearch.cluster.metadata.Metadata
- dataStreamAliasesByDataStream() - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Return a map of DataStreamAlias objects by DataStream name
- DataStreamAutoShardingEvent - Record Class in org.elasticsearch.cluster.metadata
-
Represents the last auto sharding event that occured for a data stream.
- DataStreamAutoShardingEvent(String, int, long) - Constructor for record class org.elasticsearch.cluster.metadata.DataStreamAutoShardingEvent
-
Creates an instance of a
DataStreamAutoShardingEvent
record class. - DataStreamAutoShardingService - Class in org.elasticsearch.action.datastreams.autosharding
-
Calculates the optimal number of shards the data stream write index should have based on the indexing load.
- DataStreamAutoShardingService(Settings, ClusterService, FeatureService, LongSupplier) - Constructor for class org.elasticsearch.action.datastreams.autosharding.DataStreamAutoShardingService
- DataStreamFailureStore - Record Class in org.elasticsearch.cluster.metadata
-
Holds the data stream failure store metadata that enable or disable the failure store of a data stream.
- DataStreamFailureStore(Boolean) - Constructor for record class org.elasticsearch.cluster.metadata.DataStreamFailureStore
-
Creates an instance of a
DataStreamFailureStore
record class. - DataStreamFailureStore(StreamInput) - Constructor for record class org.elasticsearch.cluster.metadata.DataStreamFailureStore
- DataStreamFailureStoreDefinition - Class in org.elasticsearch.cluster.metadata
-
A utility class that contains the mappings and settings logic for failure store indices that are a part of data streams.
- DataStreamFailureStoreDefinition() - Constructor for class org.elasticsearch.cluster.metadata.DataStreamFailureStoreDefinition
- DataStreamGlobalRetention - Record Class in org.elasticsearch.cluster.metadata
-
Wrapper class for the
DataStreamGlobalRetentionSettings
. - DataStreamGlobalRetention(TimeValue, TimeValue) - Constructor for record class org.elasticsearch.cluster.metadata.DataStreamGlobalRetention
-
Creates an instance of a
DataStreamGlobalRetention
record class. - dataStreamGlobalRetentionSettings() - Method in record class org.elasticsearch.node.PluginServiceInstances
-
Returns the value of the
dataStreamGlobalRetentionSettings
record component. - dataStreamGlobalRetentionSettings() - Method in interface org.elasticsearch.plugins.Plugin.PluginServices
-
A service that holds the data stream global retention settings that applies to data streams managed by the data stream lifecycle.
- DataStreamGlobalRetentionSettings - Class in org.elasticsearch.cluster.metadata
-
This class holds the data stream global retention settings.
- DataStreamIndices(String, List<Index>, boolean, DataStreamAutoShardingEvent) - Constructor for class org.elasticsearch.cluster.metadata.DataStream.DataStreamIndices
- DataStreamInfo(DataStream, ClusterHealthStatus, String, String, GetDataStreamAction.Response.TimeSeries, Map<Index, GetDataStreamAction.Response.IndexProperties>, boolean, Long) - Constructor for class org.elasticsearch.action.datastreams.GetDataStreamAction.Response.DataStreamInfo
- DataStreamLifecycle - Class in org.elasticsearch.cluster.metadata
-
Holds the data stream lifecycle metadata that are configuring how a data stream is managed.
- DataStreamLifecycle() - Constructor for class org.elasticsearch.cluster.metadata.DataStreamLifecycle
- DataStreamLifecycle(String, DataStreamLifecycle, boolean) - Constructor for record class org.elasticsearch.action.datastreams.lifecycle.GetDataStreamLifecycleAction.Response.DataStreamLifecycle
-
Creates an instance of a
DataStreamLifecycle
record class. - DataStreamLifecycle(DataStreamLifecycle.Retention, DataStreamLifecycle.Downsampling, Boolean) - Constructor for class org.elasticsearch.cluster.metadata.DataStreamLifecycle
- DataStreamLifecycle(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.DataStreamLifecycle
- DataStreamLifecycle.Builder - Class in org.elasticsearch.cluster.metadata
-
This builder helps during the composition of the data stream lifecycle templates.
- DataStreamLifecycle.Downsampling - Record Class in org.elasticsearch.cluster.metadata
-
Downsampling holds the configuration about when should elasticsearch downsample a backing index.
- DataStreamLifecycle.Downsampling.Round - Record Class in org.elasticsearch.cluster.metadata
-
A round represents the configuration for when and how elasticsearch will downsample a backing index.
- DataStreamLifecycle.Retention - Record Class in org.elasticsearch.cluster.metadata
-
Retention is the least amount of time that the data will be kept by elasticsearch.
- DataStreamLifecycle.RetentionSource - Enum Class in org.elasticsearch.cluster.metadata
-
This enum represents all configuration sources that can influence the retention of a data stream.
- DataStreamLifecycleHealthInfo - Record Class in org.elasticsearch.health.node
-
Represents the data stream lifecycle information that would help shape the functionality's health.
- DataStreamLifecycleHealthInfo(List<DslErrorInfo>, int) - Constructor for record class org.elasticsearch.health.node.DataStreamLifecycleHealthInfo
-
Creates an instance of a
DataStreamLifecycleHealthInfo
record class. - DataStreamLifecycleHealthInfo(StreamInput) - Constructor for record class org.elasticsearch.health.node.DataStreamLifecycleHealthInfo
- dataStreamMetadata() - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- DataStreamMetadata - Class in org.elasticsearch.cluster.metadata
-
Custom
Metadata
implementation for storing a map ofDataStream
s and their names. - DataStreamMetadata(ImmutableOpenMap<String, DataStream>, ImmutableOpenMap<String, DataStreamAlias>) - Constructor for class org.elasticsearch.cluster.metadata.DataStreamMetadata
- DataStreamMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.DataStreamMetadata
- dataStreamName() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
Returns the name of the data stream this new index will be part of.
- dataStreamName() - Method in record class org.elasticsearch.action.datastreams.lifecycle.GetDataStreamLifecycleAction.Response.DataStreamLifecycle
-
Returns the value of the
dataStreamName
record component. - dataStreamName(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- dataStreamNames(ClusterState, IndicesOptions, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- DataStreamOptions - Record Class in org.elasticsearch.cluster.metadata
-
Holds data stream dedicated configuration options such as failure store, (in the future lifecycle).
- DataStreamOptions() - Constructor for record class org.elasticsearch.cluster.metadata.DataStreamOptions
- DataStreamOptions(DataStreamFailureStore) - Constructor for record class org.elasticsearch.cluster.metadata.DataStreamOptions
-
Creates an instance of a
DataStreamOptions
record class. - dataStreams() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- dataStreams() - Method in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- dataStreams() - Method in class org.elasticsearch.cluster.metadata.Metadata
- dataStreams() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- dataStreams() - Method in class org.elasticsearch.snapshots.SnapshotInfo
- dataStreams(Map<String, DataStream>, Map<String, DataStreamAlias>) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- DataStreamsActionUtil - Class in org.elasticsearch.action.datastreams
- DataStreamsActionUtil() - Constructor for class org.elasticsearch.action.datastreams.DataStreamsActionUtil
- DataStreamShardStats(ShardRouting, StoreStats, long) - Constructor for class org.elasticsearch.action.datastreams.DataStreamsStatsAction.DataStreamShardStats
- DataStreamShardStats(StreamInput) - Constructor for class org.elasticsearch.action.datastreams.DataStreamsStatsAction.DataStreamShardStats
- DataStreamsStatsAction - Class in org.elasticsearch.action.datastreams
- DataStreamsStatsAction() - Constructor for class org.elasticsearch.action.datastreams.DataStreamsStatsAction
- DataStreamsStatsAction.DataStreamShardStats - Class in org.elasticsearch.action.datastreams
- DataStreamsStatsAction.DataStreamStats - Class in org.elasticsearch.action.datastreams
- DataStreamsStatsAction.Request - Class in org.elasticsearch.action.datastreams
- DataStreamsStatsAction.Response - Class in org.elasticsearch.action.datastreams
- DataStreamStats(String, int, ByteSizeValue, long) - Constructor for class org.elasticsearch.action.datastreams.DataStreamsStatsAction.DataStreamStats
- DataStreamStats(StreamInput) - Constructor for class org.elasticsearch.action.datastreams.DataStreamsStatsAction.DataStreamStats
- dataStreamTemplate(ComposableIndexTemplate.DataStreamTemplate) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.Builder
- DataStreamTemplate() - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- DataStreamTemplate(boolean, boolean) - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- DataStreamTemplate(boolean, boolean, boolean) - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- DataStreamTimestampFieldMapper - Class in org.elasticsearch.index.mapper
-
FieldMapper for the data-stream's timestamp meta-field.
- DataStreamTimestampFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- DataStreamTimestampFieldMapper.TimestampFieldType - Class in org.elasticsearch.index.mapper
- DataTier - Class in org.elasticsearch.cluster.routing.allocation
-
The
DataTier
class encapsulates the formalization of the "content", "hot", "warm", and "cold" tiers as node roles. - DataTier() - Constructor for class org.elasticsearch.cluster.routing.allocation.DataTier
- DataTier.DefaultHotAllocationSettingProvider - Class in org.elasticsearch.cluster.routing.allocation
-
This setting provider injects the setting allocating all newly created indices with
index.routing.allocation.include._tier_preference: "data_hot"
for a data stream index orindex.routing.allocation.include._tier_preference: "data_content"
for an index not part of a data stream unless the user overrides the setting while the index is being created (in a create index request for instance) - date() - Method in record class org.elasticsearch.Build
-
Returns the value of the
date
record component. - DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- DATE - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- DATE - Enum constant in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- DATE - Enum constant in enum class org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- DATE - Enum constant in enum class org.elasticsearch.index.mapper.RangeType
- DATE - Enum constant in enum class org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- DATE - Enum constant in enum class org.elasticsearch.search.aggregations.support.ValueType
-
Deprecated.
- DATE - Static variable in class org.elasticsearch.http.CorsHandler
- DATE_DETECTION - Static variable in class org.elasticsearch.index.mapper.RootObjectMapper.Defaults
- DATE_FIELD_UNITS - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- DATE_FORMATTER - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- DATE_FORMATTER - Static variable in class org.elasticsearch.index.mapper.RangeFieldMapper.Defaults
- DATE_HOUR - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- DATE_HOUR - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- DATE_HOUR_MINUTE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- DATE_HOUR_MINUTE - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- DATE_HOUR_MINUTE_SECOND - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- DATE_HOUR_MINUTE_SECOND - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- DATE_HOUR_MINUTE_SECOND_FRACTION - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- DATE_HOUR_MINUTE_SECOND_FRACTION - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- DATE_HOUR_MINUTE_SECOND_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- DATE_HOUR_MINUTE_SECOND_MILLIS - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- DATE_NANOS_CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.DateFieldMapper
- DATE_NANOSECONDS - Enum constant in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- DATE_OPTIONAL_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- DATE_OPTIONAL_TIME - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- DATE_RANGE_INDEXING_FIX - Static variable in class org.elasticsearch.index.mapper.RangeFieldMapper
- DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- DATE_TIME_DOC_VALUES_LOCALES - Static variable in class org.elasticsearch.TransportVersions
- DATE_TIME_FORMATTER - Static variable in record class org.elasticsearch.cluster.routing.UnassignedInfo
- DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.LegacyFormatNames
- dateComparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.IndexNumericFieldData
- dateComparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData
- dateDetection - Variable in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- dateDetection() - Method in class org.elasticsearch.index.mapper.RootObjectMapper
-
Public API
- DateFieldMapper - Class in org.elasticsearch.index.mapper
-
A
FieldMapper
for dates. - DateFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- DateFieldMapper.DateFieldType - Class in org.elasticsearch.index.mapper
- DateFieldMapper.Resolution - Enum Class in org.elasticsearch.index.mapper
- DateFieldRangeInfo - Record Class in org.elasticsearch.indices
-
Data holder of timestamp fields held in cluster state IndexMetadata.
- DateFieldRangeInfo(DateFieldMapper.DateFieldType, IndexLongFieldRange, DateFieldMapper.DateFieldType, IndexLongFieldRange) - Constructor for record class org.elasticsearch.indices.DateFieldRangeInfo
-
Creates an instance of a
DateFieldRangeInfo
record class. - DateFieldScript - Class in org.elasticsearch.script
- DateFieldScript(String, Map<String, Object>, SearchLookup, DateFormatter, OnScriptError, LeafReaderContext) - Constructor for class org.elasticsearch.script.DateFieldScript
- DateFieldScript.Emit - Class in org.elasticsearch.script
- DateFieldScript.Factory - Interface in org.elasticsearch.script
- DateFieldScript.LeafFactory - Interface in org.elasticsearch.script
- DateFieldScript.Parse - Class in org.elasticsearch.script
-
Temporary parse method that takes into account the date format.
- DateFieldType(String) - Constructor for class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- DateFieldType(String, boolean) - Constructor for class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- DateFieldType(String, boolean, boolean, boolean, boolean, DateFormatter, DateFieldMapper.Resolution, String, FieldValues<Long>, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- DateFieldType(String, boolean, boolean, boolean, DateFormatter, DateFieldMapper.Resolution, String, FieldValues<Long>, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- DateFieldType(String, DateFormatter) - Constructor for class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- DateFieldType(String, DateFieldMapper.Resolution) - Constructor for class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- DateFieldType(String, DateFieldMapper.Resolution, DateFormatter) - Constructor for class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- DateFormatter - Interface in org.elasticsearch.common.time
- DateFormatters - Class in org.elasticsearch.common.time
- DateFormatters() - Constructor for class org.elasticsearch.common.time.DateFormatters
- dateHistogram(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
DateHistogramAggregationBuilder
aggregation with the given name. - DateHistogramAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
A builder for histograms on date fields.
- DateHistogramAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Create a new builder with the given name.
- DateHistogramAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Read from a stream, for internal use only.
- DateHistogramAggregationBuilder(DateHistogramAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- DateHistogramAggregationSupplier - Interface in org.elasticsearch.search.aggregations.bucket.histogram
- DateHistogramAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.histogram
- DateHistogramAggregatorFactory(String, ValuesSourceConfig, BucketOrder, boolean, long, boolean, Rounding, LongBounds, LongBounds, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>, DateHistogramAggregationSupplier) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregatorFactory
- DateHistogramInterval - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
The interval the date histogram is based on.
- DateHistogramInterval(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- DateHistogramInterval(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
-
Read from a stream.
- DateHistogramValuesSource - Class in org.elasticsearch.search.aggregations.bucket.composite
-
A
SingleDimensionValuesSource
for date histogram values. - DateHistogramValuesSourceBuilder - Class in org.elasticsearch.search.aggregations.bucket.composite
-
A
CompositeValuesSourceBuilder
that builds aRoundingValuesSource
from aScript
or a field name using the provided interval. - DateHistogramValuesSourceBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- DateHistogramValuesSourceBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- DateHistogramValuesSourceBuilder.DateHistogramCompositeSupplier - Interface in org.elasticsearch.search.aggregations.bucket.composite
- DateIntervalConsumer<T> - Interface in org.elasticsearch.search.aggregations.bucket.histogram
-
A shared interface for aggregations that parse and use "interval" parameters.
- DateIntervalWrapper - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
A class that handles all the parsing, bwc and deprecations surrounding date histogram intervals.
- DateIntervalWrapper() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- DateIntervalWrapper(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- DateIntervalWrapper.IntervalTypeEnum - Enum Class in org.elasticsearch.search.aggregations.bucket.histogram
- dateMathExpressionResolverAt() - Static method in class org.elasticsearch.index.IndexService
- dateMathExpressionResolverAt(long) - Static method in class org.elasticsearch.index.IndexService
- dateMathParser - Variable in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- dateMathParser() - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- dateMathParser() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- DateMathParser - Interface in org.elasticsearch.common.time
-
An abstraction over date math parsing.
- DateMillisDocValuesField - Class in org.elasticsearch.script.field
- DateMillisDocValuesField(SortedNumericDocValues, String) - Constructor for class org.elasticsearch.script.field.DateMillisDocValuesField
- dateNanosComparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.IndexNumericFieldData
- dateNanosComparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData
- DateNanosDocValuesField - Class in org.elasticsearch.script.field
- DateNanosDocValuesField(SortedNumericDocValues, String) - Constructor for class org.elasticsearch.script.field.DateNanosDocValuesField
- dateRange(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
DateRangeAggregationBuilder
aggregation with the given name. - DateRangeAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.range
- DateRangeAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- DateRangeAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Read from a stream.
- DateRangeAggregationBuilder(DateRangeAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- DateRangeAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.range
- DateRangeAggregatorFactory(String, ValuesSourceConfig, RangeAggregator.Range[], boolean, InternalRange.Factory<?, ?>, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>, RangeAggregatorSupplier) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregatorFactory
- DateRangeIncludingNowQuery - Class in org.elasticsearch.index.query
-
A simple wrapper class that indicates that the wrapped query has made use of NOW when parsing its datemath.
- DateRangeIncludingNowQuery(Query) - Constructor for class org.elasticsearch.index.query.DateRangeIncludingNowQuery
- dateRangeQuery(Object, Object, boolean, boolean, ZoneId, DateMathParser, SearchExecutionContext, DateFieldMapper.Resolution, BiFunction<Long, Long, Query>) - Static method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- Dates(ScriptDocValues.Supplier<ZonedDateTime>) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Dates
- DateScriptBlockDocValuesReader - Class in org.elasticsearch.index.mapper
-
BlockDocValuesReader
implementation for date scripts. - DateScriptFieldData - Class in org.elasticsearch.index.fielddata
- DateScriptFieldData.Builder - Class in org.elasticsearch.index.fielddata
- DateScriptFieldData.DateScriptLeafFieldData - Class in org.elasticsearch.index.fielddata
- DateScriptFieldType - Class in org.elasticsearch.index.mapper
- dateSetting(String, Instant, Setting.Validator<Instant>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- DateTime(DateFormatter, ZoneId, DateFieldMapper.Resolution) - Constructor for class org.elasticsearch.search.DocValueFormat.DateTime
- dateTimeFormatter - Variable in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- dateTimeFormatter() - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- dateTimeFormatter() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- DateUtils - Class in org.elasticsearch.common.time
- DateUtils() - Constructor for class org.elasticsearch.common.time.DateUtils
- DAY - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- DAY_OF_MONTH - Enum constant in enum class org.elasticsearch.common.Rounding.DateTimeUnit
- days(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- deactivate() - Method in class org.elasticsearch.index.engine.Engine.IndexThrottle
-
Deactivate throttling, which switches the lock to be an always-acquirable NoOpLock
- deactivate(DiscoveryNode) - Method in class org.elasticsearch.discovery.PeerFinder
- deactivateThrottling() - Method in class org.elasticsearch.index.engine.Engine
-
Reverses a previous
Engine.activateThrottling()
call. - deactivateThrottling() - Method in class org.elasticsearch.index.engine.InternalEngine
- deactivateThrottling() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- deactivateThrottling() - Method in class org.elasticsearch.index.shard.IndexShard
- deactivateThrottling(IndexShard) - Method in class org.elasticsearch.indices.IndexingMemoryController
-
Asks this shard to stop throttling indexing to one thread
- DEB - Enum constant in enum class org.elasticsearch.Build.Type
- debug(String) - Method in class org.elasticsearch.common.logging.internal.LoggerImpl
- debug(String, Object...) - Method in class org.elasticsearch.common.logging.internal.LoggerImpl
- debug(String, Throwable) - Method in class org.elasticsearch.common.logging.internal.LoggerImpl
- debug(Supplier<String>) - Method in class org.elasticsearch.common.logging.internal.LoggerImpl
- debug(Supplier<String>, Throwable) - Method in class org.elasticsearch.common.logging.internal.LoggerImpl
- DEBUG - Enum constant in enum class org.elasticsearch.index.SlowLogLevel
-
Deprecated.
- debugDecision() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- debugDecision(boolean) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- dec() - Method in class org.elasticsearch.common.metrics.CounterMetric
- dec(long) - Method in class org.elasticsearch.common.metrics.CounterMetric
- DECAY - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- decayDateExp(ZonedDateTime) - Method in class org.elasticsearch.script.ScoreScriptUtils.DecayDateExp
- DecayDateExp(String, String, String, double) - Constructor for class org.elasticsearch.script.ScoreScriptUtils.DecayDateExp
- decayDateGauss(ZonedDateTime) - Method in class org.elasticsearch.script.ScoreScriptUtils.DecayDateGauss
- DecayDateGauss(String, String, String, double) - Constructor for class org.elasticsearch.script.ScoreScriptUtils.DecayDateGauss
- decayDateLinear(ZonedDateTime) - Method in class org.elasticsearch.script.ScoreScriptUtils.DecayDateLinear
- DecayDateLinear(String, String, String, double) - Constructor for class org.elasticsearch.script.ScoreScriptUtils.DecayDateLinear
- DecayFunction - Interface in org.elasticsearch.index.query.functionscore
-
Implement this interface to provide a decay function that is executed on a distance.
- DecayFunctionBuilder<DFB extends DecayFunctionBuilder<DFB>> - Class in org.elasticsearch.index.query.functionscore
- DecayFunctionBuilder(String, Object, Object, Object) - Constructor for class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
-
Convenience constructor that converts its parameters into json to parse on the data nodes.
- DecayFunctionBuilder(String, Object, Object, Object, double) - Constructor for class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
-
Convenience constructor that converts its parameters into json to parse on the data nodes.
- DecayFunctionBuilder(String, BytesReference) - Constructor for class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- DecayFunctionBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
-
Read from a stream.
- DecayFunctionBuilder.AbstractDistanceScoreFunction - Class in org.elasticsearch.index.query.functionscore
-
This is the base class for scoring a single field.
- DecayFunctionParser<DFB extends DecayFunctionBuilder<DFB>> - Class in org.elasticsearch.index.query.functionscore
-
Parser used for all decay functions, one instance each.
- DecayFunctionParser(BiFunction<String, BytesReference, DFB>) - Constructor for class org.elasticsearch.index.query.functionscore.DecayFunctionParser
-
Create the parser using a method reference to a "create from bytes" constructor for the DecayFunctionBuilder.
- decayGeoExp(GeoPoint) - Method in class org.elasticsearch.script.ScoreScriptUtils.DecayGeoExp
- DecayGeoExp(String, String, String, double) - Constructor for class org.elasticsearch.script.ScoreScriptUtils.DecayGeoExp
- decayGeoGauss(GeoPoint) - Method in class org.elasticsearch.script.ScoreScriptUtils.DecayGeoGauss
- DecayGeoGauss(String, String, String, double) - Constructor for class org.elasticsearch.script.ScoreScriptUtils.DecayGeoGauss
- decayGeoLinear(GeoPoint) - Method in class org.elasticsearch.script.ScoreScriptUtils.DecayGeoLinear
- DecayGeoLinear(String, String, String, double) - Constructor for class org.elasticsearch.script.ScoreScriptUtils.DecayGeoLinear
- decayNumericExp(double) - Method in class org.elasticsearch.script.ScoreScriptUtils.DecayNumericExp
- DecayNumericExp(double, double, double, double) - Constructor for class org.elasticsearch.script.ScoreScriptUtils.DecayNumericExp
- decayNumericGauss(double) - Method in class org.elasticsearch.script.ScoreScriptUtils.DecayNumericGauss
- DecayNumericGauss(double, double, double, double) - Constructor for class org.elasticsearch.script.ScoreScriptUtils.DecayNumericGauss
- decayNumericLinear(double) - Method in class org.elasticsearch.script.ScoreScriptUtils.DecayNumericLinear
- DecayNumericLinear(double, double, double, double) - Constructor for class org.elasticsearch.script.ScoreScriptUtils.DecayNumericLinear
- decCurrentAsSource() - Method in class org.elasticsearch.index.recovery.RecoveryStats
- decCurrentAsTarget() - Method in class org.elasticsearch.index.recovery.RecoveryStats
- decideMove(ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
-
Makes a decision on whether to move a started shard to another node.
- deciders() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Get
AllocationDeciders
used for allocation - DECIDERS_NO - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
-
The shard was denied allocation to a node because the allocation deciders all returned a NO decision
- DECIDERS_THROTTLED - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
-
The allocation attempt was throttled on the shard by the allocation deciders
- decideShardAllocation(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- decideShardAllocation(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceShardsAllocator
- decideShardAllocation(ShardRouting, RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocator
-
Returns the decision for where a shard should reside in the cluster.
- Decimal(String) - Constructor for class org.elasticsearch.search.DocValueFormat.Decimal
- decision() - Method in record class org.elasticsearch.gateway.ReplicaShardAllocator.PerNodeAllocationResult
-
Returns the value of the
decision
record component. - decision(Decision, String, String, Object...) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Create a routing decision, including the reason if the debug flag is turned on
- Decision - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This abstract class defining basic
Decision
used during shard allocation process. - Decision() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.Decision
- Decision.Multi - Class in org.elasticsearch.cluster.routing.allocation.decider
-
Simple class representing a list of decisions
- Decision.Single - Class in org.elasticsearch.cluster.routing.allocation.decider
-
Simple class representing a single decision
- Decision.Type - Enum Class in org.elasticsearch.cluster.routing.allocation.decider
-
This enumeration defines the possible types of decisions
- decisions() - Method in class org.elasticsearch.cluster.routing.allocation.RerouteExplanation
- declareAcknowledgedAndShardsAcknowledgedFields(ConstructingObjectParser<T, Void>) - Static method in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- declareAcknowledgedField(ConstructingObjectParser<T, Void>) - Static method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- declareBaseParserFields(String, AbstractObjectParser<? extends RetrieverBuilder, RetrieverParserContext>) - Static method in class org.elasticsearch.search.retriever.RetrieverBuilder
- declareCommon(AbstractObjectParser<? extends MultiValuesSourceAggregationBuilder<?>, T>, boolean, ValueType) - Static method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceParseHelper
- declareField(String, AbstractObjectParser<? extends MultiValuesSourceAggregationBuilder<?>, T>, boolean, boolean, boolean, boolean, boolean) - Static method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceParseHelper
-
Declares a field that contains information about a values source
- declareFields(AbstractObjectParser<? extends ValuesSourceAggregationBuilder<?>, T>, boolean, boolean, boolean) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- declareFields(AbstractObjectParser<? extends ValuesSourceAggregationBuilder<?>, T>, boolean, boolean, boolean, boolean) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- declareFields(ConstructingObjectParser<T, Void>) - Static method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- declareFields(ConstructingObjectParser<T, Void>) - Static method in exception org.elasticsearch.action.support.DefaultShardOperationFailedException
- declareIntervalFields(ObjectParser<T, String>) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- declareParseFields(ConstructingObjectParser<? extends NXYSignificanceHeuristic, ?>) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
-
Set up and ConstructingObjectParser to accept the standard arguments for an NXYSignificanceHeuristic.
- declareRawObject(AbstractObjectParser<Value, Context>, BiConsumer<Value, BytesReference>, ParseField) - Static method in class org.elasticsearch.common.xcontent.ObjectParserHelper
-
Helper to declare an object that will be parsed into a
BytesReference
- declareRawObjectOrNull(AbstractObjectParser<Value, Context>, BiConsumer<Value, BytesReference>, ParseField) - Static method in class org.elasticsearch.common.xcontent.ObjectParserHelper
- declareScript(AbstractObjectParser<T, ?>, BiConsumer<T, Script>) - Static method in class org.elasticsearch.script.Script
-
Declare a script field on an
ObjectParser
with the standard name (script
). - declareScript(AbstractObjectParser<T, ?>, BiConsumer<T, Script>, ParseField) - Static method in class org.elasticsearch.script.Script
-
Declare a script field on an
ObjectParser
. - declareStandardFields(AbstractObjectParser<? extends QueryBuilder, ?>) - Static method in class org.elasticsearch.index.query.AbstractQueryBuilder
- decode(int, DataInput, long[]) - Static method in class org.elasticsearch.index.codec.ForUtil
-
Decode 128 integers into
longs
. - decode(int, DataInput, long[]) - Method in class org.elasticsearch.index.codec.tsdb.DocValuesForUtil
- decode(String) - Static method in class org.elasticsearch.index.mapper.TimeSeriesRoutingHashFieldMapper
- decode(BytesRef) - Static method in class org.elasticsearch.search.runtime.IpScriptFieldTermsQuery
- decode(ReleasableBytesReference, Consumer<Object>) - Method in class org.elasticsearch.transport.InboundDecoder
- decode(NamedWriteableRegistry, BytesReference) - Static method in class org.elasticsearch.action.search.SearchContextId
- decodeAfterQueryParam(String) - Static method in enum class org.elasticsearch.action.admin.cluster.snapshots.get.SnapshotSortKey
- decodeAsMap(byte[]) - Static method in class org.elasticsearch.index.mapper.IgnoredSourceFieldMapper
-
Parses the passed byte array as a NameValue and converts its decoded value to a map of maps that corresponds to the field-value subtree.
- decodeAsMap(BytesRef) - Static method in class org.elasticsearch.index.mapper.RoutingPathFields
- decodeComponent(String) - Static method in class org.elasticsearch.rest.RestUtils
-
Decodes a bit of an URL encoded by a browser.
- decoded - Variable in class org.elasticsearch.script.field.vectors.ByteBinaryDenseVectorDocValuesField
- decoded - Variable in class org.elasticsearch.script.field.vectors.ByteMultiDenseVectorDocValuesField
- decodeDenseVector(IndexVersion, BytesRef, float[]) - Static method in class org.elasticsearch.index.mapper.vectors.VectorEncoderDecoder
-
Decodes a BytesRef into the provided array of floats
- decodeDoc(long) - Static method in class org.elasticsearch.search.sort.ShardDocSortField
-
Get the doc id encoded in the sort value.
- decodeId(byte[]) - Static method in class org.elasticsearch.index.mapper.Uid
-
Decode an indexed id back to its original form.
- decodeId(byte[], int, int) - Static method in class org.elasticsearch.index.mapper.Uid
-
Decode an indexed id back to its original form.
- decodeIndices(BytesReference) - Static method in class org.elasticsearch.action.search.SearchContextId
- decodeMagnitude(IndexVersion, BytesRef) - Static method in class org.elasticsearch.index.mapper.vectors.VectorEncoderDecoder
-
Decodes the last 4 bytes of the encoded vector, which contains the vector magnitude.
- decodeMultiDenseVector(BytesRef, int, float[][]) - Static method in class org.elasticsearch.index.mapper.vectors.VectorEncoderDecoder
- decodeQueryString(String, int, Map<String, String>) - Static method in class org.elasticsearch.rest.RestUtils
- decodeRanges(BytesRef) - Method in enum class org.elasticsearch.index.mapper.RangeType
- decodeShardRequestIndex(long) - Static method in class org.elasticsearch.search.sort.ShardDocSortField
-
Get the shard request index encoded in the sort value.
- decodeTo32(int, DataInput, long[]) - Static method in class org.elasticsearch.index.codec.ForUtil
-
Decodes 128 integers into 64
longs
such that each long contains two values, each represented with 32 bits. - decodeX(int) - Method in class org.elasticsearch.lucene.spatial.CoordinateEncoder
-
decode X value
- decodeY(int) - Method in class org.elasticsearch.lucene.spatial.CoordinateEncoder
-
decode Y value
- decompress(BytesReference) - Method in class org.elasticsearch.transport.DeflateTransportDecompressor
- decompress(BytesReference) - Method in class org.elasticsearch.transport.Lz4TransportDecompressor
- decompress(BytesReference) - Method in class org.elasticsearch.transport.TransportDecompressor
-
Decompress the provided bytes
- decorate(CompoundProcessor, ConditionalProcessor, List<SimulateProcessorResult>) - Static method in class org.elasticsearch.ingest.TrackingResultProcessor
- decorate(XContentParser) - Method in interface org.elasticsearch.plugins.internal.XContentParserDecorator
- DECREASE_SHARDS - Enum constant in enum class org.elasticsearch.action.datastreams.autosharding.AutoShardingType
- decRef() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodeHotThreads
- decRef() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsResponse
- decRef() - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequest
- decRef() - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequest.NodeRequest
- decRef() - Method in class org.elasticsearch.action.search.MultiSearchResponse
- decRef() - Method in class org.elasticsearch.action.search.SearchResponse
- decRef() - Method in class org.elasticsearch.action.search.SearchResponseSections
- decRef() - Method in class org.elasticsearch.cluster.coordination.ValidateJoinRequest
- decRef() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- decRef() - Method in class org.elasticsearch.index.store.Store
-
Decreases the refCount of this Store instance.
- decRef() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- decRef() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- decRef() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- decRef() - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- decRef() - Method in class org.elasticsearch.search.query.QuerySearchResult
- decRef() - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
- decRef() - Method in class org.elasticsearch.search.SearchHit
- decRef() - Method in class org.elasticsearch.search.SearchHits
- decRef() - Method in class org.elasticsearch.transport.BytesTransportRequest
- decRef() - Method in class org.elasticsearch.transport.TransportMessage
-
Note that the lifetime of an outbound
TransportMessage
lasts at least until it has been fully sent over the network, and it may be closed on a network thread in a context in which there's a risk of stack overflows if on close it calls back into the network layer in a manner that might end up nesting too deeply. - decRef(ElasticsearchDirectoryReader) - Method in class org.elasticsearch.index.engine.ElasticsearchReaderManager
- decrementRecoveredOperations(int) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- decribe() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds
-
Description used in profile results.
- decribe() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromMany
- decribe() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromManySmall
- decribe() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromSingle
- decrypt(char[]) - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Decrypts the underlying keystore data.
- decryptKeyStore(KeyStoreWrapper, Terminal) - Static method in class org.elasticsearch.common.cli.KeyStoreAwareCommand
-
Decrypt the
keyStore
, prompting the user to enter the password in theTerminal
if it is password protected - dedup() - Method in class org.elasticsearch.index.analysis.HunspellTokenFilterFactory
- deduplicate() - Method in class org.elasticsearch.script.field.WriteField
-
Remove all duplicate values from this path.
- deduplicate(String) - Method in class org.elasticsearch.common.util.StringLiteralDeduplicator
- deduplicate(T) - Method in interface org.elasticsearch.common.io.stream.DelayableWriteable.Deduplicator
- DEDUPLICATED_MAPPINGS_PARAM - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- DeduplicateFieldInfosCodec(String, Codec) - Constructor for class org.elasticsearch.index.codec.CodecService.DeduplicateFieldInfosCodec
- deduplicateNodeIdentifier(String) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Deduplicate the given string that must be a node id or node name.
- DeduplicatingFieldInfosFormat - Class in org.elasticsearch.index.codec
-
Wrapper around a
FieldInfosFormat
that will deduplicate and intern all field names, attribute-keys and -values, and in most cases attribute maps on read. - DeduplicatingFieldInfosFormat(FieldInfosFormat) - Constructor for class org.elasticsearch.index.codec.DeduplicatingFieldInfosFormat
- DeDuplicatingTokenFilter - Class in org.elasticsearch.lucene.analysis.miscellaneous
-
Inspects token streams for duplicate sequences of tokens.
- DeDuplicatingTokenFilter(TokenStream, DuplicateByteSequenceSpotter) - Constructor for class org.elasticsearch.lucene.analysis.miscellaneous.DeDuplicatingTokenFilter
- DeDuplicatingTokenFilter(TokenStream, DuplicateByteSequenceSpotter, boolean) - Constructor for class org.elasticsearch.lucene.analysis.miscellaneous.DeDuplicatingTokenFilter
- deepCopy(Object) - Static method in class org.elasticsearch.ingest.IngestDocument
- deepCopy(AggregationBuilder, Function<AggregationBuilder, AggregationBuilder>) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Creates a deep copy of by recursively invoking
#shallowCopy
on the sub aggregations. - deepCopyMap(Map<K, V>) - Static method in class org.elasticsearch.ingest.IngestDocument
- deepEquals(Map<K, V>, Map<K, V>) - Static method in class org.elasticsearch.common.util.Maps
-
Returns
true
if the two specified maps are equal to one another. - DEFAULT - Enum constant in enum class org.elasticsearch.cluster.routing.ShardRouting.Role
- DEFAULT - Enum constant in enum class org.elasticsearch.index.mapper.DynamicTemplate.MatchType
-
DEFAULT is set when the user did not explicitly set a match_pattern in their dynamic_templates entry.
- DEFAULT - Enum constant in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- DEFAULT - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.composite.MissingOrder
-
Place buckets for missing values first if the source uses ASC ordering or last otherwise.
- DEFAULT - Enum constant in enum class org.elasticsearch.search.aggregations.metrics.TDigestExecutionHint
- DEFAULT - Static variable in enum class org.elasticsearch.action.search.SearchType
-
The default search type (
SearchType.QUERY_THEN_FETCH
. - DEFAULT - Static variable in record class org.elasticsearch.action.support.ActiveShardCount
- DEFAULT - Static variable in record class org.elasticsearch.action.support.IndicesOptions
- DEFAULT - Static variable in record class org.elasticsearch.action.support.IndicesOptions.GatekeeperOptions
- DEFAULT - Static variable in record class org.elasticsearch.action.support.IndicesOptions.SelectorOptions
-
Default instance.
- DEFAULT - Static variable in record class org.elasticsearch.action.support.IndicesOptions.WildcardOptions
- DEFAULT - Static variable in class org.elasticsearch.cluster.ClusterName
- DEFAULT - Static variable in class org.elasticsearch.cluster.metadata.DataStreamLifecycle
- DEFAULT - Static variable in interface org.elasticsearch.cluster.routing.allocation.WriteLoadForecaster
- DEFAULT - Static variable in enum class org.elasticsearch.common.unit.DistanceUnit
- DEFAULT - Static variable in class org.elasticsearch.common.util.concurrent.EsExecutors.TaskTrackingConfig
- DEFAULT - Static variable in enum class org.elasticsearch.index.query.GeoValidationMethod
- DEFAULT - Static variable in record class org.elasticsearch.monitor.jvm.HotThreads.RequestOptions
- DEFAULT - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightUtils.Encoders
- DEFAULT_ACCEPTABLE_OVERHEAD_RATIO - Static variable in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Default acceptable overhead ratio.
- DEFAULT_ACCURACY - Static variable in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- DEFAULT_ACK_TIMEOUT - Static variable in class org.elasticsearch.action.support.master.AcknowledgedRequest
- DEFAULT_ALLOW_PARTIAL_SEARCH_RESULTS - Static variable in class org.elasticsearch.search.SearchService
- DEFAULT_ANALYZE_WILDCARD - Static variable in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Default for wildcard analysis.
- DEFAULT_ANALYZER_NAME - Static variable in class org.elasticsearch.index.analysis.AnalysisRegistry
- DEFAULT_BACKOFF_DISCOUNT - Static variable in class org.elasticsearch.search.suggest.phrase.StupidBackoff
-
Default discount parameter for
StupidBackoff
smoothing - DEFAULT_BATCHED_REDUCE_SIZE - Static variable in class org.elasticsearch.action.search.SearchRequest
- DEFAULT_BOOST - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Boost terms in query based on score.
- DEFAULT_BOOST - Static variable in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Default for boost to apply to resulting Lucene query.
- DEFAULT_BOOST_MODE - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- DEFAULT_BOOST_TERMS - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- DEFAULT_BUFFER_PIXELS - Static variable in class org.elasticsearch.common.geo.SimpleVectorTileFormatter
- DEFAULT_BUFFER_SIZE - Static variable in class org.elasticsearch.index.translog.TranslogConfig
- DEFAULT_CASE_INSENSITIVITY - Static variable in class org.elasticsearch.index.query.PrefixQueryBuilder
- DEFAULT_CASE_INSENSITIVITY - Static variable in class org.elasticsearch.index.query.RegexpQueryBuilder
- DEFAULT_CASE_INSENSITIVITY - Static variable in class org.elasticsearch.index.query.TermQueryBuilder
- DEFAULT_CASE_INSENSITIVITY - Static variable in class org.elasticsearch.index.query.WildcardQueryBuilder
- DEFAULT_CHUNK_SIZE - Static variable in class org.elasticsearch.index.shard.PrimaryReplicaSyncer
- DEFAULT_CHUNK_SIZE - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
- DEFAULT_CLUSTER_ROUTING_ALLOCATION_NODE_CONCURRENT_RECOVERIES - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
- DEFAULT_CLUSTER_ROUTING_ALLOCATION_NODE_INITIAL_PRIMARIES_RECOVERIES - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
- DEFAULT_CODEC - Static variable in class org.elasticsearch.index.codec.CodecService
- DEFAULT_COMPILATION_RATE_LIMIT - Static variable in class org.elasticsearch.script.ScriptContext
-
The default compilation rate limit for contexts with compilation rate limiting enabled
- DEFAULT_CONNECT_TIMEOUT - Static variable in class org.elasticsearch.index.reindex.RemoteInfo
-
Default
RemoteInfo.connectTimeout
for requests that don't have one set. - DEFAULT_DATE_TIME_FORMATTER - Static variable in class org.elasticsearch.index.mapper.DateFieldMapper
- DEFAULT_DATE_TIME_NANOS_FORMATTER - Static variable in class org.elasticsearch.index.mapper.DateFieldMapper
- DEFAULT_DECAY - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- DEFAULT_DELETES_PCT_ALLOWED - Static variable in class org.elasticsearch.index.MergePolicyConfig
- DEFAULT_DENSE_VECTOR_TO_INT8_HNSW - Static variable in class org.elasticsearch.index.IndexVersions
- DEFAULT_DISTANCE_UNIT - Static variable in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Default for distance unit computation.
- DEFAULT_ELECTION_STRATEGY - Static variable in class org.elasticsearch.discovery.DiscoveryModule
- DEFAULT_ENABLE_POSITION_INCREMENTS - Static variable in class org.elasticsearch.index.query.QueryStringQueryBuilder
- DEFAULT_ENCODER - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
the default encoder setting
- DEFAULT_ESCAPE - Static variable in class org.elasticsearch.index.query.QueryStringQueryBuilder
- DEFAULT_EWMA_ALPHA - Static variable in class org.elasticsearch.common.util.concurrent.EsExecutors.TaskTrackingConfig
- DEFAULT_EXPUNGE_DELETES_ALLOWED - Static variable in class org.elasticsearch.index.MergePolicyConfig
- DEFAULT_EXTENT - Static variable in class org.elasticsearch.common.geo.SimpleVectorTileFormatter
- DEFAULT_FACTOR - Static variable in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- DEFAULT_FAIL_ON_UNSUPPORTED_FIELDS - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- DEFAULT_FEATURES_SETTING - Static variable in class org.elasticsearch.transport.TransportSettings
- DEFAULT_FIELD_NAMES - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Default field names.
- DEFAULT_FIELD_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- DEFAULT_FLAGS - Static variable in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Default for search flags to use.
- DEFAULT_FLAGS_VALUE - Static variable in class org.elasticsearch.index.query.RegexpQueryBuilder
- DEFAULT_FLOOR_SEGMENT - Static variable in class org.elasticsearch.index.MergePolicyConfig
- DEFAULT_FORMATTER - Static variable in class org.elasticsearch.common.xcontent.XContentElasticsearchExtension
- DEFAULT_FRAGMENT_CHAR_SIZE - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
the default number of fragments size in characters
- DEFAULT_FROM - Static variable in class org.elasticsearch.index.query.InnerHitBuilder
- DEFAULT_FROM - Static variable in class org.elasticsearch.search.SearchService
- DEFAULT_FUZZINESS - Static variable in class org.elasticsearch.index.query.FuzzyQueryBuilder
-
Default maximum edit distance.
- DEFAULT_FUZZINESS - Static variable in class org.elasticsearch.index.query.QueryStringQueryBuilder
- DEFAULT_FUZZY_MAX_EXPANSIONS - Static variable in class org.elasticsearch.index.query.QueryStringQueryBuilder
- DEFAULT_FUZZY_MAX_EXPANSIONS - Static variable in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Default number of terms fuzzy queries will expand to.
- DEFAULT_FUZZY_PREFIX_LENGTH - Static variable in class org.elasticsearch.index.query.QueryStringQueryBuilder
- DEFAULT_FUZZY_PREFIX_LENGTH - Static variable in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Default for prefix length in fuzzy queries.
- DEFAULT_FUZZY_TRANSPOSITIONS - Static variable in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- DEFAULT_FUZZY_TRANSPOSITIONS - Static variable in class org.elasticsearch.index.query.QueryStringQueryBuilder
- DEFAULT_FUZZY_TRANSPOSITIONS - Static variable in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Default for using transpositions in fuzzy queries.
- DEFAULT_GC_DELETES - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting to enable / disable deletes garbage collection.
- DEFAULT_GEO_DISTANCE - Static variable in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Default for geo distance computation.
- DEFAULT_GLOBAL_RETENTION - Enum constant in enum class org.elasticsearch.cluster.metadata.DataStreamLifecycle.RetentionSource
- DEFAULT_HEADER_SIZE_IN_BYTES - Static variable in class org.elasticsearch.index.translog.Translog
- DEFAULT_HEADERS_SETTING - Static variable in class org.elasticsearch.common.util.concurrent.ThreadContext
- DEFAULT_HIGHLIGHT_FILTER - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
default for whether
fvh
should provide highlighting on filter clauses - DEFAULT_IGNORE_UNMAPPED - Static variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
The default value for ignore_unmapped.
- DEFAULT_IGNORE_UNMAPPED - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
The default value for ignore_unmapped.
- DEFAULT_IGNORE_UNMAPPED - Static variable in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
The default value for ignore_unmapped.
- DEFAULT_IGNORE_UNMAPPED - Static variable in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.The default value for ignore_unmapped.
- DEFAULT_IGNORE_UNMAPPED - Static variable in class org.elasticsearch.index.query.NestedQueryBuilder
-
The default value for ignore_unmapped.
- DEFAULT_IN_ORDER - Static variable in class org.elasticsearch.index.query.SpanNearQueryBuilder
-
Default for flag controlling whether matches are required to be in-order
- DEFAULT_INCLUDE - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- DEFAULT_INCLUDE_LOWER - Static variable in class org.elasticsearch.index.mapper.RangeFieldMapper
- DEFAULT_INCLUDE_LOWER - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- DEFAULT_INCLUDE_TYPE_NAME_POLICY - Static variable in class org.elasticsearch.rest.BaseRestHandler
- DEFAULT_INCLUDE_UPPER - Static variable in class org.elasticsearch.index.mapper.RangeFieldMapper
- DEFAULT_INCLUDE_UPPER - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- DEFAULT_INDEX_AUTOSCALING_EWMA_ALPHA - Static variable in class org.elasticsearch.threadpool.ThreadPool
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.admin.indices.diskusage.AnalyzeIndexDiskUsageRequest
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.admin.indices.resolve.ResolveClusterActionRequest
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Request
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.search.OpenPointInTimeRequest
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.search.SearchRequest
- DEFAULT_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- DEFAULT_INNER_HIT_QUERY - Static variable in class org.elasticsearch.index.query.InnerHitBuilder
- DEFAULT_INSTANCE - Static variable in class org.elasticsearch.cluster.coordination.ElectionStrategy
- DEFAULT_KEEPALIVE_SETTING - Static variable in class org.elasticsearch.search.SearchService
- DEFAULT_LAPLACE_ALPHA - Static variable in class org.elasticsearch.search.suggest.phrase.Laplace
-
Default alpha parameter for laplace smoothing
- DEFAULT_LENIENCY - Static variable in class org.elasticsearch.index.search.MatchQueryParser
- DEFAULT_LENIENT - Static variable in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Default for using lenient query parsing.
- DEFAULT_LENIENT_PARSING - Static variable in enum class org.elasticsearch.index.query.GeoValidationMethod
- DEFAULT_LOCALE - Static variable in class org.elasticsearch.index.mapper.DateFieldMapper
- DEFAULT_MAC_ADDRESS_SUPPLIER - Static variable in class org.elasticsearch.common.UUIDs
- DEFAULT_MAX_ANALYZED_OFFSET - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
default for whether to stop highlighting at the defined max_analyzed_offset to avoid exceptions for longer texts
- DEFAULT_MAX_BOOST - Static variable in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- DEFAULT_MAX_BUCKETS - Static variable in class org.elasticsearch.search.aggregations.MultiBucketConsumerService
- DEFAULT_MAX_CLAUSE_COUNT - Static variable in class org.elasticsearch.search.SearchUtils
- DEFAULT_MAX_CONCURRENT_SHARD_REQUESTS - Static variable in class org.elasticsearch.action.search.SearchRequest
- DEFAULT_MAX_DETERMINED_STATES - Static variable in class org.elasticsearch.index.query.QueryStringQueryBuilder
- DEFAULT_MAX_DETERMINIZED_STATES - Static variable in class org.elasticsearch.index.query.RegexpQueryBuilder
- DEFAULT_MAX_DOC_FREQ - Static variable in class org.elasticsearch.action.termvectors.TermVectorsFilter
- DEFAULT_MAX_DOC_FREQ - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Ignore words which occur in more than this many docs.
- DEFAULT_MAX_DOC_FREQ - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- DEFAULT_MAX_EDITS - Static variable in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- DEFAULT_MAX_EXPANSIONS - Static variable in class org.elasticsearch.index.query.FuzzyQueryBuilder
-
Default maximum number of terms that the fuzzy query will expand to.
- DEFAULT_MAX_EXPANSIONS - Static variable in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- DEFAULT_MAX_INPUT_LENGTH - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Defaults
- DEFAULT_MAX_INSPECTIONS - Static variable in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- DEFAULT_MAX_MERGE_AT_ONCE - Static variable in class org.elasticsearch.index.MergePolicyConfig
- DEFAULT_MAX_MERGED_SEGMENT - Static variable in class org.elasticsearch.index.MergePolicyConfig
- DEFAULT_MAX_MERGED_SEGMENT_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- DEFAULT_MAX_NUM_CELLS - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- DEFAULT_MAX_NUM_TOKENS_PARSED - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Default maximum number of tokens to parse in each example doc field that is not stored with TermVector support.
- DEFAULT_MAX_QUERY_TERMS - Static variable in class org.elasticsearch.action.termvectors.TermVectorsFilter
- DEFAULT_MAX_QUERY_TERMS - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Return a Query with no more than this many terms.
- DEFAULT_MAX_QUERY_TERMS - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- DEFAULT_MAX_TERM_FREQ - Static variable in class org.elasticsearch.action.termvectors.TermVectorsFilter
- DEFAULT_MAX_TERM_FREQ - Static variable in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- DEFAULT_MAX_TIME_BASED_MERGED_SEGMENT - Static variable in class org.elasticsearch.index.MergePolicyConfig
-
Time-based data generally gets rolled over, so there is not much value in enforcing a maximum segment size, which has the side effect of merging fewer segments together than the merge factor, which in-turn increases write amplification.
- DEFAULT_MAX_TIME_BASED_MERGED_SEGMENT_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- DEFAULT_MAX_WORD_LENGTH - Static variable in class org.elasticsearch.action.termvectors.TermVectorsFilter
- DEFAULT_MAX_WORD_LENGTH - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Ignore words greater than this length or if 0 then this has no effect.
- DEFAULT_MAX_WORD_LENGTH - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- DEFAULT_MERGE_FACTOR - Static variable in class org.elasticsearch.index.MergePolicyConfig
-
A default value for
LogByteSizeMergePolicy
's merge factor: 32. - DEFAULT_MIN_DOC_FREQ - Static variable in class org.elasticsearch.action.termvectors.TermVectorsFilter
- DEFAULT_MIN_DOC_FREQ - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Ignore words which do not occur in at least this many docs.
- DEFAULT_MIN_DOC_FREQ - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- DEFAULT_MIN_DOC_FREQ - Static variable in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- DEFAULT_MIN_TERM_FREQ - Static variable in class org.elasticsearch.action.termvectors.TermVectorsFilter
- DEFAULT_MIN_TERM_FREQ - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Ignore terms with less than this frequency in the source doc.
- DEFAULT_MIN_TERM_FREQ - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- DEFAULT_MIN_WORD_LENGTH - Static variable in class org.elasticsearch.action.termvectors.TermVectorsFilter
- DEFAULT_MIN_WORD_LENGTH - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Ignore words less than this length or if 0 then this has no effect.
- DEFAULT_MIN_WORD_LENGTH - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- DEFAULT_MIN_WORD_LENGTH - Static variable in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- DEFAULT_MINIMUM_SHOULD_MATCH - Static variable in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- DEFAULT_MINIMUM_SHOULD_MATCH - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- DEFAULT_MODIFIER - Static variable in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- DEFAULT_MULTI_VALUE_MODE - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- DEFAULT_NETWORK_HOST - Static variable in class org.elasticsearch.common.network.NetworkService
-
By default, we bind to loopback interfaces
- DEFAULT_NO_MATCH_SIZE - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
default for fragment size when there are no matches
- DEFAULT_NUMBER_OF_FRAGMENTS - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
the default number of fragments for highlighting
- DEFAULT_OPERATOR - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
-
The default mode terms are combined in a match query
- DEFAULT_OPERATOR - Static variable in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- DEFAULT_OPERATOR - Static variable in class org.elasticsearch.index.query.QueryStringQueryBuilder
- DEFAULT_OPERATOR - Static variable in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Default for default operator to use for linking boolean clauses.
- DEFAULT_PATH - Static variable in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper
- DEFAULT_PHRASE_LIMIT - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
default for the maximum number of phrases the fvh will consider
- DEFAULT_PHRASE_SLOP - Static variable in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- DEFAULT_PHRASE_SLOP - Static variable in class org.elasticsearch.index.query.QueryStringQueryBuilder
- DEFAULT_PHRASE_SLOP - Static variable in class org.elasticsearch.index.search.MatchQueryParser
- DEFAULT_PIPELINE - Static variable in class org.elasticsearch.index.IndexSettings
- DEFAULT_POSITION_INCREMENTS - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Defaults
- DEFAULT_POST - Static variable in class org.elasticsearch.index.query.SpanNotQueryBuilder
-
the default post parameter size
- DEFAULT_PRE - Static variable in class org.elasticsearch.index.query.SpanNotQueryBuilder
-
the default pre parameter size
- DEFAULT_PRE_FILTER_SHARD_SIZE - Static variable in class org.elasticsearch.action.search.SearchRequest
- DEFAULT_PRE_FILTER_SHARD_SIZE - Static variable in class org.elasticsearch.action.search.TransportSearchAction
- DEFAULT_PREALLOCATION - Static variable in class org.elasticsearch.search.aggregations.AggregationBuilder
- DEFAULT_PRECISION - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- DEFAULT_PRECISION - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregationBuilder
- DEFAULT_PRECISION - Static variable in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- DEFAULT_PRECISION - Static variable in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- DEFAULT_PREFIX_LENGTH - Static variable in class org.elasticsearch.index.query.FuzzyQueryBuilder
-
Default number of initial characters which will not be “fuzzified”.
- DEFAULT_PREFIX_LENGTH - Static variable in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- DEFAULT_PREFIX_LENGTH - Static variable in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- DEFAULT_PRESERVE_SEPARATORS - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Defaults
- DEFAULT_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- DEFAULT_QUERYWEIGHT - Static variable in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- DEFAULT_RANK_WINDOW_SIZE - Static variable in class org.elasticsearch.search.rank.RankBuilder
- DEFAULT_REASON - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
- DEFAULT_REFRESH_INTERVAL - Static variable in class org.elasticsearch.index.IndexSettings
- DEFAULT_REQUIRE_FIELD_MATCH - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
default for whether a field should be highlighted only if a query matches that field
- DEFAULT_RESCORE_QUERYWEIGHT - Static variable in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- DEFAULT_RESTART_SHARD_ALLOCATION_DELAY - Static variable in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- DEFAULT_SCOPED_SETTINGS - Static variable in class org.elasticsearch.common.settings.IndexScopedSettings
- DEFAULT_SCORE_MODE - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- DEFAULT_SCORE_MODE - Static variable in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- DEFAULT_SCORE_ORDERED - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
default for highlight fragments being ordered by score
- DEFAULT_SCRIPT - Static variable in class org.elasticsearch.index.mapper.AbstractScriptFieldType
- DEFAULT_SCRIPT_LANG - Static variable in class org.elasticsearch.script.Script
-
The name of the of the default scripting language.
- DEFAULT_SCRIPT_TYPE - Static variable in class org.elasticsearch.script.Script
-
The default
ScriptType
. - DEFAULT_SCROLL_SIZE - Static variable in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- DEFAULT_SCROLL_TIMEOUT - Static variable in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- DEFAULT_SEARCH_ANALYZER_NAME - Static variable in class org.elasticsearch.index.analysis.AnalysisRegistry
- DEFAULT_SEARCH_QUOTED_ANALYZER_NAME - Static variable in class org.elasticsearch.index.analysis.AnalysisRegistry
- DEFAULT_SEARCH_TIMEOUT_SETTING - Static variable in class org.elasticsearch.search.SearchService
- DEFAULT_SEED - Static variable in class org.elasticsearch.index.codec.bloomfilter.ES87BloomFilterPostingsFormat.MurmurHash3
-
A default seed to use for the murmur hash algorithm.
- DEFAULT_SEGMENTS_PER_TIER - Static variable in class org.elasticsearch.index.MergePolicyConfig
- DEFAULT_SEQUENCE_ID_SUPPLIER - Static variable in class org.elasticsearch.common.UUIDs
- DEFAULT_SETTINGS - Static variable in class org.elasticsearch.indices.SystemIndexDescriptor
- DEFAULT_SHAPE_FIELD_NAME - Static variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- DEFAULT_SHAPE_INDEX_NAME - Static variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- DEFAULT_SHAPE_RELATION - Static variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- DEFAULT_SHARD_SAMPLE_SIZE - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- DEFAULT_SIMILARITY - Static variable in class org.elasticsearch.index.similarity.SimilarityService
- DEFAULT_SIZE - Static variable in class org.elasticsearch.index.query.InnerHitBuilder
- DEFAULT_SIZE - Static variable in class org.elasticsearch.search.SearchService
- DEFAULT_SLOP - Static variable in class org.elasticsearch.index.query.SpanNearQueryBuilder
-
Default slop value, this is the same that lucene
SpanNearQuery
uses if no slop is provided - DEFAULT_SNAPSHOT_COMMIT_SUPPLIER - Static variable in class org.elasticsearch.index.IndexModule
- DEFAULT_SOCKET_TIMEOUT - Static variable in class org.elasticsearch.index.reindex.RemoteInfo
-
Default
RemoteInfo.socketTimeout
for requests that don't have one set. - DEFAULT_SORT - Static variable in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- DEFAULT_STOP_WORDS - Static variable in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Default set of stopwords.
- DEFAULT_STRING_DISTANCE - Static variable in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- DEFAULT_STYLED_POST_TAGS - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
the default closing tags when
tag_schema = "styled"
- DEFAULT_STYLED_PRE_TAG - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
the default opening tags when
tag_schema = "styled"
- DEFAULT_SUGGEST_MODE - Static variable in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- DEFAULT_SYSTEM_DATA_STREAM_THREAD_POOLS - Static variable in record class org.elasticsearch.indices.ExecutorNames
-
The thread pools for a typical system data stream.
- DEFAULT_SYSTEM_INDEX_THREAD_POOLS - Static variable in record class org.elasticsearch.indices.ExecutorNames
-
The thread pools for a typical system index.
- DEFAULT_TEMPLATE_LANG - Static variable in class org.elasticsearch.script.Script
-
The name of the default template language.
- DEFAULT_TERMINATE_AFTER - Static variable in class org.elasticsearch.search.internal.SearchContext
- DEFAULT_TIE_BREAKER - Static variable in class org.elasticsearch.index.query.DisMaxQueryBuilder
-
Default multiplication factor for breaking ties in document scores.
- DEFAULT_TIMEOUT - Static variable in class org.elasticsearch.action.support.replication.ReplicationRequest
- DEFAULT_TIMEOUT - Static variable in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- DEFAULT_TIMESTAMP_FIELD - Static variable in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
- DEFAULT_TIMESTAMP_MAPPING_WITHOUT_ROUTING - Static variable in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
- DEFAULT_TIMESTAMP_SUPPLIER - Static variable in class org.elasticsearch.common.UUIDs
- DEFAULT_TIMEZONE - Static variable in class org.elasticsearch.action.downsample.DownsampleConfig
- DEFAULT_TO_INT8 - Static variable in class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper
- DEFAULT_TRACK_TOTAL_HITS_UP_TO - Static variable in class org.elasticsearch.search.internal.SearchContext
- DEFAULT_TRANSPOSITIONS - Static variable in class org.elasticsearch.index.query.FuzzyQueryBuilder
-
Default as to whether transpositions should be treated as a primitive edit operation, instead of classic Levenshtein algorithm.
- DEFAULT_TYPE - Static variable in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- DEFAULT_TYPE - Static variable in class org.elasticsearch.index.query.QueryStringQueryBuilder
- DEFAULT_TYPE - Static variable in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- DEFAULT_VALIDATION - Static variable in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- DEFAULT_VALUE - Static variable in class org.elasticsearch.index.mapper.DocCountFieldMapper.DocCountFieldType
- DEFAULT_VALUE - Static variable in class org.elasticsearch.search.aggregations.bucket.DocCountProvider
- DEFAULT_VERBOSE_MODE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- DEFAULT_WAIT_FOR_COMPLETION - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
- DEFAULT_WAIT_FOR_NODE_TIMEOUT - Static variable in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- DEFAULT_WAIT_TIMEOUT - Static variable in class org.elasticsearch.action.downsample.DownsampleAction
- DEFAULT_WEIGHT - Static variable in class org.elasticsearch.search.aggregations.AggregatorBase
-
The default "weight" that a bucket takes when performing an aggregation
- DEFAULT_WINDOW_SIZE - Static variable in class org.elasticsearch.search.rescore.RescorerBuilder
- DEFAULT_ZERO_TERMS_QUERY - Static variable in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- DEFAULT_ZERO_TERMS_QUERY - Static variable in class org.elasticsearch.index.search.MatchQueryParser
- defaultAllowPartialSearchResults() - Method in class org.elasticsearch.search.SearchService
- DefaultBuiltInExecutorBuilders - Class in org.elasticsearch.threadpool
- DefaultBuiltInExecutorBuilders() - Constructor for class org.elasticsearch.threadpool.DefaultBuiltInExecutorBuilders
- DefaultConfigId(String, TaskType, InferenceService) - Constructor for record class org.elasticsearch.inference.InferenceService.DefaultConfigId
-
Creates an instance of a
DefaultConfigId
record class. - defaultConfigIds() - Method in interface org.elasticsearch.inference.InferenceService
-
Get the Ids and task type of any default configurations provided by this service
- defaultConfigs(ActionListener<List<Model>>) - Method in interface org.elasticsearch.inference.InferenceService
-
Call the listener with the default model configurations defined by the service
- defaultDisplayString(Build.Type, String, String, String) - Static method in record class org.elasticsearch.Build
- defaultField() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- defaultField(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
The default field to run against when no prefix field is specified.
- defaultFields() - Method in class org.elasticsearch.index.query.FilteredSearchExecutionContext
- defaultFields() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- defaultFrom(boolean) - Method in enum class org.elasticsearch.index.mapper.RangeType
- DefaultHighlighter - Class in org.elasticsearch.search.fetch.subphase.highlight
- DefaultHighlighter() - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.DefaultHighlighter
- DefaultHotAllocationSettingProvider() - Constructor for class org.elasticsearch.cluster.routing.allocation.DataTier.DefaultHotAllocationSettingProvider
- DefaultMalformedValueHandler(CheckedBiConsumer<Exception, XContentBuilder, IOException>) - Constructor for record class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.DefaultMalformedValueHandler
-
Creates an instance of a
DefaultMalformedValueHandler
record class. - defaultOperator() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- defaultOperator() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns the default operator for the query.
- defaultOperator(Operator) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Sets the boolean operator of the query parser used to parse the query string.
- defaultOperator(Operator) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Specify the default operator for the query.
- defaultPipeline() - Method in record class org.elasticsearch.ingest.IngestService.Pipelines
-
Returns the value of the
defaultPipeline
record component. - DefaultRestChannel - Class in org.elasticsearch.http
-
The default rest channel for incoming requests.
- defaultRetention() - Method in record class org.elasticsearch.cluster.metadata.DataStreamGlobalRetention
-
Returns the value of the
defaultRetention
record component. - defaultReuseAddress() - Static method in class org.elasticsearch.common.network.NetworkUtils
-
Returns system default for SO_REUSEADDR
- Defaults() - Constructor for class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.CompletionFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.FieldNamesFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.IgnoredFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.ObjectMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.RootObjectMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.RoutingFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.SourceFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.Defaults
- defaultSelector() - Method in record class org.elasticsearch.action.support.IndicesOptions.SelectorOptions
-
Returns the value of the
defaultSelector
record component. - defaultSettings() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
-
If the originating
GetIndexRequest
object was configured to include defaults, this will contain a mapping of index name toSettings
objects. - DefaultShardOperationFailedException - Exception in org.elasticsearch.action.support
- DefaultShardOperationFailedException() - Constructor for exception org.elasticsearch.action.support.DefaultShardOperationFailedException
- DefaultShardOperationFailedException(String, int, Throwable) - Constructor for exception org.elasticsearch.action.support.DefaultShardOperationFailedException
- DefaultShardOperationFailedException(StreamInput) - Constructor for exception org.elasticsearch.action.support.DefaultShardOperationFailedException
- DefaultShardOperationFailedException(ElasticsearchException) - Constructor for exception org.elasticsearch.action.support.DefaultShardOperationFailedException
- defaultSourceMode() - Method in enum class org.elasticsearch.index.IndexMode
- defaultStoreType(boolean) - Static method in class org.elasticsearch.index.IndexModule
- defaultTo(boolean) - Method in enum class org.elasticsearch.index.mapper.RangeType
- defaultValue - Variable in class org.elasticsearch.common.settings.Setting
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.countedterms.CountedTermsAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.prefix.IpPrefixAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.PercentileRanksAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
-
Aggregations should use this method to define a
ValuesSourceType
of last resort. - defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Aggregations should use this method to define a
ValuesSourceType
of last resort. - DefaultWriteLoadForecaster() - Constructor for class org.elasticsearch.cluster.routing.allocation.WriteLoadForecaster.DefaultWriteLoadForecaster
- DeferableBucketAggregator - Class in org.elasticsearch.search.aggregations.bucket
- DeferableBucketAggregator(String, AggregatorFactories, AggregationContext, Aggregator, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.DeferableBucketAggregator
- DeferringBucketCollector - Class in org.elasticsearch.search.aggregations.bucket
-
A
BucketCollector
that records collected doc IDs and buckets and allows to replay a subset of the collected buckets. - DeferringBucketCollector() - Constructor for class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
-
Sole constructor.
- DeferringBucketCollector.WrappedAggregator - Class in org.elasticsearch.search.aggregations.bucket
- deferringCollector() - Method in class org.elasticsearch.search.aggregations.bucket.DeferableBucketAggregator
-
Get the deferring collector.
- definition - Variable in class org.elasticsearch.index.analysis.NameOrDefinition
- definition() - Method in record class org.elasticsearch.health.Diagnosis
-
Returns the value of the
definition
record component. - Definition(String, String, String, String, String) - Constructor for record class org.elasticsearch.health.Diagnosis.Definition
-
Creates an instance of a
Definition
record class. - DEFLATE - Enum constant in enum class org.elasticsearch.transport.Compression.Scheme
- DeflateCompressor - Class in org.elasticsearch.common.compress
-
Compressor
implementation based on the DEFLATE compression algorithm. - DeflateCompressor() - Constructor for class org.elasticsearch.common.compress.DeflateCompressor
- DeflateTransportDecompressor - Class in org.elasticsearch.transport
- DeflateTransportDecompressor(Recycler<BytesRef>) - Constructor for class org.elasticsearch.transport.DeflateTransportDecompressor
- delay(ActionListener<T>) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.AllocationActionMultiListener
- DelayableWriteable<T extends Writeable> - Class in org.elasticsearch.common.io.stream
-
A holder for
Writeable
s that delays reading the underlying object on the receiving end. - DelayableWriteable.Deduplicator - Interface in org.elasticsearch.common.io.stream
-
An object implementing this interface can deduplicate instance of the provided objects.
- DelayableWriteable.Serialized<T extends Writeable> - Class in org.elasticsearch.common.io.stream
-
A
Writeable
stored in serialized form backed by aReleasableBytesReference
. - delayed() - Method in record class org.elasticsearch.cluster.routing.UnassignedInfo
-
Returns the value of the
delayed
record component. - delayed(long, long, List<NodeAllocationResult>) - Static method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Returns a NO decision for a delayed shard allocation on a replica shard, with the individual node-level decisions that comprised the final NO decision, if in explain mode.
- delayed(Writeable.Reader<T>, StreamInput) - Static method in class org.elasticsearch.common.io.stream.DelayableWriteable
-
Build a DelayableWriteable that copies a buffer from the provided StreamInput and deserializes the buffer when
DelayableWriteable.expand()
is called. - DELAYED_ALLOCATION - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
-
Allocation decision has been delayed
- DELAYED_WITH_ALTERNATIVE - Static variable in class org.elasticsearch.cluster.routing.allocation.Explanations.Allocation
- DELAYED_WITHOUT_ALTERNATIVE - Static variable in class org.elasticsearch.cluster.routing.allocation.Explanations.Allocation
- DelayedAllocationService - Class in org.elasticsearch.cluster.routing
-
The
DelayedAllocationService
listens to cluster state changes and checks if there are unassigned shards with delayed allocation (unassigned shards that have the delay marker). - DelayedAllocationService(ThreadPool, ClusterService, AllocationService) - Constructor for class org.elasticsearch.cluster.routing.DelayedAllocationService
- DelayedBucket<B extends InternalMultiBucketAggregation.InternalBucket> - Class in org.elasticsearch.search.aggregations
-
A wrapper around reducing buckets with the same key that can delay that reduction as long as possible.
- DelayedBucket(List<B>) - Constructor for class org.elasticsearch.search.aggregations.DelayedBucket
-
Build a delayed bucket.
- DelayedBucketReducer<B extends MultiBucketsAggregation.Bucket> - Class in org.elasticsearch.search.aggregations.bucket
-
Class for reducing a list of
DelayedBucketReducer
to a singleInternalAggregations
and the number of documents in a delayable fashion. - DelayedBucketReducer(B, AggregationReduceContext) - Constructor for class org.elasticsearch.search.aggregations.bucket.DelayedBucketReducer
- delayedDecision(ShardRouting, RoutingAllocation, Logger, List<NodeAllocationResult>) - Static method in class org.elasticsearch.gateway.ReplicaShardAllocator
-
Return a delayed decision, filling in the right amount of remaining time if decisions are debugged/explained.
- delayPrepareBulkRequest(ThreadPool, long, int, AbstractRunnable) - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
-
Schedule prepareBulkRequestRunnable to run after some delay.
- DelayRecoveryException - Exception in org.elasticsearch.indices.recovery
-
An exception marking that this recovery attempt should be ignored (since probably, we already recovered).
- DelayRecoveryException(String) - Constructor for exception org.elasticsearch.indices.recovery.DelayRecoveryException
- DelayRecoveryException(StreamInput) - Constructor for exception org.elasticsearch.indices.recovery.DelayRecoveryException
- delDocCount - Variable in class org.elasticsearch.index.engine.Segment
- delegate - Variable in class org.elasticsearch.action.DelegatingActionListener
- delegate - Variable in class org.elasticsearch.action.support.AbstractThreadedActionListener
- delegate - Variable in class org.elasticsearch.common.io.stream.FilterStreamInput
- delegate - Variable in class org.elasticsearch.index.mapper.BlockLoader.Delegating
- delegate() - Method in class org.elasticsearch.index.codec.CodecService.DeduplicateFieldInfosCodec
- DelegateDocValuesField - Class in org.elasticsearch.script.field
-
A default
Field
to provideScriptDocValues
for fields that are not supported by the script fields api. - DelegateDocValuesField(ScriptDocValues<?>, String) - Constructor for class org.elasticsearch.script.field.DelegateDocValuesField
- delegateFailure(BiConsumer<ActionListener<Response>, T>) - Method in interface org.elasticsearch.action.ActionListener
-
Creates a new listener, wrapping this one, that overrides
ActionListener.onResponse(Response)
handling with the givenbc
consumer. - delegateFailureAndWrap(CheckedBiConsumer<ActionListener<Response>, T, ? extends Exception>) - Method in interface org.elasticsearch.action.ActionListener
-
Same as
ActionListener.delegateFailure(BiConsumer)
except that any failure thrown bybc
or the original listener'sActionListener.onResponse(Response)
will be passed to the original listener'sActionListener.onFailure(Exception)
. - delegateFailureIgnoreResponseAndWrap(CheckedConsumer<ActionListener<Response>, ? extends Exception>) - Method in interface org.elasticsearch.action.ActionListener
-
Same as
ActionListener.delegateFailureAndWrap(CheckedBiConsumer)
except that the response is ignored and not passed to the delegate. - delegateResponse(BiConsumer<ActionListener<Response>, Exception>) - Method in interface org.elasticsearch.action.ActionListener
-
Creates a listener that delegates all responses it receives to this instance.
- Delegating(BlockLoader) - Constructor for class org.elasticsearch.index.mapper.BlockLoader.Delegating
- DelegatingActionListener<Response,
DelegateResponse> - Class in org.elasticsearch.action -
A wrapper around an
ActionListener
L
that by default delegates failures toL
'sActionListener.onFailure(java.lang.Exception)
method. - DelegatingActionListener(ActionListener<DelegateResponse>) - Constructor for class org.elasticsearch.action.DelegatingActionListener
- DelegatingNodeConnectionListener() - Constructor for class org.elasticsearch.transport.ConnectionManager.DelegatingNodeConnectionListener
- DelegatingRoutingChangesObserver(RoutingChangesObserver...) - Constructor for class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- delegatingTo() - Method in class org.elasticsearch.index.mapper.BlockLoader.Delegating
- delete() - Method in class org.elasticsearch.common.lucene.FilterIndexCommit
- delete(DeleteIndexRequest) - Method in class org.elasticsearch.client.internal.IndicesAdminClient
- delete(DeleteIndexRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.client.internal.IndicesAdminClient
- delete(DeleteRequest) - Method in interface org.elasticsearch.client.internal.Client
-
Deletes a document from the index based on the index and id.
- delete(DeleteRequest) - Method in class org.elasticsearch.client.internal.support.AbstractClient
- delete(DeleteRequest, ActionListener<DeleteResponse>) - Method in interface org.elasticsearch.client.internal.Client
-
Deletes a document from the index based on the index and id.
- delete(DeleteRequest, ActionListener<DeleteResponse>) - Method in class org.elasticsearch.client.internal.support.AbstractClient
- delete(DeletePipelineRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.ingest.IngestService
-
Deletes the pipeline specified by id in the request.
- delete(OperationPurpose) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Deletes this container and all its contents from the repository.
- delete(OperationPurpose) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- delete(OperationPurpose) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- delete(Engine.Delete) - Method in class org.elasticsearch.index.engine.Engine
-
Perform document delete operation on the engine
- delete(Engine.Delete) - Method in class org.elasticsearch.index.engine.InternalEngine
- delete(Engine.Delete) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- Delete(String, long, long) - Constructor for class org.elasticsearch.index.translog.Translog.Delete
-
utility for testing
- Delete(String, long, long, long) - Constructor for class org.elasticsearch.index.translog.Translog.Delete
- Delete(String, BytesRef, long) - Constructor for class org.elasticsearch.index.engine.Engine.Delete
- Delete(String, BytesRef, long, long, long, VersionType, Engine.Operation.Origin, long, long, long) - Constructor for class org.elasticsearch.index.engine.Engine.Delete
- Delete(Engine.Delete, Engine.DeleteResult) - Constructor for class org.elasticsearch.index.translog.Translog.Delete
- DELETE - Enum constant in enum class org.elasticsearch.action.DocWriteRequest.OpType
-
Deletes a document
- DELETE - Enum constant in enum class org.elasticsearch.index.engine.Engine.Operation.TYPE
- DELETE - Enum constant in enum class org.elasticsearch.index.translog.Translog.Operation.Type
- DELETE - Enum constant in enum class org.elasticsearch.rest.RestRequest.Method
- deleteAll() - Method in class org.elasticsearch.gateway.MetaStateService
-
Removes manifest file, global metadata and all index metadata
- deleteAll(Path[]) - Static method in class org.elasticsearch.gateway.PersistedClusterStateService
-
Remove all persisted cluster states from the given data paths, for use in tests.
- deleteAny(CharSequence, String) - Static method in class org.elasticsearch.common.Strings
-
Delete any character in a given CharSequence.
- deleteAny(String, String) - Static method in class org.elasticsearch.common.Strings
-
Delete any character in a given String.
- deleteBlobsIgnoringIfNotExists(OperationPurpose, Iterator<String>) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Deletes the blobs with given names.
- deleteBlobsIgnoringIfNotExists(OperationPurpose, Iterator<String>) - Method in interface org.elasticsearch.common.blobstore.BlobStore
-
Delete all the provided blobs from the blob store.
- deleteBlobsIgnoringIfNotExists(OperationPurpose, Iterator<String>) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- deleteBlobsIgnoringIfNotExists(OperationPurpose, Iterator<String>) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
- deleteBlobsIgnoringIfNotExists(OperationPurpose, Iterator<String>) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- DeleteByQueryAction - Class in org.elasticsearch.index.reindex
- DeleteByQueryRequest - Class in org.elasticsearch.index.reindex
-
Creates a new
DeleteByQueryRequest
that uses scrolling and bulk requests to delete all documents matching the query. - DeleteByQueryRequest() - Constructor for class org.elasticsearch.index.reindex.DeleteByQueryRequest
- DeleteByQueryRequest(String...) - Constructor for class org.elasticsearch.index.reindex.DeleteByQueryRequest
- DeleteByQueryRequest(StreamInput) - Constructor for class org.elasticsearch.index.reindex.DeleteByQueryRequest
- DeleteByQueryRequestBuilder - Class in org.elasticsearch.index.reindex
- DeleteByQueryRequestBuilder(ElasticsearchClient) - Constructor for class org.elasticsearch.index.reindex.DeleteByQueryRequestBuilder
- DELETED - Enum constant in enum class org.elasticsearch.action.DocWriteResponse.Result
- DELETED - Enum constant in enum class org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices.IndexRemovalReason
-
The index is deleted.
- DELETED - Enum constant in enum class org.elasticsearch.synonyms.SynonymsManagementAPIService.UpdateSynonymsResultStatus
- DELETED_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- DELETED_SHARD_GEN - Static variable in class org.elasticsearch.repositories.ShardGenerations
-
Special generation that signifies that the shard has been deleted from the repository.
- DeleteDanglingIndexRequest - Class in org.elasticsearch.action.admin.indices.dangling.delete
-
Represents a request to delete a particular dangling index, specified by its UUID.
- DeleteDanglingIndexRequest(String, boolean) - Constructor for class org.elasticsearch.action.admin.indices.dangling.delete.DeleteDanglingIndexRequest
- DeleteDanglingIndexRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.dangling.delete.DeleteDanglingIndexRequest
- deleteDanglingIndicesInfo() - Method in class org.elasticsearch.index.IndexService
- DeleteDataStreamAction - Class in org.elasticsearch.action.datastreams
- DeleteDataStreamAction.Request - Class in org.elasticsearch.action.datastreams
- deletedRepositories - Variable in class org.elasticsearch.repositories.RepositoriesService.UnregisterRepositoryTask
- deleteIndexDirectorySafe(Index, long, IndexSettings, Consumer<Path[]>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Deletes an indexes data directory recursively iff all of the indexes shards locks were successfully acquired.
- deleteIndexDirectoryUnderLock(Index, IndexSettings, Consumer<Path[]>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Deletes an indexes data directory recursively.
- DeleteIndexRequest - Class in org.elasticsearch.action.admin.indices.delete
-
A request to delete an index.
- DeleteIndexRequest() - Constructor for class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- DeleteIndexRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
-
Constructs a new delete index request for the specified index.
- DeleteIndexRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
-
Constructs a new delete index request for the specified indices.
- DeleteIndexRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- DeleteIndexRequestBuilder - Class in org.elasticsearch.action.admin.indices.delete
- DeleteIndexRequestBuilder(ElasticsearchClient, String...) - Constructor for class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequestBuilder
- DeleteIndexTemplateRequest - Class in org.elasticsearch.action.admin.indices.template.delete
-
A request to delete an index template.
- DeleteIndexTemplateRequest() - Constructor for class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
- DeleteIndexTemplateRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
-
Constructs a new delete index request for the specified name.
- DeleteIndexTemplateRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
- DeleteIndexTemplateRequestBuilder - Class in org.elasticsearch.action.admin.indices.template.delete
- DeleteIndexTemplateRequestBuilder(ElasticsearchClient, String) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequestBuilder
- deleteIndices(ClusterState, Set<Index>, Settings) - Static method in class org.elasticsearch.cluster.metadata.MetadataDeleteIndexService
-
Delete some indices from the cluster state.
- deleteIndices(TimeValue, TimeValue, Set<Index>, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataDeleteIndexService
- deleteLeftoverShardDirectory(Logger, NodeEnvironment, ShardLock, IndexSettings, Consumer<Path[]>) - Static method in class org.elasticsearch.index.shard.ShardPath
-
This method tries to delete left-over shards where the index name has been reused but the UUID is different to allow the new shard to be allocated.
- deleteMetaState(Path...) - Static method in class org.elasticsearch.gateway.MetadataStateFormat
-
Deletes all meta state directories recursively for the given data locations
- deletePipeline(DeletePipelineRequest) - Method in class org.elasticsearch.client.internal.ClusterAdminClient
- deletePipeline(DeletePipelineRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.client.internal.ClusterAdminClient
- DeletePipelineClusterStateUpdateTask(String) - Constructor for class org.elasticsearch.ingest.IngestService.DeletePipelineClusterStateUpdateTask
-
Used by the
ReservedPipelineAction
- DeletePipelineRequest - Class in org.elasticsearch.action.ingest
- DeletePipelineRequest(String) - Constructor for class org.elasticsearch.action.ingest.DeletePipelineRequest
- DeletePipelineRequest(StreamInput) - Constructor for class org.elasticsearch.action.ingest.DeletePipelineRequest
- DeletePipelineRequestBuilder - Class in org.elasticsearch.action.ingest
- DeletePipelineRequestBuilder(ElasticsearchClient, String) - Constructor for class org.elasticsearch.action.ingest.DeletePipelineRequestBuilder
- DeletePipelineTransportAction - Class in org.elasticsearch.action.ingest
- DeletePipelineTransportAction(ThreadPool, IngestService, TransportService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.ingest.DeletePipelineTransportAction
- deleteQuiet(String...) - Method in class org.elasticsearch.index.store.Store
- deleteRepository(DeleteRepositoryRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.client.internal.ClusterAdminClient
- DeleteRepositoryRequest - Class in org.elasticsearch.action.admin.cluster.repositories.delete
-
Unregister repository request.
- DeleteRepositoryRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
- DeleteRepositoryRequest(TimeValue, TimeValue, String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
-
Constructs a new unregister repository request with the provided name.
- DeleteRepositoryRequestBuilder - Class in org.elasticsearch.action.admin.cluster.repositories.delete
-
Builder for unregister repository request
- DeleteRepositoryRequestBuilder(ElasticsearchClient, TimeValue, TimeValue, String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequestBuilder
-
Constructs unregister repository request builder with specified repository name
- DeleteRequest - Class in org.elasticsearch.action.delete
-
A request to delete a document from an index based on its type and id.
- DeleteRequest() - Constructor for class org.elasticsearch.action.delete.DeleteRequest
- DeleteRequest(String) - Constructor for class org.elasticsearch.action.delete.DeleteRequest
-
Constructs a new delete request against the specified index.
- DeleteRequest(String, String) - Constructor for class org.elasticsearch.action.delete.DeleteRequest
-
Constructs a new delete request against the specified index and id.
- DeleteRequest(StreamInput) - Constructor for class org.elasticsearch.action.delete.DeleteRequest
- DeleteRequest(ShardId, StreamInput) - Constructor for class org.elasticsearch.action.delete.DeleteRequest
- DeleteRequestBuilder - Class in org.elasticsearch.action.delete
-
A delete document action request builder.
- DeleteRequestBuilder(ElasticsearchClient, String) - Constructor for class org.elasticsearch.action.delete.DeleteRequestBuilder
- DeleteResponse - Class in org.elasticsearch.action.delete
-
The response of the delete action.
- DeleteResponse(StreamInput) - Constructor for class org.elasticsearch.action.delete.DeleteResponse
- DeleteResponse(ShardId, String, long, long, long, boolean) - Constructor for class org.elasticsearch.action.delete.DeleteResponse
- DeleteResponse(ShardId, StreamInput) - Constructor for class org.elasticsearch.action.delete.DeleteResponse
- DeleteResponse.Builder - Class in org.elasticsearch.action.delete
-
Builder class for
DeleteResponse
. - DeleteResult - Class in org.elasticsearch.common.blobstore
-
The result of deleting multiple blobs from a
BlobStore
. - DeleteResult(long, long) - Constructor for class org.elasticsearch.common.blobstore.DeleteResult
- DeleteResult(long, long, long, boolean, String) - Constructor for class org.elasticsearch.index.engine.Engine.DeleteResult
- DeleteResult(Exception, long, long, long, boolean, String) - Constructor for class org.elasticsearch.index.engine.Engine.DeleteResult
- DeleteResult(Exception, long, long, String) - Constructor for class org.elasticsearch.index.engine.Engine.DeleteResult
-
use in case of the delete operation failed before getting to internal engine
- deletes - Variable in class org.elasticsearch.cluster.DiffableUtils.MapDiff
- deleteScript(String) - Method in class org.elasticsearch.script.ScriptMetadata.Builder
-
Delete a script from the existing stored scripts based on a user-specified id.
- deleteShard(String, String) - Method in class org.elasticsearch.cluster.routing.IndexRouting
-
Called when deleting a document to generate the shard id that should contain a document with the provided
_id
and (optional)_routing
. - deleteShard(String, String) - Method in class org.elasticsearch.cluster.routing.IndexRouting.ExtractFromSource
- deleteShardDirectorySafe(ShardId, IndexSettings, Consumer<Path[]>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Deletes a shard data directory iff the shards locks were successfully acquired.
- deleteShardDirectoryUnderLock(ShardLock, IndexSettings, Consumer<Path[]>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Deletes a shard data directory.
- deleteShardStore(String, ShardLock, IndexSettings) - Method in interface org.elasticsearch.index.IndexService.ShardStoreDeleter
- deleteShardStore(String, ShardLock, IndexSettings) - Method in class org.elasticsearch.indices.IndicesService
-
Deletes the shard with an already acquired shard lock.
- deleteShardStore(String, ShardId, ClusterState) - Method in class org.elasticsearch.indices.IndicesService
-
This method deletes the shard contents on disk for the given shard ID.
- deleteSnapshot(DeleteSnapshotRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.client.internal.ClusterAdminClient
- DeleteSnapshotRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.delete
-
Delete snapshot request
- DeleteSnapshotRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
- DeleteSnapshotRequest(TimeValue, String, String...) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
-
Constructs a new delete snapshots request with repository and snapshot names
- DeleteSnapshotRequestBuilder - Class in org.elasticsearch.action.admin.cluster.snapshots.delete
-
Delete snapshot request builder
- DeleteSnapshotRequestBuilder(ElasticsearchClient, TimeValue, String, String...) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequestBuilder
-
Constructs delete snapshot request builder with specified repository and snapshot names
- deleteSnapshots(Collection<SnapshotId>, long, IndexVersion, ActionListener<RepositoryData>, Runnable) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- deleteSnapshots(Collection<SnapshotId>, long, IndexVersion, ActionListener<RepositoryData>, Runnable) - Method in class org.elasticsearch.repositories.FilterRepository
- deleteSnapshots(Collection<SnapshotId>, long, IndexVersion, ActionListener<RepositoryData>, Runnable) - Method in class org.elasticsearch.repositories.InvalidRepository
- deleteSnapshots(Collection<SnapshotId>, long, IndexVersion, ActionListener<RepositoryData>, Runnable) - Method in interface org.elasticsearch.repositories.Repository
-
Deletes snapshots
- deleteSnapshots(Collection<SnapshotId>, long, IndexVersion, ActionListener<RepositoryData>, Runnable) - Method in class org.elasticsearch.repositories.UnknownTypeRepository
- deleteSnapshots(DeleteSnapshotRequest, ActionListener<Void>) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Deletes snapshots from the repository.
- deleteStoredScript(ClusterService, DeleteStoredScriptRequest, ActionListener<AcknowledgedResponse>) - Static method in class org.elasticsearch.script.ScriptService
- DeleteStoredScriptRequest - Class in org.elasticsearch.action.admin.cluster.storedscripts
- DeleteStoredScriptRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- DeleteStoredScriptRequest(TimeValue, TimeValue, String) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- deleteSubDirectories(Path...) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Deletes all subdirectories in the given path recursively
- deleteSynonymRule(String, String, ActionListener<SynonymsManagementAPIService.SynonymsReloadResult>) - Method in class org.elasticsearch.synonyms.SynonymsManagementAPIService
- DeleteSynonymRuleAction - Class in org.elasticsearch.action.synonyms
- DeleteSynonymRuleAction() - Constructor for class org.elasticsearch.action.synonyms.DeleteSynonymRuleAction
- DeleteSynonymRuleAction.Request - Class in org.elasticsearch.action.synonyms
- DeleteSynonymsAction - Class in org.elasticsearch.action.synonyms
- DeleteSynonymsAction() - Constructor for class org.elasticsearch.action.synonyms.DeleteSynonymsAction
- DeleteSynonymsAction.Request - Class in org.elasticsearch.action.synonyms
- deleteSynonymsSet(String, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.synonyms.SynonymsManagementAPIService
- deleteTemplate(DeleteIndexTemplateRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.client.internal.IndicesAdminClient
- deleteTemporaryApmConfig(JvmInfo, BiConsumer<Exception, Path>) - Static method in class org.elasticsearch.node.Node
-
If the JVM was started with the Elastic APM agent and a config file argument was specified, then delete the config file.
- deleteTombstone(String) - Static method in class org.elasticsearch.index.mapper.ParsedDocument
-
Create a delete tombstone document, which will be used in soft-update methods.
- deleteUnassignedIndex(String, IndexMetadata, ClusterState) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
-
Deletes an index that is not assigned to this node.
- deleteUnassignedIndex(String, IndexMetadata, ClusterState) - Method in class org.elasticsearch.indices.IndicesService
-
Deletes an index that is not assigned to this node.
- deleteUnknownOrInvalidSettings(Settings, Consumer<Map.Entry<String, String>>, BiConsumer<Map.Entry<String, String>, IllegalArgumentException>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Deletes invalid or unknown settings.
- deletionsInProgressCount() - Method in record class org.elasticsearch.cluster.ClusterSnapshotStats
-
Returns the value of the
deletionsInProgressCount
record component. - deletionStrategyForOperation(Engine.Delete) - Method in class org.elasticsearch.index.engine.InternalEngine
- delimitedListToStringArray(String, String) - Static method in class org.elasticsearch.common.Strings
-
Take a String which is a delimited list and convert it to a String array.
- delimitedListToStringArray(String, String, String) - Static method in class org.elasticsearch.common.Strings
-
Take a String which is a delimited list and convert it to a String array.
- DELIMITER - Static variable in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- DELIMITER_BYTE - Static variable in class org.elasticsearch.index.mapper.Uid
- delta() - Method in class org.elasticsearch.search.aggregations.metrics.CompensatedSum
-
The correction term.
- delta(DiscoveryNodes) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns the changes comparing this nodes to the provided nodes.
- DenormalizedCosineFloatVectorValues - Class in org.elasticsearch.index.mapper.vectors
-
Provides the denormalized vectors.
- DenormalizedCosineFloatVectorValues(FloatVectorValues, NumericDocValues) - Constructor for class org.elasticsearch.index.mapper.vectors.DenormalizedCosineFloatVectorValues
- DENSE_VECTOR - Static variable in interface org.elasticsearch.search.DocValueFormat
- DenseOffHeapVectorValues(int, int, float[], float, BinaryQuantizer, VectorSimilarityFunction, FlatVectorsScorer, IndexInput) - Constructor for class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues.DenseOffHeapVectorValues
- denseVector() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- denseVector(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- DenseVector - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- DenseVector - Interface in org.elasticsearch.script.field.vectors
-
DenseVector value type for the painless.
- DenseVectorDocValuesField - Class in org.elasticsearch.script.field.vectors
- DenseVectorDocValuesField(String, DenseVectorFieldMapper.ElementType) - Constructor for class org.elasticsearch.script.field.vectors.DenseVectorDocValuesField
- DenseVectorFieldMapper - Class in org.elasticsearch.index.mapper.vectors
-
A
FieldMapper
for indexing a dense vector of floats. - DenseVectorFieldMapper.Builder - Class in org.elasticsearch.index.mapper.vectors
- DenseVectorFieldMapper.DenseVectorFieldType - Class in org.elasticsearch.index.mapper.vectors
- DenseVectorFieldMapper.ElementType - Enum Class in org.elasticsearch.index.mapper.vectors
- DenseVectorFieldMapper.VectorSimilarity - Enum Class in org.elasticsearch.index.mapper.vectors
- DenseVectorFieldStats - Class in org.elasticsearch.action.admin.cluster.stats
-
Holds enhanced stats about a dense vector mapped field.
- DenseVectorFieldType(String, IndexVersion, DenseVectorFieldMapper.ElementType, Integer, boolean, DenseVectorFieldMapper.VectorSimilarity, DenseVectorFieldMapper.IndexOptions, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.DenseVectorFieldType
- DenseVectorFunction(ScoreScript, DenseVectorDocValuesField) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.DenseVectorFunction
- denseVectorLength(IndexVersion, BytesRef) - Static method in class org.elasticsearch.index.mapper.vectors.VectorEncoderDecoder
- DenseVectorQuery - Class in org.elasticsearch.search.vectors
-
Exact knn query.
- DenseVectorQuery(String) - Constructor for class org.elasticsearch.search.vectors.DenseVectorQuery
- DenseVectorQuery.Bytes - Class in org.elasticsearch.search.vectors
- DenseVectorQuery.Floats - Class in org.elasticsearch.search.vectors
- DenseVectorScriptDocValues - Class in org.elasticsearch.index.mapper.vectors
- DenseVectorScriptDocValues(DenseVectorScriptDocValues.DenseVectorSupplier, int) - Constructor for class org.elasticsearch.index.mapper.vectors.DenseVectorScriptDocValues
- DenseVectorScriptDocValues.DenseVectorSupplier - Interface in org.elasticsearch.index.mapper.vectors
- denseVectorStats - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- denseVectorStats() - Method in class org.elasticsearch.index.shard.IndexShard
- denseVectorStats(IndexReader, List<String>) - Method in class org.elasticsearch.index.engine.Engine
- denseVectorStats(MappingLookup) - Method in class org.elasticsearch.index.engine.Engine
-
Returns the
DenseVectorStats
for this engine - DenseVectorStats - Class in org.elasticsearch.index.shard
-
Statistics about indexed dense vector
- DenseVectorStats() - Constructor for class org.elasticsearch.index.shard.DenseVectorStats
- DenseVectorStats(long) - Constructor for class org.elasticsearch.index.shard.DenseVectorStats
- DenseVectorStats(StreamInput) - Constructor for class org.elasticsearch.index.shard.DenseVectorStats
- dependencies() - Method in interface org.elasticsearch.reservedstate.ReservedClusterStateHandler
-
List of dependent handler names for this handler.
- Dependency<T> - Class in org.elasticsearch.injection.guice.spi
-
A variable that can be resolved by an injector.
- DEPLOYMENT_MANAGEMENT - Enum constant in enum class org.elasticsearch.health.ImpactArea
- DEPRECATE_SOURCE_MODE_MAPPER - Static variable in class org.elasticsearch.index.IndexVersions
- deprecated() - Method in class org.elasticsearch.cluster.metadata.ComponentTemplate
- deprecated() - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Deprecates the entire parameter.
- deprecated(Boolean) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.Builder
- deprecated(String, Level, RestApiVersion) - Method in class org.elasticsearch.rest.RestHandler.Route.RouteBuilder
-
Marks that the route being built has been deprecated (for some reason -- the deprecationMessage), and notes the major version in which that deprecation occurred.
- deprecated(String, RestApiVersion) - Method in class org.elasticsearch.rest.RestHandler.Route.RouteBuilder
-
Marks that the route being built has been deprecated (for some reason -- the deprecationMessage), and notes the major version in which that deprecation occurred.
- Deprecated - Enum constant in enum class org.elasticsearch.common.settings.Setting.Property
-
mark this setting as deprecated (critical level)
- DEPRECATED_KEY - Static variable in class org.elasticsearch.ingest.Pipeline
- DEPRECATED_LONG_TIMEZONES - Static variable in class org.elasticsearch.common.time.DateUtils
- DEPRECATED_ROUTE_KEY - Static variable in class org.elasticsearch.rest.DeprecationRestHandler
- DeprecatedMessage - Class in org.elasticsearch.common.logging
-
A logger message used by
DeprecationLogger
, enriched with fields named following ECS conventions. - DeprecatedMessage() - Constructor for class org.elasticsearch.common.logging.DeprecatedMessage
- DeprecatedWarning - Enum constant in enum class org.elasticsearch.common.settings.Setting.Property
-
mark this setting as deprecated (warning level)
- DEPRECATION_LOGGER - Static variable in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- DEPRECATION_WARNING - Static variable in class org.elasticsearch.index.mapper.SourceFieldMapper
- DEPRECATION_WARNING - Static variable in class org.elasticsearch.rest.action.admin.indices.RestPutIndexTemplateAction
- DeprecationCategory - Enum Class in org.elasticsearch.common.logging
-
Deprecation log messages are categorised so that consumers of the logs can easily aggregate them.
- deprecationLogger - Static variable in class org.elasticsearch.index.mapper.FieldMapper
- DeprecationLogger - Class in org.elasticsearch.common.logging
-
A logger that logs deprecation notices.
- deprecationMessage() - Method in class org.elasticsearch.script.ScriptService.ContextSettings
-
deprecation message for implicitly using the context cache
- DeprecationRestHandler - Class in org.elasticsearch.rest
-
DeprecationRestHandler
provides a proxy for any existingRestHandler
so that usage of the handler can be logged using theDeprecationLogger
. - DeprecationRestHandler(RestHandler, RestRequest.Method, String, Level, String, DeprecationLogger, boolean) - Constructor for class org.elasticsearch.rest.DeprecationRestHandler
-
Create a
DeprecationRestHandler
that encapsulates thehandler
using thedeprecationLogger
to log deprecationwarning
. - dePrioritizeNode(String) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.OrderedShardsIterator
- DEPTH_FIRST - Enum constant in enum class org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
-
Creates buckets and delegates to child aggregators in a single pass over the matching documents
- deque(Recycler.C<T>, int) - Static method in enum class org.elasticsearch.common.recycler.Recyclers
-
Return a recycler based on a deque.
- dequeFactory(Recycler.C<T>, int) - Static method in enum class org.elasticsearch.common.recycler.Recyclers
-
Return a recycler based on a deque.
- DequeRecycler<T> - Class in org.elasticsearch.common.recycler
- DequeRecycler(Recycler.C<T>, Deque<T>, int) - Constructor for class org.elasticsearch.common.recycler.DequeRecycler
- deriveCollectorName(Collector) - Method in class org.elasticsearch.search.profile.query.InternalProfileCollector
-
Creates a human-friendly representation of the Collector name.
- DESC - Enum constant in enum class org.elasticsearch.search.sort.SortOrder
-
Descending order.
- descendsFromGlobalAggregator(Aggregator) - Static method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
- descendsFromNestedAggregator(Aggregator) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- describe() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator.CollectorSource
-
A description of the strategy to include in profile results.
- describe() - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator.ValuesSourceCollectorSource
- describeFloodStageThreshold(ByteSizeValue, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- describeFloodStageWatermark() - Method in record class org.elasticsearch.health.metadata.HealthMetadata.Disk
- describeFrozenFloodStageThreshold(ByteSizeValue, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- describeFrozenFloodStageWatermark() - Method in record class org.elasticsearch.health.metadata.HealthMetadata.Disk
- describeHighThreshold(ByteSizeValue, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- describeHighWatermark() - Method in record class org.elasticsearch.health.metadata.HealthMetadata.Disk
- describeLowThreshold(ByteSizeValue, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- describeTasks(List<T>) - Method in interface org.elasticsearch.cluster.ClusterStateTaskExecutor
-
Builds a concise description of a list of tasks (to be used in logging etc.).
- description - Variable in class org.elasticsearch.ingest.AbstractProcessor
- description() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- description() - Method in record class org.elasticsearch.tasks.TaskInfo
-
Returns the value of the
description
record component. - DESCRIPTION_KEY - Static variable in class org.elasticsearch.ingest.ConfigurationUtils
- DESCRIPTION_KEY - Static variable in class org.elasticsearch.ingest.Pipeline
- descriptionWithoutAttributes() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- descriptor() - Method in record class org.elasticsearch.plugins.PluginRuntimeInfo
-
Returns the value of the
descriptor
record component. - deserialize(String, NamedXContentRegistry, InputStream) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- desired() - Method in record class org.elasticsearch.action.admin.cluster.allocation.DesiredBalanceResponse.DesiredShards
-
Returns the value of the
desired
record component. - DESIRED_BALANCE_ALLOCATOR - Static variable in class org.elasticsearch.cluster.ClusterModule
- DESIRED_NODE_VERSION_DEPRECATED - Static variable in class org.elasticsearch.cluster.metadata.DesiredNode
- DesiredBalance - Record Class in org.elasticsearch.cluster.routing.allocation.allocator
-
The desired balance of the cluster, indicating which nodes should hold a copy of each shard.
- DesiredBalance(long, Map<ShardId, ShardAssignment>) - Constructor for record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalance
- DesiredBalance(long, Map<ShardId, ShardAssignment>, DesiredBalance.ComputationFinishReason) - Constructor for record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalance
-
Creates an instance of a
DesiredBalance
record class. - DesiredBalanceComputer - Class in org.elasticsearch.cluster.routing.allocation.allocator
-
Holds the desired balance and updates it as the cluster evolves.
- DesiredBalanceComputer(ClusterSettings, ThreadPool, ShardsAllocator) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceComputer
- DesiredBalanceInput - Record Class in org.elasticsearch.cluster.routing.allocation.allocator
-
The input to the desired balance computation.
- DesiredBalanceInput(long, RoutingAllocation, List<ShardRouting>) - Constructor for record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceInput
-
Creates an instance of a
DesiredBalanceInput
record class. - DesiredBalanceReconciler - Class in org.elasticsearch.cluster.routing.allocation.allocator
-
Given the current allocation of shards and the desired balance, performs the next (legal) shard movements towards the goal.
- DesiredBalanceReconciler(ClusterSettings, ThreadPool, MeterRegistry) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceReconciler
- DesiredBalanceRequest - Class in org.elasticsearch.action.admin.cluster.allocation
- DesiredBalanceRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.allocation.DesiredBalanceRequest
- DesiredBalanceRequest(TimeValue) - Constructor for class org.elasticsearch.action.admin.cluster.allocation.DesiredBalanceRequest
- DesiredBalanceResponse - Class in org.elasticsearch.action.admin.cluster.allocation
- DesiredBalanceResponse(DesiredBalanceStats, ClusterBalanceStats, Map<String, Map<Integer, DesiredBalanceResponse.DesiredShards>>, ClusterInfo) - Constructor for class org.elasticsearch.action.admin.cluster.allocation.DesiredBalanceResponse
- DesiredBalanceResponse.DesiredShards - Record Class in org.elasticsearch.action.admin.cluster.allocation
- DesiredBalanceResponse.ShardAssignmentView - Record Class in org.elasticsearch.action.admin.cluster.allocation
- DesiredBalanceResponse.ShardView - Record Class in org.elasticsearch.action.admin.cluster.allocation
- DesiredBalanceShardsAllocator - Class in org.elasticsearch.cluster.routing.allocation.allocator
-
A
ShardsAllocator
which asynchronously refreshes the desired balance held by theDesiredBalanceComputer
and then takes steps towards the desired balance using theDesiredBalanceReconciler
. - DesiredBalanceShardsAllocator(ShardsAllocator, ThreadPool, ClusterService, DesiredBalanceComputer, DesiredBalanceShardsAllocator.DesiredBalanceReconcilerAction, TelemetryProvider) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceShardsAllocator
- DesiredBalanceShardsAllocator(ClusterSettings, ShardsAllocator, ThreadPool, ClusterService, DesiredBalanceShardsAllocator.DesiredBalanceReconcilerAction, TelemetryProvider) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceShardsAllocator
- DesiredBalanceShardsAllocator.DesiredBalanceReconcilerAction - Interface in org.elasticsearch.cluster.routing.allocation.allocator
- DesiredBalanceStats - Record Class in org.elasticsearch.cluster.routing.allocation.allocator
- DesiredBalanceStats(long, boolean, long, long, long, long, long, long, long, long, long, long) - Constructor for record class org.elasticsearch.cluster.routing.allocation.allocator.DesiredBalanceStats
-
Creates an instance of a
DesiredBalanceStats
record class. - desiredNode() - Method in record class org.elasticsearch.cluster.metadata.DesiredNodeWithStatus
-
Returns the value of the
desiredNode
record component. - DesiredNode - Class in org.elasticsearch.cluster.metadata
- DesiredNode(Settings, double, ByteSizeValue, ByteSizeValue) - Constructor for class org.elasticsearch.cluster.metadata.DesiredNode
- DesiredNode(Settings, double, ByteSizeValue, ByteSizeValue, String) - Constructor for class org.elasticsearch.cluster.metadata.DesiredNode
-
Deprecated.
- DesiredNode(Settings, DesiredNode.ProcessorsRange, ByteSizeValue, ByteSizeValue) - Constructor for class org.elasticsearch.cluster.metadata.DesiredNode
- DesiredNode(Settings, DesiredNode.ProcessorsRange, ByteSizeValue, ByteSizeValue, String) - Constructor for class org.elasticsearch.cluster.metadata.DesiredNode
-
Deprecated.
- DesiredNode.ProcessorsRange - Record Class in org.elasticsearch.cluster.metadata
- desiredNodes() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- DesiredNodes - Class in org.elasticsearch.cluster.metadata
-
Desired nodes represents the cluster topology that the operator of the cluster is aiming for.
- DesiredNodes.SerializationContext - Enum Class in org.elasticsearch.cluster.metadata
- DesiredNodesMetadata - Class in org.elasticsearch.cluster.metadata
- DesiredNodesMetadata(DesiredNodes) - Constructor for class org.elasticsearch.cluster.metadata.DesiredNodesMetadata
- DesiredNodesMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.DesiredNodesMetadata
- DesiredNodeWithStatus - Record Class in org.elasticsearch.cluster.metadata
- DesiredNodeWithStatus(DesiredNode, DesiredNodeWithStatus.Status) - Constructor for record class org.elasticsearch.cluster.metadata.DesiredNodeWithStatus
-
Creates an instance of a
DesiredNodeWithStatus
record class. - DesiredNodeWithStatus.Status - Enum Class in org.elasticsearch.cluster.metadata
- DesiredShards(List<DesiredBalanceResponse.ShardView>, DesiredBalanceResponse.ShardAssignmentView) - Constructor for record class org.elasticsearch.action.admin.cluster.allocation.DesiredBalanceResponse.DesiredShards
-
Creates an instance of a
DesiredShards
record class. - destination() - Method in class org.elasticsearch.index.reindex.ReindexRequestBuilder
- destination(String) - Method in class org.elasticsearch.index.reindex.ReindexRequestBuilder
-
Set the destination index.
- destroy(T) - Method in class org.elasticsearch.common.recycler.AbstractRecyclerC
- destroy(T) - Method in interface org.elasticsearch.common.recycler.Recycler.C
-
Destroy the data.
- DestructiveOperations - Class in org.elasticsearch.action.support
-
Helper for dealing with destructive operations and wildcard usage.
- DestructiveOperations(Settings, ClusterSettings) - Constructor for class org.elasticsearch.action.support.DestructiveOperations
- DetachClusterCommand - Class in org.elasticsearch.cluster.coordination
- DetachClusterCommand() - Constructor for class org.elasticsearch.cluster.coordination.DetachClusterCommand
- detail() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Response
- DetailAnalyzeResponse(AnalyzeAction.AnalyzeTokenList) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.DetailAnalyzeResponse
- DetailAnalyzeResponse(AnalyzeAction.CharFilteredText[], AnalyzeAction.AnalyzeTokenList, AnalyzeAction.AnalyzeTokenList[]) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.DetailAnalyzeResponse
- detailed() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
-
True if detailed flag is set, false otherwise.
- detailed(boolean) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
-
Set value of the detailed flag.
- detailedErrorsEnabled() - Method in record class org.elasticsearch.http.HttpHandlingSettings
-
Returns the value of the
detailedErrorsEnabled
record component. - detailedErrorsEnabled() - Method in class org.elasticsearch.rest.AbstractRestChannel
- detailedErrorsEnabled() - Method in interface org.elasticsearch.rest.RestChannel
- details() - Method in record class org.elasticsearch.cluster.coordination.CoordinationDiagnosticsService.CoordinationDiagnosticsResult
-
Returns the value of the
details
record component. - details() - Method in record class org.elasticsearch.cluster.routing.UnassignedInfo
-
Builds a string representation of the message and the failure if exists.
- details() - Method in record class org.elasticsearch.health.HealthIndicatorResult
-
Returns the value of the
details
record component. - details() - Method in record class org.elasticsearch.health.SimpleHealthIndicatorDetails
-
Returns the value of the
details
record component. - DETAILS_FIELD - Static variable in class org.elasticsearch.action.search.SearchResponse.Clusters
- detect(Writer) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- detectNoop() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Should this update attempt to detect if it is a noop? Defaults to true.
- detectNoop(boolean) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Should this update attempt to detect if it is a noop? Defaults to true.
- determineCurrentHealth() - Method in class org.elasticsearch.health.node.tracker.DiskHealthTracker
-
Determines the disk health of this node by checking if it exceeds the thresholds defined in the health metadata.
- determineCurrentHealth() - Method in class org.elasticsearch.health.node.tracker.HealthTracker
-
Determine the health info for this health check.
- determineCurrentHealth() - Method in class org.elasticsearch.health.node.tracker.RepositoriesHealthTracker
-
Determine the health of the repositories on this node.
- DeviceStats(int, int, String, long, long, long, long, long, FsInfo.DeviceStats) - Constructor for class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- DeviceStats(StreamInput) - Constructor for class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- dfs() - Method in class org.elasticsearch.search.query.QuerySearchRequest
- DFS - Enum constant in enum class org.elasticsearch.search.SearchService.ResultsType
- DFS_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
-
Part of DFS_QUERY_THEN_FETCH, which fetches distributed term frequencies and executes KNN.
- DFS_QUERY_THEN_FETCH - Enum constant in enum class org.elasticsearch.action.search.SearchType
-
Same as
SearchType.QUERY_THEN_FETCH
, except for an initial scatter phase which goes and computes the distributed term frequencies for more accurate scoring. - DfsKnnResults - Class in org.elasticsearch.search.dfs
- DfsKnnResults(String, ScoreDoc[]) - Constructor for class org.elasticsearch.search.dfs.DfsKnnResults
- DfsKnnResults(StreamInput) - Constructor for class org.elasticsearch.search.dfs.DfsKnnResults
- DfsPhase - Class in org.elasticsearch.search.dfs
-
DFS phase of a search request, used to make scoring 100% accurate by collecting additional info from each shard before the query phase.
- DfsPhaseExecutionException - Exception in org.elasticsearch.search.dfs
- DfsPhaseExecutionException(StreamInput) - Constructor for exception org.elasticsearch.search.dfs.DfsPhaseExecutionException
- DfsPhaseExecutionException(SearchShardTarget, String, Throwable) - Constructor for exception org.elasticsearch.search.dfs.DfsPhaseExecutionException
- DfsProfiler - Class in org.elasticsearch.search.profile.dfs
-
This class collects profiling information for the dfs phase and generates a
ProfileResult
for the results of the timing information for statistics collection. - DfsProfiler() - Constructor for class org.elasticsearch.search.profile.dfs.DfsProfiler
- dfsResult() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- dfsResult() - Method in class org.elasticsearch.search.internal.SearchContext
- dfsResult() - Method in class org.elasticsearch.search.rank.RankSearchContext
- DfsSearchResult - Class in org.elasticsearch.search.dfs
- DfsSearchResult(StreamInput) - Constructor for class org.elasticsearch.search.dfs.DfsSearchResult
- DfsSearchResult(ShardSearchContextId, SearchShardTarget, ShardSearchRequest) - Constructor for class org.elasticsearch.search.dfs.DfsSearchResult
- DfsTimingType - Enum Class in org.elasticsearch.search.profile.dfs
- DIAGNOSE_SHARDS_ACTION_GUIDE - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- diagnoseMasterStability(boolean) - Method in class org.elasticsearch.cluster.coordination.CoordinationDiagnosticsService
-
This method calculates the master stability as seen from this node.
- Diagnosis - Record Class in org.elasticsearch.health
-
Details a potential issue that was diagnosed by a
HealthService
. - Diagnosis(Diagnosis.Definition, List<Diagnosis.Resource>) - Constructor for record class org.elasticsearch.health.Diagnosis
-
Creates an instance of a
Diagnosis
record class. - DIAGNOSIS_WAIT_FOR_INITIALIZATION - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- DIAGNOSIS_WAIT_FOR_OR_FIX_DELAYED_SHARDS - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- Diagnosis.Definition - Record Class in org.elasticsearch.health
-
Details a diagnosis - cause and a potential action that a user could take to clear an issue identified by a
HealthService
. - Diagnosis.Resource - Class in org.elasticsearch.health
-
Represents a type of affected resource, together with the resources/abstractions that are affected.
- Diagnosis.Resource.Type - Enum Class in org.elasticsearch.health
- diagnosisList() - Method in record class org.elasticsearch.health.HealthIndicatorResult
-
Returns the value of the
diagnosisList
record component. - diff(String, String) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- diff(M, M, DiffableUtils.KeySerializer<K>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Calculates diff between two Maps of Diffable objects.
- diff(M, M, DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Calculates diff between two Maps of non-diffable objects
- diff(ClusterFeatures) - Method in class org.elasticsearch.cluster.ClusterFeatures
- diff(ClusterState) - Method in class org.elasticsearch.cluster.ClusterState
- diff(ClusterState.Custom) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- diff(DiffableStringMap) - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap
- diff(IndexMetadata) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- diff(Metadata) - Method in class org.elasticsearch.cluster.metadata.Metadata
- diff(Metadata.Custom) - Method in record class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownMetadataCustom
- diff(Metadata.Custom) - Method in class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- diff(Metadata.Custom) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- diff(Metadata.Custom) - Method in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- diff(Metadata.Custom) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- diff(Metadata.Custom) - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- diff(Metadata.Custom) - Method in class org.elasticsearch.ingest.IngestMetadata
- diff(Metadata.Custom) - Method in class org.elasticsearch.script.ScriptMetadata
- diff(Metadata.Custom) - Method in class org.elasticsearch.snapshots.RegisteredPolicySnapshots
- diff(Metadata.Custom) - Method in class org.elasticsearch.upgrades.FeatureMigrationResults
- diff(RoutingTable) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- diff(SnapshotsInProgress.Entry) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- diff(Settings) - Method in class org.elasticsearch.common.settings.Settings
- diff(Settings.Builder, Settings, Settings) - Method in class org.elasticsearch.common.settings.SecureSetting
-
Overrides the diff operation to make this a no-op for secure settings as they shouldn't be returned in a diff
- diff(Settings.Builder, Settings, Settings) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
- diff(Settings.Builder, Settings, Settings) - Method in class org.elasticsearch.common.settings.Setting
-
Add this setting to the builder if it doesn't exists in the source settings.
- diff(Settings, Settings) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Returns a settings object that contains all settings that are not already set in the given source.
- diff(T) - Method in class org.elasticsearch.cluster.AbstractNamedDiffable
- diff(T) - Method in interface org.elasticsearch.cluster.Diffable
-
Returns serializable object representing differences between this and previousState
- diff(T) - Method in interface org.elasticsearch.cluster.SimpleDiffable
- diff(V, V) - Method in class org.elasticsearch.cluster.DiffableUtils.DiffableValueSerializer
- diff(V, V) - Method in class org.elasticsearch.cluster.DiffableUtils.NonDiffableValueSerializer
- diff(V, V) - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Computes diff if this serializer supports diffable values
- Diff<T> - Interface in org.elasticsearch.cluster
-
Represents difference between states of cluster state parts
- Diffable<T> - Interface in org.elasticsearch.cluster
-
Cluster state part, changes in which can be serialized
- DiffableStringMap - Class in org.elasticsearch.cluster.metadata
-
This is a
Map<String, String>
that implements AbstractDiffable so it can be used for cluster state purposes - DiffableStringMap.DiffableStringMapDiff - Class in org.elasticsearch.cluster.metadata
-
Represents differences between two DiffableStringMaps.
- DiffableUtils - Class in org.elasticsearch.cluster
- DiffableUtils.DiffableValueReader<K,
V extends Diffable<V>> - Class in org.elasticsearch.cluster -
Implementation of the ValueSerializer that wraps value and diff readers.
- DiffableUtils.DiffableValueSerializer<K,
V extends Diffable<V>> - Class in org.elasticsearch.cluster -
Serializer for Diffable map values.
- DiffableUtils.KeySerializer<K> - Interface in org.elasticsearch.cluster
-
Provides read and write operations to serialize keys of map
- DiffableUtils.MapDiff<K,
T, M extends Map<K, T>> - Class in org.elasticsearch.cluster -
Represents differences between two maps of objects and is used as base class for different map implementations.
- DiffableUtils.NonDiffableValueSerializer<K,
V> - Class in org.elasticsearch.cluster -
Serializer for non-diffable map values
- DiffableUtils.StringSetValueSerializer<K> - Class in org.elasticsearch.cluster
-
Implementation of ValueSerializer that serializes immutable sets
- DiffableUtils.ValueSerializer<K,
V> - Interface in org.elasticsearch.cluster -
Provides read and write operations to serialize map values.
- DiffableValueReader(Writeable.Reader<V>, Writeable.Reader<Diff<V>>) - Constructor for class org.elasticsearch.cluster.DiffableUtils.DiffableValueReader
- DiffableValueSerializer() - Constructor for class org.elasticsearch.cluster.DiffableUtils.DiffableValueSerializer
- difference(Set<T>, Set<T>) - Static method in class org.elasticsearch.common.util.set.Sets
-
The relative complement, or difference, of the specified left and right set.
- different - Variable in class org.elasticsearch.index.store.Store.RecoveryDiff
-
Files that exist in both snapshots but their they are not identical
- diffs - Variable in class org.elasticsearch.cluster.DiffableUtils.MapDiff
- digest() - Method in class org.elasticsearch.common.hash.Murmur3Hasher
-
Completes the hash of all bytes previously passed to
Murmur3Hasher.update(byte[])
. - digest(InputStream, MessageDigest) - Static method in class org.elasticsearch.common.hash.MessageDigests
-
Reads bytes from the stream and updates the given digest.
- digest(BytesReference, MessageDigest) - Static method in class org.elasticsearch.common.hash.MessageDigests
-
Updates the given digest with the given bytes reference and the returns the result of the digest.
- digestHash() - Method in class org.elasticsearch.common.hash.Murmur3Hasher
-
Completes the hash of all bytes previously passed to
Murmur3Hasher.update(byte[])
. - digestHash(MurmurHash3.Hash128) - Method in class org.elasticsearch.common.hash.Murmur3Hasher
-
Completes the hash of all bytes previously passed to
Murmur3Hasher.update(byte[])
. - digestToString(long) - Static method in class org.elasticsearch.index.store.Store
-
Produces a string representation of the given digest value.
- DII - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- DIM - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- dimension - Variable in class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues
- dimension() - Method in class org.elasticsearch.index.codec.vectors.BinarizedByteVectorValues
-
Return the dimension of the vectors
- dimension() - Method in class org.elasticsearch.index.codec.vectors.ES816BinaryQuantizedVectorsReader.BinarizedVectorValues
- dimension() - Method in class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues
- dimension() - Method in class org.elasticsearch.index.mapper.vectors.DenormalizedCosineFloatVectorValues
- dimension(boolean) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.Builder
- dimension(boolean) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.Builder
- dimension(boolean) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- dimension(boolean) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- DimensionalShapeType - Enum Class in org.elasticsearch.lucene.spatial
-
Like
ShapeType
but has specific types for when the geometry is aGeometryCollection
and more information about what the highest-dimensional sub-shape is. - DimensionBuilder(String) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.DimensionBuilder
- dimensionFields() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- dimensionParam(Function<FieldMapper, Boolean>) - Static method in class org.elasticsearch.index.mapper.TimeSeriesParams
- dimensions() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.RootFlattenedFieldType
- dimensions() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- dimensions() - Method in interface org.elasticsearch.inference.ServiceSettings
-
Number of dimensions the service works with.
- dimensions(int) - Method in class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.Builder
- dimensions(int) - Method in class org.elasticsearch.index.mapper.vectors.MultiDenseVectorFieldMapper.Builder
- dimensionsParam(Function<FieldMapper, List<String>>) - Static method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.Builder
- dimensionsSetByUser() - Method in interface org.elasticsearch.inference.ServiceSettings
-
Boolean signifying whether the dimensions were set by the user
- dims - Variable in class org.elasticsearch.script.field.vectors.ByteBinaryDenseVector
- dims - Variable in class org.elasticsearch.script.field.vectors.ByteBinaryDenseVectorDocValuesField
- dims - Variable in class org.elasticsearch.script.field.vectors.ByteKnnDenseVectorDocValuesField
- dims - Variable in class org.elasticsearch.script.field.vectors.ByteMultiDenseVector
- dims - Variable in class org.elasticsearch.script.field.vectors.ByteMultiDenseVectorDocValuesField
- dims - Variable in class org.elasticsearch.script.field.vectors.KnnDenseVectorDocValuesField
- dims() - Method in class org.elasticsearch.index.mapper.vectors.DenseVectorScriptDocValues
- dims() - Method in class org.elasticsearch.index.mapper.vectors.MultiDenseVectorScriptDocValues
- DIRECT - Enum constant in enum class org.elasticsearch.search.aggregations.metrics.CardinalityAggregatorFactory.ExecutionMode
- DIRECT - Enum constant in enum class org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
-
Deprecated, for removal: This API element is subject to removal in a future version.
- DIRECT_EXECUTOR_SERVICE - Static variable in class org.elasticsearch.common.util.concurrent.EsExecutors
-
ExecutorService
that executes submitted tasks on the current thread. - DIRECT_GENERATOR_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- DIRECT_RESPONSE_PROFILE - Static variable in class org.elasticsearch.transport.TransportService
- DirectCandidateGenerator - Class in org.elasticsearch.search.suggest.phrase
- DirectCandidateGenerator(DirectSpellChecker, String, SuggestMode, IndexReader, double, int) - Constructor for class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- DirectCandidateGenerator(DirectSpellChecker, String, SuggestMode, IndexReader, double, int, Analyzer, Analyzer, Terms) - Constructor for class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- DirectCandidateGenerator.Candidate - Class in org.elasticsearch.search.suggest.phrase
- DirectCandidateGenerator.CandidateSet - Class in org.elasticsearch.search.suggest.phrase
- DirectCandidateGenerator.TokenConsumer - Class in org.elasticsearch.search.suggest.phrase
- DirectCandidateGeneratorBuilder - Class in org.elasticsearch.search.suggest.phrase
- DirectCandidateGeneratorBuilder(String) - Constructor for class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- DirectCandidateGeneratorBuilder(StreamInput) - Constructor for class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Read from a stream.
- directory() - Method in class org.elasticsearch.index.store.Store
- directSourceAccess() - Method in class org.elasticsearch.script.CtxMap
-
Does this access to the internal
CtxMap.source
map occur directly via ctx? iectx['myField']
. - DirectSpellcheckerSettings - Class in org.elasticsearch.search.suggest
- DirectSpellcheckerSettings() - Constructor for class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- disableCache() - Method in class org.elasticsearch.index.query.FilteredSearchExecutionContext
- disableCache() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Marks this context as not cacheable.
- disabled() - Static method in class org.elasticsearch.http.CorsHandler
- DISABLED - Enum constant in enum class org.elasticsearch.index.mapper.ObjectMapper.Subobjects
- DISABLED - Enum constant in enum class org.elasticsearch.index.mapper.SourceFieldMapper.Mode
- DisabledQueryCache - Class in org.elasticsearch.index.cache.query
- DisableGraphAttribute - Interface in org.elasticsearch.lucene.analysis.miscellaneous
-
This attribute can be used to indicate that the
PositionLengthAttribute
should not be taken in account in thisTokenStream
. - DisableGraphAttributeImpl - Class in org.elasticsearch.lucene.analysis.miscellaneous
-
Default implementation of
DisableGraphAttribute
. - DisableGraphAttributeImpl() - Constructor for class org.elasticsearch.lucene.analysis.miscellaneous.DisableGraphAttributeImpl
- disableRecoveryMonitor() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
Set flag to signal to
RecoveriesCollection.RecoveryMonitor
that it must not cancel this recovery temporarily. - disableStatePersistence() - Method in class org.elasticsearch.cluster.block.ClusterBlock
-
Should global state persistence be disabled when this block is present.
- disableStatePersistence() - Method in class org.elasticsearch.cluster.block.ClusterBlocks
-
Returns
true
if one of the global blocks as its disable state persistence flag set. - disassociateDeadNodes(ClusterState) - Static method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
-
Unassign any persistent tasks executing on nodes that are no longer in the cluster.
- disassociateDeadNodes(ClusterState, boolean, String) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
unassigned an shards that are associated with nodes that are no longer part of the cluster, potentially promoting replicas if needed.
- disconnectFromNode(DiscoveryNode) - Method in class org.elasticsearch.transport.ClusterConnectionManager
-
Disconnected from the given node, if not connected, will do nothing.
- disconnectFromNode(DiscoveryNode) - Method in interface org.elasticsearch.transport.ConnectionManager
- disconnectFromNode(DiscoveryNode) - Method in class org.elasticsearch.transport.RemoteConnectionManager
- disconnectFromNode(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService
- disconnectFromNodesExcept(DiscoveryNodes) - Method in class org.elasticsearch.cluster.NodeConnectionsService
-
Disconnect from any nodes to which we are currently connected which do not appear in the given nodes.
- DISCOVERY - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestParameters.Metric
- DISCOVERY_CLUSTER_FORMATION_WARNING_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.ClusterFormationFailureHelper
-
This time period controls how often warning log messages will be written if this node fails to join or form a cluster.
- DISCOVERY_FIND_PEERS_INTERVAL_SETTING - Static variable in class org.elasticsearch.discovery.PeerFinder
- DISCOVERY_NODE_COMPARATOR - Static variable in class org.elasticsearch.cluster.node.DiscoveryNode
- DISCOVERY_REQUEST_PEERS_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.PeerFinder
- DISCOVERY_SEED_HOSTS_SETTING - Static variable in class org.elasticsearch.discovery.SettingsBasedSeedHostsProvider
- DISCOVERY_SEED_PROVIDERS_SETTING - Static variable in class org.elasticsearch.discovery.DiscoveryModule
- DISCOVERY_SEED_RESOLVER_MAX_CONCURRENT_RESOLVERS_SETTING - Static variable in class org.elasticsearch.discovery.SeedHostsResolver
- DISCOVERY_SEED_RESOLVER_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.SeedHostsResolver
- DISCOVERY_TROUBLESHOOTING - Enum constant in enum class org.elasticsearch.common.ReferenceDocs
- DISCOVERY_TYPE_SETTING - Static variable in class org.elasticsearch.discovery.DiscoveryModule
- discoveryIsConfigured(Settings) - Static method in class org.elasticsearch.cluster.coordination.ClusterBootstrapService
- DiscoveryModule - Class in org.elasticsearch.discovery
-
A module for loading classes for node discovery.
- DiscoveryModule(Settings, TransportService, Client, NamedWriteableRegistry, NetworkService, MasterService, ClusterApplier, ClusterSettings, List<DiscoveryPlugin>, List<ClusterCoordinationPlugin>, AllocationService, Path, GatewayMetaState, RerouteService, NodeHealthService, CircuitBreakerService, CompatibilityVersions, FeatureService) - Constructor for class org.elasticsearch.discovery.DiscoveryModule
- DiscoveryNode - Class in org.elasticsearch.cluster.node
-
A discovery node represents a node that is part of the cluster.
- DiscoveryNode(String, String, String, String, String, TransportAddress, Map<String, String>, Set<DiscoveryNodeRole>, VersionInformation) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
-
Creates a new
DiscoveryNode
. - DiscoveryNode(String, String, String, String, String, TransportAddress, Map<String, String>, Set<DiscoveryNodeRole>, VersionInformation, String) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
-
Creates a new
DiscoveryNode
. - DiscoveryNode(String, String, TransportAddress, Map<String, String>, Set<DiscoveryNodeRole>, VersionInformation) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
-
Creates a new
DiscoveryNode
- DiscoveryNode(StreamInput) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
-
Creates a new
DiscoveryNode
by reading from the stream provided as argument - DiscoveryNodeFilters - Class in org.elasticsearch.cluster.node
- DiscoveryNodeFilters.OpType - Enum Class in org.elasticsearch.cluster.node
- DiscoveryNodeRole - Class in org.elasticsearch.cluster.node
-
Represents a node role.
- DiscoveryNodeRole(String, String) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNodeRole
- DiscoveryNodeRole(String, String, boolean) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNodeRole
- DiscoveryNodes - Class in org.elasticsearch.cluster.node
-
This class holds all
DiscoveryNode
in the cluster and provides convenience methods to access, modify merge / diff discovery nodes. - DiscoveryNodes.Builder - Class in org.elasticsearch.cluster.node
- DiscoveryNodes.Delta - Class in org.elasticsearch.cluster.node
- discoveryNodeToXContent(DiscoveryNode, boolean, XContentBuilder) - Static method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Generates X-Content for a
DiscoveryNode
that leaves off some of the non-critical fields. - DiscoveryPlugin - Interface in org.elasticsearch.plugins
-
An additional extension point for
Plugin
s that extends Elasticsearch's discovery functionality. - DiscoveryStats - Class in org.elasticsearch.discovery
- DiscoveryStats(PendingClusterStateStats, PublishClusterStateStats, ClusterStateUpdateStats, ClusterApplierRecordingService.Stats) - Constructor for class org.elasticsearch.discovery.DiscoveryStats
- DiscoveryStats(StreamInput) - Constructor for class org.elasticsearch.discovery.DiscoveryStats
- discretize(int, int) - Static method in class org.elasticsearch.index.codec.vectors.BQVectorUtils
- discretizedDimensions() - Method in class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues
- discretizedDimensions() - Method in interface org.elasticsearch.index.codec.vectors.RandomAccessBinarizedByteVectorValues
- DISJOINT - Enum constant in enum class org.elasticsearch.common.geo.ShapeRelation
- DISJOINT - Enum constant in enum class org.elasticsearch.index.mapper.MappedFieldType.Relation
- Disjunction(List<IntervalsSourceProvider>, IntervalsSourceProvider.IntervalFilter) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.Disjunction
- Disjunction(StreamInput) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.Disjunction
- disk(HealthMetadata.Disk) - Method in class org.elasticsearch.health.metadata.HealthMetadata.Builder
- Disk(RelativeByteSizeValue, ByteSizeValue, RelativeByteSizeValue, ByteSizeValue, RelativeByteSizeValue, ByteSizeValue) - Constructor for record class org.elasticsearch.health.metadata.HealthMetadata.Disk
-
Creates an instance of a
Disk
record class. - DISK_USAGE_BALANCE_FACTOR_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- DiskHealthIndicatorService - Class in org.elasticsearch.health.node
-
This indicator reports the clusters' disk health aka if the cluster has enough available space to function.
- DiskHealthIndicatorService(ClusterService, FeatureService) - Constructor for class org.elasticsearch.health.node.DiskHealthIndicatorService
- diskHealthInfo(DiskHealthInfo) - Method in class org.elasticsearch.health.node.UpdateHealthInfoCacheAction.Request.Builder
- DiskHealthInfo - Record Class in org.elasticsearch.health.node
-
The health status of the disk space of this node along with the cause.
- DiskHealthInfo(StreamInput) - Constructor for record class org.elasticsearch.health.node.DiskHealthInfo
- DiskHealthInfo(HealthStatus) - Constructor for record class org.elasticsearch.health.node.DiskHealthInfo
- DiskHealthInfo(HealthStatus, DiskHealthInfo.Cause) - Constructor for record class org.elasticsearch.health.node.DiskHealthInfo
-
Creates an instance of a
DiskHealthInfo
record class. - DiskHealthInfo.Cause - Enum Class in org.elasticsearch.health.node
- DiskHealthTracker - Class in org.elasticsearch.health.node.tracker
-
Determines the disk health of this node by checking if it exceeds the thresholds defined in the health metadata.
- DiskHealthTracker(NodeService, ClusterService) - Constructor for class org.elasticsearch.health.node.tracker.DiskHealthTracker
- diskInfoByNode() - Method in record class org.elasticsearch.health.node.HealthInfo
-
Returns the value of the
diskInfoByNode
record component. - DiskIoBufferPool - Class in org.elasticsearch.common.io
- DiskIoBufferPool() - Constructor for class org.elasticsearch.common.io.DiskIoBufferPool
- DiskThresholdDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
The
DiskThresholdDecider
checks that the node a shard is potentially being allocated to has enough disk space. - DiskThresholdDecider(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
- DiskThresholdMonitor - Class in org.elasticsearch.cluster.routing.allocation
-
Listens for a node to go over the high watermark and kicks off an empty reroute if it does.
- DiskThresholdMonitor(Settings, Supplier<ClusterState>, ClusterSettings, Client, LongSupplier, RerouteService) - Constructor for class org.elasticsearch.cluster.routing.allocation.DiskThresholdMonitor
- DiskThresholdSettings - Class in org.elasticsearch.cluster.routing.allocation
-
A container to keep settings for disk thresholds up to date with cluster setting changes.
- DiskThresholdSettings(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- DiskThresholdSettings(RelativeByteSizeValue, ByteSizeValue, RelativeByteSizeValue, ByteSizeValue, RelativeByteSizeValue, ByteSizeValue, RelativeByteSizeValue, ByteSizeValue) - Constructor for class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- DiskUsage - Record Class in org.elasticsearch.cluster
-
Encapsulation class used to represent the amount of disk used on a node.
- DiskUsage(String, String, String, long, long) - Constructor for record class org.elasticsearch.cluster.DiskUsage
-
Creates an instance of a
DiskUsage
record class. - DiskUsage(StreamInput) - Constructor for record class org.elasticsearch.cluster.DiskUsage
- dismaxBlendedQuery(Term[], float) - Static method in class org.elasticsearch.lucene.queries.BlendedTermQuery
- dismaxBlendedQuery(Term[], float[], float) - Static method in class org.elasticsearch.lucene.queries.BlendedTermQuery
- disMaxQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that generates the union of documents produced by its sub-queries, and that scores each document with the maximum score for that document as produced by any sub-query, plus a tie breaking increment for any additional matching sub-queries.
- DisMaxQueryBuilder - Class in org.elasticsearch.index.query
-
A query that generates the union of documents produced by its sub-queries, and that scores each document with the maximum score for that document as produced by any sub-query, plus a tie breaking increment for any additional matching sub-queries.
- DisMaxQueryBuilder() - Constructor for class org.elasticsearch.index.query.DisMaxQueryBuilder
- DisMaxQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.DisMaxQueryBuilder
-
Read from a stream.
- dispatchBadRequest(RestChannel, ThreadContext, Throwable) - Method in interface org.elasticsearch.http.HttpServerTransport.Dispatcher
-
Dispatches a bad request.
- dispatchBadRequest(RestChannel, ThreadContext, Throwable) - Method in class org.elasticsearch.rest.RestController
- dispatchedShardOperationOnPrimary(BulkShardRequest, IndexShard, ActionListener<TransportReplicationAction.PrimaryResult<BulkShardRequest, BulkShardResponse>>) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- dispatchedShardOperationOnPrimary(ResyncReplicationRequest, IndexShard, ActionListener<TransportReplicationAction.PrimaryResult<ResyncReplicationRequest, ResyncReplicationResponse>>) - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- dispatchedShardOperationOnPrimary(RetentionLeaseSyncAction.Request, IndexShard, ActionListener<TransportReplicationAction.PrimaryResult<RetentionLeaseSyncAction.Request, RetentionLeaseSyncAction.Response>>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- dispatchedShardOperationOnPrimary(Request, IndexShard, ActionListener<TransportReplicationAction.PrimaryResult<ReplicaRequest, Response>>) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- dispatchedShardOperationOnReplica(BulkShardRequest, IndexShard, ActionListener<TransportReplicationAction.ReplicaResult>) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- dispatchedShardOperationOnReplica(ResyncReplicationRequest, IndexShard, ActionListener<TransportReplicationAction.ReplicaResult>) - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- dispatchedShardOperationOnReplica(RetentionLeaseSyncAction.Request, IndexShard, ActionListener<TransportReplicationAction.ReplicaResult>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- dispatchedShardOperationOnReplica(ReplicaRequest, IndexShard, ActionListener<TransportReplicationAction.ReplicaResult>) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- dispatcher - Variable in class org.elasticsearch.http.AbstractHttpServerTransport
- dispatchRequest(RestRequest, RestChannel, ThreadContext) - Method in interface org.elasticsearch.http.HttpServerTransport.Dispatcher
-
Dispatches the
RestRequest
to the relevant request handler or responds to the given rest channel directly if the request can't be handled by any request handler. - dispatchRequest(RestRequest, RestChannel, ThreadContext) - Method in class org.elasticsearch.rest.RestController
- displayName() - Method in enum class org.elasticsearch.Build.Type
- displayName() - Method in enum class org.elasticsearch.cluster.metadata.DataStreamLifecycle.RetentionSource
- displayString() - Method in record class org.elasticsearch.Build
-
Returns the value of the
displayString
record component. - displayType(String) - Static method in enum class org.elasticsearch.inference.configuration.SettingsConfigurationDisplayType
- displayValue - Variable in enum class org.elasticsearch.action.datastreams.GetDataStreamAction.Response.ManagedBy
- displayValue() - Method in enum class org.elasticsearch.health.ImpactArea
- dist(int) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- distance() - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Returns the distance configured as radius.
- distance(double, DistanceUnit) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Sets the distance from the center for this query.
- distance(int) - Method in class org.elasticsearch.common.util.BigArrays.DoubleBinarySearcher
- distance(int) - Method in class org.elasticsearch.common.util.BinarySearcher
- distance(String) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Sets the distance from the center using the default distance unit.
- distance(String, DistanceUnit) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Sets the distance from the center for this query.
- distance(LeafReaderContext) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
-
This function computes the distance from a defined origin.
- Distance(double, DistanceUnit) - Constructor for class org.elasticsearch.common.unit.DistanceUnit.Distance
- distanceFeatureQuery(Object, String, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- distanceFeatureQuery(Object, String, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DateScriptFieldType
- distanceFeatureQuery(Object, String, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointFieldType
- distanceFeatureQuery(Object, String, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.GeoPointScriptFieldType
- distanceFeatureQuery(Object, String, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- distanceFeatureQuery(Object, String, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.PlaceHolderFieldMapper.PlaceHolderFieldType
- distanceFeatureQuery(String, DistanceFeatureQueryBuilder.Origin, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query to boost scores based on their proximity to the given origin for date, date_nanos and geo_point field types.
- DistanceFeatureQueryBuilder - Class in org.elasticsearch.index.query
-
A query to boost scores based on their proximity to the given origin for date, date_nanos and geo_point field types
- DistanceFeatureQueryBuilder(String, DistanceFeatureQueryBuilder.Origin, String) - Constructor for class org.elasticsearch.index.query.DistanceFeatureQueryBuilder
- DistanceFeatureQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.DistanceFeatureQueryBuilder
- DistanceFeatureQueryBuilder.Origin - Class in org.elasticsearch.index.query
- distanceType(GeoDistance) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- DistanceUnit - Enum Class in org.elasticsearch.common.unit
-
The DistanceUnit enumerates several units for measuring distances.
- DistanceUnit.Distance - Class in org.elasticsearch.common.unit
-
This class implements a value+unit tuple.
- distanceValues(GeoDistance, DistanceUnit, MultiGeoPointValues, GeoPoint...) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Return a
SortedNumericDoubleValues
instance that returns the distances to a list of geo-points for each document. - distToC() - Method in record class org.elasticsearch.index.codec.vectors.BinaryQuantizer.QueryFactors
-
Returns the value of the
distToC
record component. - DiversifiedAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.sampler
- DiversifiedAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- DiversifiedAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
-
Read from a stream.
- DiversifiedAggregationBuilder(DiversifiedAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- DiversifiedAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.sampler
- DiversifiedAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.bucket.sampler
- DiversifiedBytesHashSamplerAggregator - Class in org.elasticsearch.search.aggregations.bucket.sampler
-
Alternative, faster implementation for converting String keys to longs but with the potential for hash collisions.
- DiversifiedMapSamplerAggregator - Class in org.elasticsearch.search.aggregations.bucket.sampler
- DiversifiedNumericSamplerAggregator - Class in org.elasticsearch.search.aggregations.bucket.sampler
- DiversifiedOrdinalsSamplerAggregator - Class in org.elasticsearch.search.aggregations.bucket.sampler
- diversifiedSampler(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Sampler
aggregation with the given name. - divideInPlace(float[], float) - Static method in class org.elasticsearch.index.codec.vectors.BQVectorUtils
- DO_NOT_FETCH_SOURCE - Static variable in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- DO_NOT_TRACK - Static variable in class org.elasticsearch.common.util.concurrent.EsExecutors.TaskTrackingConfig
- doAnyIndicesHaveAllUnavailable() - Method in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService.ShardAllocationCounts
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.random.RandomSamplerAggregationBuilder
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- doBuild(AggregationContext, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- doBuild(SearchContext, InnerHitsContext) - Method in class org.elasticsearch.index.query.InnerHitContextBuilder
- doc() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Returns the artificial document from which term vectors are requested for.
- doc() - Method in class org.elasticsearch.action.update.UpdateRequest
- doc() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- doc() - Method in record class org.elasticsearch.index.mapper.IgnoredSourceFieldMapper.NameValue
-
Returns the value of the
doc
record component. - doc() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- doc() - Method in interface org.elasticsearch.script.DocReader
-
Old-style doc['field'] access
- doc() - Method in class org.elasticsearch.script.DocValuesDocReader
- doc() - Method in class org.elasticsearch.script.field.WriteField
-
Append a
NestedDocument
to this field and return it. - doc() - Method in interface org.elasticsearch.search.LeafNestedDocuments
-
The current doc
- doc() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
- doc() - Method in record class org.elasticsearch.search.rank.RankDoc.RankKey
-
Returns the value of the
doc
record component. - doc(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc to use for updates when a script is not specified.
- doc(byte[], XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc to use for updates when a script is not specified.
- doc(int) - Method in class org.elasticsearch.script.field.WriteField
-
Returns a
NestedDocument
at the index, if index is beyond the end of the List, creates empty NestedDocument through the end of the array to the index. - doc(Object...) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc to use for updates when a script is not specified, the doc provided is a field and value pairs.
- doc(String, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc to use for updates when a script is not specified.
- doc(Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc to use for updates when a script is not specified.
- doc(Map<String, Object>, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc to use for updates when a script is not specified.
- doc(IndexRequest) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc to use for updates when a script is not specified.
- doc(BytesReference, boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Deprecated.use
TermVectorsRequest.doc(BytesReference, boolean, XContentType)
to avoid content auto detection - doc(BytesReference, boolean, XContentType) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Sets an artificial document from which term vectors are requested for.
- doc(BytesReference, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc to use for updates when a script is not specified.
- doc(XContentBuilder) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Sets an artificial document from which term vectors are requested for.
- doc(XContentBuilder) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc to use for updates when a script is not specified.
- doc(XContentType, Object...) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc to use for updates when a script is not specified, the doc provided is a field and value pairs.
- DOC - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- DOC - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- DOC_COUNT - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- DOC_COUNT_ERROR_UPPER_BOUND_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- DOC_EXTENSION - Static variable in class org.elasticsearch.index.codec.postings.ES812PostingsFormat
-
Filename extension for document number, frequencies, and skip data.
- DOC_FIELD_NAME - Static variable in class org.elasticsearch.search.sort.FieldSortBuilder
-
special field name to sort by index order
- DOC_STATS_SOURCE - Static variable in class org.elasticsearch.index.engine.Engine
- DOC_VALUES - Enum constant in enum class org.elasticsearch.index.mapper.MappedFieldType.FieldExtractPreference
-
Load the field from doc-values into a BlockLoader supporting doc-values.
- DOC_VALUES - Enum constant in enum class org.elasticsearch.index.search.stats.FieldUsageStats.UsageContext
- DOC_VALUES - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- DOC_VALUES - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- DOC_VALUES_FOR_IGNORED_META_FIELD - Static variable in class org.elasticsearch.index.IndexVersions
- DOC_VALUES_IN_BYTES - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- doCache(Weight, QueryCachingPolicy) - Method in class org.elasticsearch.index.cache.query.DisabledQueryCache
- doCache(Weight, QueryCachingPolicy) - Method in class org.elasticsearch.index.cache.query.IndexQueryCache
- doCache(Weight, QueryCachingPolicy) - Method in class org.elasticsearch.indices.IndicesQueryCache
- docAsMap() - Method in class org.elasticsearch.script.DocBasedScript
- docAsMap() - Method in interface org.elasticsearch.script.DocReader
-
Old-style doc access for contexts that map some doc contents in params
- docAsMap() - Method in class org.elasticsearch.script.DocValuesDocReader
- docAsUpsert() - Method in class org.elasticsearch.action.update.UpdateRequest
- docAsUpsert(boolean) - Method in class org.elasticsearch.action.update.UpdateRequest
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.AbstractCatAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestAliasAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestAllocationAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestCatComponentTemplateAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestCatRecoveryAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestCountAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestFielddataAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestHealthAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestIndicesAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestMasterAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestNodeAttrsAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestNodesAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestPendingClusterTasksAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestPluginsAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestRepositoriesAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestSegmentsAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestShardsAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestSnapshotAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestTasksAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestTemplatesAction
- doCatRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestThreadPoolAction
- docBase - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndVersion
- DocBasedScript - Class in org.elasticsearch.script
- DocBasedScript(DocReader) - Constructor for class org.elasticsearch.script.DocBasedScript
- docBetterThan(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForDoubles.Leaf
- docBetterThan(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForFloats.Leaf
- docBetterThan(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForLongs.Leaf
- docBetterThan(long) - Method in class org.elasticsearch.search.sort.BucketedSort.Leaf
-
true
if the sort value for the doc is "better" than the entry atindex
. - docCount - Variable in class org.elasticsearch.index.engine.Segment
- docCount - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- docCount - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramBucket
- docCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- docCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- docCount() - Method in record class org.elasticsearch.index.engine.SafeCommitInfo
-
Returns the value of the
docCount
record component. - docCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- docCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- DocCountFieldMapper - Class in org.elasticsearch.index.mapper
-
Mapper for the doc_count field.
- DocCountFieldMapper.DocCountFieldType - Class in org.elasticsearch.index.mapper
- DocCountFieldType() - Constructor for class org.elasticsearch.index.mapper.DocCountFieldMapper.DocCountFieldType
- docCountProvider - Variable in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
- DocCountProvider - Class in org.elasticsearch.search.aggregations.bucket
-
An implementation of a doc_count provider that reads the value of the _doc_count field in the document.
- DocCountProvider() - Constructor for class org.elasticsearch.search.aggregations.bucket.DocCountProvider
- docFreq() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- docFreq() - Method in class org.elasticsearch.script.ScriptTermStats
-
Collect docFreq (number of documents a term occurs in) for the terms of the query and returns statistics for them.
- docFreq(Term, long) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- doCheckAndNotify() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Will be called periodically
- doCheckAndNotify() - Method in class org.elasticsearch.watcher.FileWatcher
- doCheckNoMissingShards(String, SearchRequest, GroupShardsIterator<SearchShardIterator>) - Method in class org.elasticsearch.action.search.RankFeaturePhase
- docId - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndSeqNo
- docId - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndVersion
- docId() - Method in class org.elasticsearch.index.mapper.BlockDocValuesReader
- docId() - Method in class org.elasticsearch.index.mapper.BooleanScriptBlockDocValuesReader
- docId() - Method in class org.elasticsearch.index.mapper.DateScriptBlockDocValuesReader
- docId() - Method in class org.elasticsearch.index.mapper.DoubleScriptBlockDocValuesReader
- docId() - Method in class org.elasticsearch.index.mapper.IpScriptBlockDocValuesReader
- docId() - Method in class org.elasticsearch.index.mapper.KeywordScriptBlockDocValuesReader
- docId() - Method in class org.elasticsearch.index.mapper.LongScriptBlockDocValuesReader
- docId() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- docId() - Method in class org.elasticsearch.search.SearchHit
- docID() - Method in class org.elasticsearch.common.lucene.search.function.MinScoreScorer
- docID() - Method in class org.elasticsearch.index.codec.vectors.ES816BinaryQuantizedVectorsReader.BinarizedVectorValues
- docID() - Method in class org.elasticsearch.index.codec.vectors.OffHeapBinarizedVectorValues.DenseOffHeapVectorValues
- docID() - Method in class org.elasticsearch.index.fielddata.AbstractBinaryDocValues
- docID() - Method in class org.elasticsearch.index.fielddata.AbstractSortedNumericDocValues
- docID() - Method in class org.elasticsearch.index.fielddata.AbstractSortedSetDocValues
- docID() - Method in class org.elasticsearch.index.fielddata.AbstractSortingNumericDocValues
- docID() - Method in class org.elasticsearch.index.fielddata.SourceValueFetcherSortedNumericIndexFieldData.SourceValueFetcherSortedNumericDocValues
- docID() - Method in class org.elasticsearch.index.mapper.vectors.DenormalizedCosineFloatVectorValues
- docID() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource.CellSingleValue
- docIdAndVersion() - Method in class org.elasticsearch.index.engine.Engine.GetResult
- DocIdAndVersion(int, long, long, long, LeafReader, int) - Constructor for class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndVersion
- docIds() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- DocIdSliceQuery - Class in org.elasticsearch.search.slice
-
A
SliceQuery
that partitions documents based on their Lucene ID. - DocIdSliceQuery(int, int) - Constructor for class org.elasticsearch.search.slice.DocIdSliceQuery
- DOCKER - Enum constant in enum class org.elasticsearch.Build.Type
- doClose() - Method in class org.elasticsearch.action.search.QueryPhaseResultConsumer
- doClose() - Method in class org.elasticsearch.cluster.coordination.Coordinator
- doClose() - Method in class org.elasticsearch.cluster.NodeConnectionsService
- doClose() - Method in class org.elasticsearch.cluster.routing.DelayedAllocationService
- doClose() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- doClose() - Method in class org.elasticsearch.cluster.service.ClusterService
- doClose() - Method in class org.elasticsearch.cluster.service.MasterService
- doClose() - Method in class org.elasticsearch.common.breaker.PreallocatedCircuitBreakerService
- doClose() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
-
Close this component.
- doClose() - Method in class org.elasticsearch.common.file.AbstractFileWatchingService
- doClose() - Method in class org.elasticsearch.common.util.ObjectArrayPriorityQueue
- doClose() - Method in class org.elasticsearch.discovery.SeedHostsResolver
- doClose() - Method in class org.elasticsearch.gateway.GatewayService
- doClose() - Method in class org.elasticsearch.health.HealthPeriodicLogger
- doClose() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- doClose() - Method in class org.elasticsearch.index.engine.Engine.SearcherSupplier
- doClose() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
- doClose() - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
- doClose() - Method in class org.elasticsearch.indices.IndicesService
- doClose() - Method in class org.elasticsearch.indices.recovery.PeerRecoverySourceService
- doClose() - Method in class org.elasticsearch.indices.TimestampFieldMapperService
- doClose() - Method in class org.elasticsearch.monitor.fs.FsHealthService
- doClose() - Method in class org.elasticsearch.monitor.jvm.JvmGcMonitorService
- doClose() - Method in class org.elasticsearch.monitor.metrics.IndicesMetrics
- doClose() - Method in class org.elasticsearch.monitor.metrics.NodeMetrics
- doClose() - Method in class org.elasticsearch.monitor.MonitorService
- doClose() - Method in class org.elasticsearch.readiness.ReadinessService
- doClose() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- doClose() - Method in class org.elasticsearch.repositories.InvalidRepository
- doClose() - Method in class org.elasticsearch.repositories.RepositoriesService
- doClose() - Method in class org.elasticsearch.repositories.UnknownTypeRepository
- doClose() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Release instance-specific data.
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.prefix.IpPrefixAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedMapSamplerAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTermsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.terms.NumericTermsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTermsAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.GlobalOrdCardinalityAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.MinAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.SumAggregator
- doClose() - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregator
- doClose() - Method in class org.elasticsearch.search.SearchService
- doClose() - Method in class org.elasticsearch.snapshots.SnapshotShardsService
- doClose() - Method in class org.elasticsearch.snapshots.SnapshotsService
- doClose() - Method in class org.elasticsearch.transport.TcpTransport
- doClose() - Method in class org.elasticsearch.transport.TransportService
- doCoordinatorRewrite(CoordinatorRewriteContext) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- doCoordinatorRewrite(CoordinatorRewriteContext) - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- doCoordinatorRewrite(CoordinatorRewriteContext) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- doCoordinatorRewrite(CoordinatorRewriteContext) - Method in class org.elasticsearch.index.query.TermQueryBuilder
- doCoordinatorRewrite(CoordinatorRewriteContext) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- doCoordinatorRewrite(CoordinatorRewriteContext) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- docOrds(int) - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns a shared
LongsRef
instance for the given doc ID holding all ordinals associated with it. - docReader - Variable in class org.elasticsearch.script.DocBasedScript
- DocReader - Interface in org.elasticsearch.script
-
Access the document in a script, provides both old-style, doc['fieldname'], and new style field('fieldname') access to the fields.
- doCreateInternal(Map<String, ValuesSourceConfig>, DocValueFormat, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
-
Create the Aggregator.
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.prefix.IpPrefixAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceRangeAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregatorFactory
- doCreateInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
-
Create the Aggregator for a
ValuesSource
that has values. - docs - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- docs() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- docs() - Method in class org.elasticsearch.index.engine.Engine.Index
- docs() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- docs() - Method in class org.elasticsearch.script.field.WriteField
-
Iterable over all
NestedDocument
s in this field. - docs(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- Docs - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- DOCS - Enum constant in enum class org.elasticsearch.index.mapper.TextSearchInfo.TermVector
- DOCS_PER_RANGE_TO_USE_FILTERS - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
-
Minimum number of docs in the index per range before we attempt to use a filter-based collection mechanism.
- docsEnumFlag - Variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- docsStats(IndexReader) - Method in class org.elasticsearch.index.engine.Engine
- DocsStats - Class in org.elasticsearch.index.shard
- DocsStats() - Constructor for class org.elasticsearch.index.shard.DocsStats
- DocsStats(long, long, long) - Constructor for class org.elasticsearch.index.shard.DocsStats
- DocsStats(StreamInput) - Constructor for class org.elasticsearch.index.shard.DocsStats
- docStartFP - Variable in class org.elasticsearch.index.codec.postings.ES812PostingsFormat.IntBlockTermState
-
file pointer to the start of the doc ids enumeration, in
ES812PostingsFormat.DOC_EXTENSION
file - docStats() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the
DocsStats
for this engine - docStats() - Method in class org.elasticsearch.index.engine.NoOpEngine
- docStats() - Method in class org.elasticsearch.index.shard.IndexShard
- docsWithValue(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes
- docsWithValue(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
- docsWithValue(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource
-
Get a "has any values" view into the values.
- docsWithValue(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint
- docsWithValue(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
- docsWithValue(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Range
- docsWithValue(SortedNumericDocValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns a
DocValueBits
representing all documents fromdocValues
that have a value. - docsWithValue(SortedSetDocValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns a
DocValueBits
representing all documents fromdocValues
that have a value. - docsWithValue(MultiPointValues<? extends SpatialPoint>) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns a
DocValueBits
representing all documents frompointValues
that have a value. - docsWithValue(SortedBinaryDocValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns a
DocValueBits
representing all documents fromvalues
that have a value. - docsWithValue(SortedNumericDoubleValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns a
DocValueBits
representing all documents fromdoubleValues
that have a value. - DOCUMENT_PAGE_SIZE - Static variable in class org.elasticsearch.gateway.PersistedClusterStateService
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.AbstractCatAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestAliasAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestAllocationAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestCatComponentTemplateAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestCatRecoveryAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestCountAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestFielddataAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestHealthAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestIndicesAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestMasterAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestNodeAttrsAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestNodesAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestPendingClusterTasksAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestPluginsAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestRepositoriesAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestSegmentsAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestShardsAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestSnapshotAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestTasksAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestTemplatesAction
- documentation(StringBuilder) - Method in class org.elasticsearch.rest.action.cat.RestThreadPoolAction
- documentDescription() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Description on the document being parsed used in error messages.
- documentDescription() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- documentDescription(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.IdFieldMapper
-
Description of the document being parsed used in error messages.
- documentDescription(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.ProvidedIdFieldMapper
- documentDescription(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.TsidExtractingIdFieldMapper
- documentDescription(ParsedDocument) - Method in class org.elasticsearch.index.mapper.IdFieldMapper
-
Description of the document being indexed used after parsing for things like version conflicts.
- documentDescription(ParsedDocument) - Method in class org.elasticsearch.index.mapper.ProvidedIdFieldMapper
- documentDescription(ParsedDocument) - Method in class org.elasticsearch.index.mapper.TsidExtractingIdFieldMapper
- DocumentField - Class in org.elasticsearch.common.document
- DocumentField(String, List<Object>) - Constructor for class org.elasticsearch.common.document.DocumentField
- DocumentField(String, List<Object>, List<Object>) - Constructor for class org.elasticsearch.common.document.DocumentField
- DocumentField(String, List<Object>, List<Object>, List<LookupField>) - Constructor for class org.elasticsearch.common.document.DocumentField
- DocumentField(StreamInput) - Constructor for class org.elasticsearch.common.document.DocumentField
- documentId(String) - Static method in class org.elasticsearch.inference.Model
- documentMapper() - Method in class org.elasticsearch.index.mapper.MapperService
-
Return the document mapper, or
null
if no mapping has been put yet or no documents have been indexed in the current index yet (which triggers a dynamic mapping update) - DocumentMapper - Class in org.elasticsearch.index.mapper
- DocumentMissingException - Exception in org.elasticsearch.index.engine
- DocumentMissingException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.DocumentMissingException
- DocumentMissingException(ShardId, String) - Constructor for exception org.elasticsearch.index.engine.DocumentMissingException
- documentParser() - Method in class org.elasticsearch.index.mapper.MapperService
-
Exposes a
DocumentParser
- DocumentParser - Class in org.elasticsearch.index.mapper
-
A parser for documents
- DocumentParserContext - Class in org.elasticsearch.index.mapper
-
Context used when parsing incoming documents.
- DocumentParserContext(MappingLookup, MappingParserContext, SourceToParse, ObjectMapper, ObjectMapper.Dynamic) - Constructor for class org.elasticsearch.index.mapper.DocumentParserContext
- DocumentParsingException - Exception in org.elasticsearch.index.mapper
-
An exception thrown during document parsing Contains information about the location in the document where the error was encountered
- DocumentParsingException(StreamInput) - Constructor for exception org.elasticsearch.index.mapper.DocumentParsingException
- DocumentParsingException(XContentLocation, String) - Constructor for exception org.elasticsearch.index.mapper.DocumentParsingException
- DocumentParsingException(XContentLocation, String, Exception) - Constructor for exception org.elasticsearch.index.mapper.DocumentParsingException
- documentParsingProvider() - Method in record class org.elasticsearch.node.PluginServiceInstances
-
Returns the value of the
documentParsingProvider
record component. - documentParsingProvider() - Method in interface org.elasticsearch.plugins.Plugin.PluginServices
-
A provider of utilities to observe and report parsing of documents
- DocumentParsingProvider - Interface in org.elasticsearch.plugins.internal
-
An interface to provide instances of document parsing observer and reporter
- DocumentParsingProviderPlugin - Interface in org.elasticsearch.plugins.internal
-
An internal plugin that will return a DocumentParsingProvider.
- DocumentSize(long, long) - Constructor for record class org.elasticsearch.index.mapper.ParsedDocument.DocumentSize
-
Creates an instance of a
DocumentSize
record class. - DocumentSizeAccumulator - Interface in org.elasticsearch.plugins.internal
-
An interface to allow accumulating results of document parsing (collected with
XContentParserDecorator
) - DocumentSizeReporter - Interface in org.elasticsearch.plugins.internal
-
An interface to allow performing an action when parsing and indexing has been completed
- DocumentSourceMissingException - Exception in org.elasticsearch.index.engine
- DocumentSourceMissingException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.DocumentSourceMissingException
- DocumentSourceMissingException(ShardId, String) - Constructor for exception org.elasticsearch.index.engine.DocumentSourceMissingException
- docValue() - Method in class org.elasticsearch.search.sort.BucketedSort.ForDoubles.Leaf
-
Return the value for of this sort for the document to which we just
moved
. - docValue() - Method in class org.elasticsearch.search.sort.BucketedSort.ForFloats.Leaf
-
Return the value for of this sort for the document to which we just
moved
. - docValue() - Method in class org.elasticsearch.search.sort.BucketedSort.ForLongs.Leaf
-
Return the value for of this sort for the document to which we just
moved
. - DOCVALUE_FIELDS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- DocValueBits - Class in org.elasticsearch.index.fielddata
- DocValueBits() - Constructor for class org.elasticsearch.index.fielddata.DocValueBits
- docValueCount() - Method in class org.elasticsearch.index.fielddata.BooleanScriptDocValues
- docValueCount() - Method in class org.elasticsearch.index.fielddata.DoubleScriptDocValues
- docValueCount() - Method in interface org.elasticsearch.index.fielddata.FormattedDocValues
-
A count of the number of values at this document.
- docValueCount() - Method in class org.elasticsearch.index.fielddata.GeoPointScriptDocValues
- docValueCount() - Method in class org.elasticsearch.index.fielddata.IpScriptDocValues
- docValueCount() - Method in class org.elasticsearch.index.fielddata.LongScriptDocValues
- docValueCount() - Method in class org.elasticsearch.index.fielddata.MultiPointValues
-
Return the number of geo points the current document has.
- docValueCount() - Method in class org.elasticsearch.index.fielddata.plain.FormattedSortedNumericDocValues
- docValueCount() - Method in class org.elasticsearch.index.fielddata.SortedBinaryDocValues
-
Retrieves the number of values for the current document.
- docValueCount() - Method in class org.elasticsearch.index.fielddata.SortedNumericDoubleValues
-
Retrieves the number of values for the current document.
- docValueCount() - Method in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
- docValueCount() - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
- docValueCount() - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
- docValueCount() - Method in class org.elasticsearch.index.fielddata.SourceValueFetcherSortedBinaryIndexFieldData.SourceValueFetcherSortedBinaryDocValues
- docValueCount() - Method in class org.elasticsearch.index.fielddata.SourceValueFetcherSortedNumericIndexFieldData.SourceValueFetcherSortedNumericDocValues
- DocValueFetcher - Class in org.elasticsearch.index.mapper
-
Value fetcher that loads from doc values.
- DocValueFetcher(DocValueFormat, IndexFieldData<?>) - Constructor for class org.elasticsearch.index.mapper.DocValueFetcher
- DocValueFetcher(DocValueFormat, IndexFieldData<?>, StoredFieldsSpec) - Constructor for class org.elasticsearch.index.mapper.DocValueFetcher
- docValueField(String) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Adds a field to load from doc values and return as part of the search request.
- docValueField(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a field to load from the doc values and return as part of the search request.
- docValueField(String, String) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Adds a field to load from doc values and return as part of the search request.
- docValueField(String, String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a field to load from the doc values and return as part of the search request.
- docValueFields() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the docvalue fields.
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.BinaryFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.BooleanScriptFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.DateScriptFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.DoubleScriptFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.IpScriptFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Pick a
DocValueFormat
that can be used to display and parse values of fields of this type. - docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.TimeSeriesIdFieldMapper.TimeSeriesIdFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.DenseVectorFieldType
- docValueFormat(String, ZoneId) - Method in class org.elasticsearch.index.mapper.vectors.MultiDenseVectorFieldMapper.MultiDenseVectorFieldType
- DocValueFormat - Interface in org.elasticsearch.search
-
A formatter for values as returned by the fielddata/doc-values APIs.
- DocValueFormat.BinaryDocValueFormat - Class in org.elasticsearch.search
-
Singleton, stateless formatter, for representing bytes as base64 strings
- DocValueFormat.BooleanDocValueFormat - Class in org.elasticsearch.search
-
Stateless, Singleton formatter for boolean values.
- DocValueFormat.DateTime - Class in org.elasticsearch.search
- DocValueFormat.Decimal - Class in org.elasticsearch.search
- DocValueFormat.DenseVectorDocValueFormat - Class in org.elasticsearch.search
-
Singleton, stateless formatter, for dense vector values, no need to actually format anything
- DocValueFormat.GeoHashDocValueFormat - Class in org.elasticsearch.search
-
Singleton, stateless formatter for geo hash values
- DocValueFormat.GeoTileDocValueFormat - Class in org.elasticsearch.search
- DocValueFormat.IpDocValueFormat - Class in org.elasticsearch.search
-
Stateless, singleton formatter for IP address data
- DocValueFormat.RawDocValueFormat - Class in org.elasticsearch.search
-
Singleton, stateless formatter for "Raw" values, generally taken to mean keywords and other strings.
- DocValueFormat.TimeSeriesIdDocValueFormat - Class in org.elasticsearch.search
-
DocValues format for time series id.
- DocValueFormat.UnsignedLongShiftedDocValueFormat - Class in org.elasticsearch.search
-
DocValues format for unsigned 64 bit long values, that are stored as shifted signed 64 bit long values.
- docValues(boolean) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.Builder
- docValues(boolean) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- docValues(boolean) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- docValues(boolean) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- docValues(boolean) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- DocValuesBasedSyntheticFieldLoader() - Constructor for class org.elasticsearch.index.mapper.SourceLoader.DocValuesBasedSyntheticFieldLoader
- DocValuesBlockLoader() - Constructor for class org.elasticsearch.index.mapper.BlockDocValuesReader.DocValuesBlockLoader
- docValuesContext() - Method in class org.elasticsearch.search.fetch.FetchContext
-
Configuration for fetching docValues fields
- docValuesContext() - Method in class org.elasticsearch.search.internal.SearchContext
- docValuesContext() - Method in class org.elasticsearch.search.internal.SubSearchContext
- docValuesContext() - Method in class org.elasticsearch.search.rank.RankSearchContext
- docValuesContext(FetchDocValuesContext) - Method in class org.elasticsearch.search.internal.SearchContext
- docValuesContext(FetchDocValuesContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
- docValuesContext(FetchDocValuesContext) - Method in class org.elasticsearch.search.rank.RankSearchContext
- DocValuesDocReader - Class in org.elasticsearch.script
-
Provide access to DocValues for script
field
api anddoc
API. - DocValuesDocReader(SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.DocValuesDocReader
- docValuesFormat() - Method in class org.elasticsearch.index.codec.Elasticsearch814Codec
- docValuesFormat() - Method in class org.elasticsearch.index.codec.Elasticsearch816Codec
- DocValuesForUtil - Class in org.elasticsearch.index.codec.tsdb
- DocValuesForUtil(int) - Constructor for class org.elasticsearch.index.codec.tsdb.DocValuesForUtil
- docValuesLoader(LeafReader, int[]) - Method in class org.elasticsearch.index.mapper.BinaryDocValuesSyntheticFieldLoader
- docValuesLoader(LeafReader, int[]) - Method in class org.elasticsearch.index.mapper.CompositeSyntheticFieldLoader
- docValuesLoader(LeafReader, int[]) - Method in class org.elasticsearch.index.mapper.CompositeSyntheticFieldLoader.StoredFieldLayer
- docValuesLoader(LeafReader, int[]) - Method in class org.elasticsearch.index.mapper.SortedNumericDocValuesSyntheticFieldLoader
- docValuesLoader(LeafReader, int[]) - Method in class org.elasticsearch.index.mapper.SortedSetDocValuesSyntheticFieldLoaderLayer
- docValuesLoader(LeafReader, int[]) - Method in interface org.elasticsearch.index.mapper.SourceLoader.SyntheticFieldLoader
-
Build something to load doc values for this field or return
null
if there are no doc values for this field to load. - docValuesLoader(LeafReader, int[]) - Method in class org.elasticsearch.index.mapper.StringStoredFieldFieldLoader
- docValuesOnly(String, NumberFieldMapper.NumberType, IndexVersion) - Static method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- docValuesOrNull(LeafReader, String) - Static method in class org.elasticsearch.index.mapper.SortedNumericDocValuesSyntheticFieldLoader
-
Returns a
SortedNumericDocValues
or null if it doesn't have any doc values. - docValuesParam(Function<FieldMapper, Boolean>, boolean) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- DocValuesScriptFieldFactory - Interface in org.elasticsearch.script.field
-
This interface is used to mark classes that generate both
Field
andScriptDocValues
for use in a script. - DocValuesSliceQuery - Class in org.elasticsearch.search.slice
-
A
SliceQuery
that uses the numeric doc values of a field to do the slicing. - DocValuesSliceQuery(String, int, int) - Constructor for class org.elasticsearch.search.slice.DocValuesSliceQuery
- docVector - Variable in class org.elasticsearch.script.field.vectors.ByteKnnDenseVector
- docVector - Variable in class org.elasticsearch.script.field.vectors.KnnDenseVector
- DocWriteRequest<T> - Interface in org.elasticsearch.action
-
Generic interface to group ActionRequest, which perform writes to a single document Action requests implementing this can be part of
BulkRequest
- DocWriteRequest.OpType - Enum Class in org.elasticsearch.action
-
Requested operation type to perform on the document
- DocWriteResponse - Class in org.elasticsearch.action
-
A base class for the response of a write operation that involves a single doc
- DocWriteResponse(StreamInput) - Constructor for class org.elasticsearch.action.DocWriteResponse
-
Needed for deserialization of single item requests in
TransportIndexAction
and BwC deserialization path - DocWriteResponse(ShardId, String, long, long, long, DocWriteResponse.Result) - Constructor for class org.elasticsearch.action.DocWriteResponse
- DocWriteResponse(ShardId, StreamInput) - Constructor for class org.elasticsearch.action.DocWriteResponse
- DocWriteResponse.Builder - Class in org.elasticsearch.action
-
Base class of all
DocWriteResponse
builders. - DocWriteResponse.Result - Enum Class in org.elasticsearch.action
-
An enum that represents the results of CRUD operations, primarily used to communicate the type of operation that occurred.
- doEquals(DFB) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- doEquals(FB) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Check that two instances of the same subclass of ScoreFunctionBuilder are equal.
- doEquals(HB) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
fields only present in subclass should be checked for equality in the implementation
- doEquals(Object) - Method in class org.elasticsearch.search.retriever.CompoundRetrieverBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.retriever.KnnRetrieverBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.retriever.RankDocsRetrieverBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.retriever.RetrieverBuilder
- doEquals(Object) - Method in class org.elasticsearch.search.retriever.RetrieverBuilderWrapper
- doEquals(Object) - Method in class org.elasticsearch.search.retriever.StandardRetrieverBuilder
- doEquals(ScoreFunction) - Method in class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction
- doEquals(ScoreFunction) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.FilterScoreFunction
- doEquals(ScoreFunction) - Method in class org.elasticsearch.common.lucene.search.function.RandomScoreFunction
- doEquals(ScoreFunction) - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
-
Indicates whether some other
ScoreFunction
object of the same type is "equal to" this one. - doEquals(ScoreFunction) - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
- doEquals(ScoreFunction) - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- doEquals(ScoreFunction) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- doEquals(AbstractGeometryQueryBuilder) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- doEquals(BoolQueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- doEquals(BoostingQueryBuilder) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
- doEquals(CombinedFieldsQueryBuilder) - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- doEquals(CommonTermsQueryBuilder) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- doEquals(ConstantScoreQueryBuilder) - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- doEquals(DisMaxQueryBuilder) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- doEquals(DistanceFeatureQueryBuilder) - Method in class org.elasticsearch.index.query.DistanceFeatureQueryBuilder
- doEquals(ExistsQueryBuilder) - Method in class org.elasticsearch.index.query.ExistsQueryBuilder
- doEquals(FieldMaskingSpanQueryBuilder) - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- doEquals(FieldValueFactorFunctionBuilder) - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- doEquals(FunctionScoreQueryBuilder) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- doEquals(RandomScoreFunctionBuilder) - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- doEquals(ScriptScoreFunctionBuilder) - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- doEquals(ScriptScoreQueryBuilder) - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- doEquals(WeightBuilder) - Method in class org.elasticsearch.index.query.functionscore.WeightBuilder
- doEquals(FuzzyQueryBuilder) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- doEquals(GeoBoundingBoxQueryBuilder) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
- doEquals(GeoDistanceQueryBuilder) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
- doEquals(GeoPolygonQueryBuilder) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.
- doEquals(GeoShapeQueryBuilder) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- doEquals(IdsQueryBuilder) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
- doEquals(IntervalQueryBuilder) - Method in class org.elasticsearch.index.query.IntervalQueryBuilder
- doEquals(MatchAllQueryBuilder) - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
- doEquals(MatchBoolPrefixQueryBuilder) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
- doEquals(MatchNoneQueryBuilder) - Method in class org.elasticsearch.index.query.MatchNoneQueryBuilder
- doEquals(MatchPhrasePrefixQueryBuilder) - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- doEquals(MatchPhraseQueryBuilder) - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- doEquals(MatchQueryBuilder) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
- doEquals(MoreLikeThisQueryBuilder) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- doEquals(MultiMatchQueryBuilder) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- doEquals(NestedQueryBuilder) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
- doEquals(PrefixQueryBuilder) - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- doEquals(QueryStringQueryBuilder) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- doEquals(RangeQueryBuilder) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- doEquals(RankDocsQueryBuilder) - Method in class org.elasticsearch.index.query.RankDocsQueryBuilder
- doEquals(RegexpQueryBuilder) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- doEquals(ScriptQueryBuilder) - Method in class org.elasticsearch.index.query.ScriptQueryBuilder
- doEquals(SimpleQueryStringBuilder) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- doEquals(SpanContainingQueryBuilder) - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- doEquals(SpanFirstQueryBuilder) - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- doEquals(SpanMultiTermQueryBuilder) - Method in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- doEquals(SpanNearQueryBuilder) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- doEquals(SpanNotQueryBuilder) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- doEquals(SpanOrQueryBuilder) - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
- doEquals(SpanWithinQueryBuilder) - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- doEquals(TermQueryBuilder) - Method in class org.elasticsearch.index.query.TermQueryBuilder
- doEquals(TermsQueryBuilder) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- doEquals(TermsSetQueryBuilder) - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- doEquals(TypeQueryV7Builder) - Method in class org.elasticsearch.index.query.TypeQueryV7Builder
- doEquals(WildcardQueryBuilder) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- doEquals(WrapperQueryBuilder) - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- doEquals(HighlightBuilder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- doEquals(HighlightBuilder.Field) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
- doEquals(RankBuilder) - Method in class org.elasticsearch.search.rank.RankBuilder
- doEquals(RankDoc) - Method in class org.elasticsearch.search.rank.feature.RankFeatureDoc
- doEquals(RankDoc) - Method in class org.elasticsearch.search.rank.RankDoc
- doEquals(CompletionSuggestionBuilder) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- doEquals(PhraseSuggestionBuilder) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- doEquals(SmoothingModel) - Method in class org.elasticsearch.search.suggest.phrase.Laplace
- doEquals(SmoothingModel) - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- doEquals(SmoothingModel) - Method in class org.elasticsearch.search.suggest.phrase.SmoothingModel
-
subtype specific implementation of "equals".
- doEquals(SmoothingModel) - Method in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- doEquals(TermSuggestionBuilder) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
- doEquals(ExactKnnQueryBuilder) - Method in class org.elasticsearch.search.vectors.ExactKnnQueryBuilder
- doEquals(KnnScoreDocQueryBuilder) - Method in class org.elasticsearch.search.vectors.KnnScoreDocQueryBuilder
- doEquals(KnnVectorQueryBuilder) - Method in class org.elasticsearch.search.vectors.KnnVectorQueryBuilder
- doEquals(QB) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Indicates whether some other
QueryBuilder
object of the same type is "equal to" this one. - doEquals(QB) - Method in class org.elasticsearch.index.query.BaseTermQueryBuilder
- doEquals(T) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
Indicates whether some other
SuggestionBuilder
of the same type is "equal to" this one. - doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.internal.FilterClient
- doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.internal.node.NodeClient
- doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.internal.OriginSettingClient
- doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.internal.ParentTaskAssigningClient
- doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.internal.support.AbstractClient
- doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.rest.action.RestCancellableNodeClient
- doExecute(Task, NodesRequest, ActionListener<NodesResponse>) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
- doExecute(Task, TransportGetAllocationStatsAction.Request, ActionListener<TransportGetAllocationStatsAction.Response>) - Method in class org.elasticsearch.action.admin.cluster.allocation.TransportGetAllocationStatsAction
- doExecute(Task, ClusterFormationInfoAction.Request, ActionListener<ClusterFormationInfoAction.Response>) - Method in class org.elasticsearch.action.admin.cluster.coordination.ClusterFormationInfoAction.TransportAction
- doExecute(Task, CoordinationDiagnosticsAction.Request, ActionListener<CoordinationDiagnosticsAction.Response>) - Method in class org.elasticsearch.action.admin.cluster.coordination.CoordinationDiagnosticsAction.TransportAction
- doExecute(Task, MasterHistoryAction.Request, ActionListener<MasterHistoryAction.Response>) - Method in class org.elasticsearch.action.admin.cluster.coordination.MasterHistoryAction.TransportAction
- doExecute(Task, UpdateDesiredNodesRequest, ActionListener<UpdateDesiredNodesResponse>) - Method in class org.elasticsearch.action.admin.cluster.desirednodes.TransportUpdateDesiredNodesAction
- doExecute(Task, NodesCapabilitiesRequest, ActionListener<NodesCapabilitiesResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.capabilities.TransportNodesCapabilitiesAction
- doExecute(Task, GetTaskRequest, ActionListener<GetTaskResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.TransportGetTaskAction
- doExecute(Task, ListTasksRequest, ActionListener<ListTasksResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
- doExecute(Task, RemoteClusterNodesAction.Request, ActionListener<RemoteClusterNodesAction.Response>) - Method in class org.elasticsearch.action.admin.cluster.remote.RemoteClusterNodesAction.TransportAction
- doExecute(Task, RemoteInfoRequest, ActionListener<RemoteInfoResponse>) - Method in class org.elasticsearch.action.admin.cluster.remote.TransportRemoteInfoAction
- doExecute(Task, DeleteSnapshotRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.TransportDeleteSnapshotAction
- doExecute(Task, RemoteClusterStatsRequest, ActionListener<RemoteClusterStatsResponse>) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportRemoteClusterStatsAction
- doExecute(Task, GetScriptContextRequest, ActionListener<GetScriptContextResponse>) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportGetScriptContextAction
- doExecute(Task, GetScriptLanguageRequest, ActionListener<GetScriptLanguageResponse>) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportGetScriptLanguageAction
- doExecute(Task, CloseIndexRequest, ActionListener<CloseIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
- doExecute(Task, ImportDanglingIndexRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.dangling.import_index.TransportImportDanglingIndexAction
- doExecute(Task, DeleteIndexRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
- doExecute(Task, AnalyzeIndexDiskUsageRequest, ActionListener<AnalyzeIndexDiskUsageResponse>) - Method in class org.elasticsearch.action.admin.indices.diskusage.TransportAnalyzeIndexDiskUsageAction
- doExecute(Task, GetFieldMappingsRequest, ActionListener<GetFieldMappingsResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsAction
- doExecute(Task, PutMappingRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportAutoPutMappingAction
- doExecute(Task, OpenIndexRequest, ActionListener<OpenIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
- doExecute(Task, AddIndexBlockRequest, ActionListener<AddIndexBlockResponse>) - Method in class org.elasticsearch.action.admin.indices.readonly.TransportAddIndexBlockAction
- doExecute(Task, ResolveClusterActionRequest, ActionListener<ResolveClusterActionResponse>) - Method in class org.elasticsearch.action.admin.indices.resolve.TransportResolveClusterAction
- doExecute(Task, ResolveIndexAction.Request, ActionListener<ResolveIndexAction.Response>) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.TransportAction
- doExecute(Task, ValidateQueryRequest, ActionListener<ValidateQueryResponse>) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- doExecute(Task, BulkRequest, ActionListener<BulkResponse>) - Method in class org.elasticsearch.action.bulk.TransportAbstractBulkAction
- doExecute(Task, ExplainRequest, ActionListener<ExplainResponse>) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- doExecute(Task, FieldCapabilitiesRequest, ActionListener<FieldCapabilitiesResponse>) - Method in class org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesAction
- doExecute(Task, MultiGetRequest, ActionListener<MultiGetResponse>) - Method in class org.elasticsearch.action.get.TransportMultiGetAction
- doExecute(Task, TransportGetFromTranslogAction.Request, ActionListener<TransportGetFromTranslogAction.Response>) - Method in class org.elasticsearch.action.get.TransportGetFromTranslogAction
- doExecute(Task, TransportShardMultiGetFomTranslogAction.Request, ActionListener<TransportShardMultiGetFomTranslogAction.Response>) - Method in class org.elasticsearch.action.get.TransportShardMultiGetFomTranslogAction
- doExecute(Task, SimulatePipelineRequest, ActionListener<SimulatePipelineResponse>) - Method in class org.elasticsearch.action.ingest.SimulatePipelineTransportAction
- doExecute(Task, ResyncReplicationRequest, ActionListener<ResyncReplicationResponse>) - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- doExecute(Task, ClearScrollRequest, ActionListener<ClearScrollResponse>) - Method in class org.elasticsearch.action.search.TransportClearScrollAction
- doExecute(Task, ClosePointInTimeRequest, ActionListener<ClosePointInTimeResponse>) - Method in class org.elasticsearch.action.search.TransportClosePointInTimeAction
- doExecute(Task, MultiSearchRequest, ActionListener<MultiSearchResponse>) - Method in class org.elasticsearch.action.search.TransportMultiSearchAction
- doExecute(Task, OpenPointInTimeRequest, ActionListener<OpenPointInTimeResponse>) - Method in class org.elasticsearch.action.search.TransportOpenPointInTimeAction
- doExecute(Task, SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.TransportSearchAction
- doExecute(Task, SearchScrollRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.TransportSearchScrollAction
- doExecute(Task, SearchShardsRequest, ActionListener<SearchShardsResponse>) - Method in class org.elasticsearch.action.search.TransportSearchShardsAction
- doExecute(Task, DeleteSynonymRuleAction.Request, ActionListener<SynonymUpdateResponse>) - Method in class org.elasticsearch.action.synonyms.TransportDeleteSynonymRuleAction
- doExecute(Task, DeleteSynonymsAction.Request, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.synonyms.TransportDeleteSynonymsAction
- doExecute(Task, GetSynonymRuleAction.Request, ActionListener<GetSynonymRuleAction.Response>) - Method in class org.elasticsearch.action.synonyms.TransportGetSynonymRuleAction
- doExecute(Task, GetSynonymsAction.Request, ActionListener<GetSynonymsAction.Response>) - Method in class org.elasticsearch.action.synonyms.TransportGetSynonymsAction
- doExecute(Task, GetSynonymsSetsAction.Request, ActionListener<GetSynonymsSetsAction.Response>) - Method in class org.elasticsearch.action.synonyms.TransportGetSynonymsSetsAction
- doExecute(Task, PutSynonymRuleAction.Request, ActionListener<SynonymUpdateResponse>) - Method in class org.elasticsearch.action.synonyms.TransportPutSynonymRuleAction
- doExecute(Task, PutSynonymsAction.Request, ActionListener<SynonymUpdateResponse>) - Method in class org.elasticsearch.action.synonyms.TransportPutSynonymsAction
- doExecute(Task, MultiTermVectorsRequest, ActionListener<MultiTermVectorsResponse>) - Method in class org.elasticsearch.action.termvectors.TransportMultiTermVectorsAction
- doExecute(Task, UpdateRequest, ActionListener<UpdateResponse>) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- doExecute(Task, GetHealthAction.Request, ActionListener<GetHealthAction.Response>) - Method in class org.elasticsearch.health.GetHealthAction.LocalAction
- doExecute(Task, RetentionLeaseBackgroundSyncAction.Request, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- doExecute(Task, RetentionLeaseSyncAction.Request, ActionListener<RetentionLeaseSyncAction.Response>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- doExecute(Task, VerifyNodeRepositoryAction.Request, ActionListener<ActionResponse.Empty>) - Method in class org.elasticsearch.repositories.VerifyNodeRepositoryAction.TransportAction
- doExecute(Task, VerifyNodeRepositoryAction.Request, ActionListener<VerifyNodeRepositoryCoordinationAction.Response>) - Method in class org.elasticsearch.repositories.VerifyNodeRepositoryCoordinationAction.LocalAction
- doExecute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.bulk.TransportSingleItemBulkWriteAction
-
Deprecated.
- doExecute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
- doExecute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- doExecute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.broadcast.unpromotable.TransportBroadcastUnpromotableAction
- doExecute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- doExecute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- doExecute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- doExecute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.ReservedStateAwareHandledTransportAction
- doExecute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- doExecute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- doExecute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.TransportAction
- doExecute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.TransportLocalClusterStateAction
- doExecute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.health.node.action.TransportHealthNodeAction
- doExecute(Task, TasksRequest, ActionListener<TasksResponse>) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- doExecuteForked(Task, ResolveClusterActionRequest, ActionListener<ResolveClusterActionResponse>) - Method in class org.elasticsearch.action.admin.indices.resolve.TransportResolveClusterAction
- doExecuteForked(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- doExecuteProtected(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.ReservedStateAwareHandledTransportAction
-
A doExecute method wrapped with a check for clashes with updates to the reserved cluster state
- doForSlice(Self, TaskId, int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Setup a clone of this request with the information needed to process a slice of it.
- doForSlice(Self, TaskId, int) - Method in class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
- doGetSequentialStoredFieldsReader(StoredFieldsReader) - Method in class org.elasticsearch.common.lucene.index.ElasticsearchLeafReader
- doGetSequentialStoredFieldsReader(StoredFieldsReader) - Method in class org.elasticsearch.common.lucene.index.SequentialStoredFieldsLeafReader
-
Implementations should return a
StoredFieldsReader
that wraps the providedreader
that is optimized for sequential access (adjacent doc ids). - doHandleBytes(TcpChannel, ReleasableBytesReference) - Method in class org.elasticsearch.transport.InboundPipeline
- doHashCode() - Method in class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction
- doHashCode() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.FilterScoreFunction
- doHashCode() - Method in class org.elasticsearch.common.lucene.search.function.RandomScoreFunction
- doHashCode() - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
- doHashCode() - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
- doHashCode() - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- doHashCode() - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.BaseTermQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.DistanceFeatureQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.ExistsQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- doHashCode() - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Hashcode for fields defined in this subclass of ScoreFunctionBuilder.
- doHashCode() - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.functionscore.WeightBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.
- doHashCode() - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.IdsQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.IntervalQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.MatchNoneQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.NestedQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.RankDocsQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.ScriptQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.TermQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.TypeQueryV7Builder
- doHashCode() - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- doHashCode() - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- doHashCode() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
fields only present in subclass should contribute to hashCode in the implementation
- doHashCode() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- doHashCode() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
- doHashCode() - Method in class org.elasticsearch.search.rank.feature.RankFeatureDoc
- doHashCode() - Method in class org.elasticsearch.search.rank.RankBuilder
- doHashCode() - Method in class org.elasticsearch.search.rank.RankDoc
- doHashCode() - Method in class org.elasticsearch.search.retriever.CompoundRetrieverBuilder
- doHashCode() - Method in class org.elasticsearch.search.retriever.KnnRetrieverBuilder
- doHashCode() - Method in class org.elasticsearch.search.retriever.RankDocsRetrieverBuilder
- doHashCode() - Method in class org.elasticsearch.search.retriever.RetrieverBuilder
- doHashCode() - Method in class org.elasticsearch.search.retriever.RetrieverBuilderWrapper
- doHashCode() - Method in class org.elasticsearch.search.retriever.StandardRetrieverBuilder
- doHashCode() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- doHashCode() - Method in class org.elasticsearch.search.suggest.phrase.Laplace
- doHashCode() - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- doHashCode() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- doHashCode() - Method in class org.elasticsearch.search.suggest.phrase.SmoothingModel
- doHashCode() - Method in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- doHashCode() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
HashCode for the subclass of
SuggestionBuilder
to implement. - doHashCode() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
- doHashCode() - Method in class org.elasticsearch.search.vectors.ExactKnnQueryBuilder
- doHashCode() - Method in class org.elasticsearch.search.vectors.KnnScoreDocQueryBuilder
- doHashCode() - Method in class org.elasticsearch.search.vectors.KnnVectorQueryBuilder
- doIndexMetadataRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Optional rewrite logic that only needs access to index level metadata and services (e.g.
- doIndexMetadataRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.ExistsQueryBuilder
- doIndexMetadataRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- doIndexMetadataRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
- doIndexMetadataRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- doIndexMetadataRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.TermQueryBuilder
- doIndexMetadataRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- doIndexMetadataRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- doInit() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Will be called once on initialization
- doInit() - Method in class org.elasticsearch.watcher.FileWatcher
- doInnerHitsRewrite(InnerHitsRewriteContext) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Optional rewrite logic that allows for optimization for extracting inner hits
- doInternalExecute(Task, BulkRequest, Executor, ActionListener<BulkResponse>, long) - Method in class org.elasticsearch.action.bulk.TransportAbstractBulkAction
-
This method creates any missing resources and actually applies the BulkRequest to the relevant indices
- doInternalExecute(Task, BulkRequest, Executor, ActionListener<BulkResponse>, long) - Method in class org.elasticsearch.action.bulk.TransportBulkAction
- doInternalExecute(Task, BulkRequest, Executor, ActionListener<BulkResponse>, long) - Method in class org.elasticsearch.action.bulk.TransportSimulateBulkAction
- doMasterOperation(Task, GetIndexRequest, String[], ClusterState, ActionListener<GetIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.get.TransportGetIndexAction
- doMasterOperation(Task, GetMappingsRequest, String[], ClusterState, ActionListener<GetMappingsResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetMappingsAction
- doMasterOperation(Task, Request, String[], ClusterState, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.info.TransportClusterInfoAction
- doMerge(MergeScheduler.MergeSource, MergePolicy.OneMerge) - Method in class org.elasticsearch.index.engine.ElasticsearchConcurrentMergeScheduler
- done(boolean) - Method in class org.elasticsearch.action.support.PlainActionFuture
-
Called when the
PlainActionFuture<Object>
is completed. - done(TimeValue) - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.AsyncResponse
-
Called when done processing response to signal more data is needed.
- DONE - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Snapshot completed successfully
- DONE - Enum constant in enum class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Snapshot completed successfully
- DONE - Enum constant in enum class org.elasticsearch.indices.recovery.RecoveryState.Stage
- doNoSelfReferencesCheck() - Method in class org.elasticsearch.ingest.IngestDocument
- doNoSelfReferencesCheck(boolean) - Method in class org.elasticsearch.ingest.IngestDocument
-
Whether the ingest framework should perform a self referencing check after this ingest document has been processed by all pipelines.
- DoNotSync - Enum constant in enum class org.elasticsearch.action.support.replication.TransportReplicationAction.SyncGlobalCheckpointAfterOperation
-
Do not sync as part of this action
- doPostCollection() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Can be overridden by aggregator implementation to be called back when the collection phase ends.
- doPostCollection() - Method in class org.elasticsearch.search.aggregations.AggregatorCollector
- doPostCollection() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregator
- doPostCollection() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
- doPostCollection() - Method in record class org.elasticsearch.search.aggregations.BucketCollector.BucketCollectorWrapper
- doPostCollection() - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- doPostCollection() - Method in class org.elasticsearch.search.aggregations.metrics.GlobalOrdCardinalityAggregator
- doPostCollection() - Method in interface org.elasticsearch.search.internal.TwoPhaseCollector
-
run post-collection phase
- doPostCollection() - Method in class org.elasticsearch.search.profile.query.InternalProfileCollector
- doPostCollection() - Method in class org.elasticsearch.search.query.QueryPhaseCollector
- doPreCollection() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Can be overridden by aggregator implementation to be called back when the collection phase starts.
- doPreCollection() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregator
- doPreCollection() - Method in class org.elasticsearch.search.aggregations.bucket.DeferableBucketAggregator
- doReadString(int) - Method in class org.elasticsearch.common.io.stream.StreamInput
- doReduce(InternalAggregations, AggregationReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregator
- doReduce(InternalAggregations, AggregationReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.SiblingPipelineAggregator
- doRemotes() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequest
-
Should the remote cluster stats be included in the response.
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.RankDocsQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Rewrites this aggregation builder into its primitive form.
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.vectors.ExactKnnQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.vectors.KnnScoreDocQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.vectors.KnnVectorQueryBuilder
- doRun() - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
-
This method has the same semantics as
Runnable.run()
- doRun() - Method in class org.elasticsearch.threadpool.Scheduler.ReschedulingRunnable
- doSearchRewrite(SearchExecutionContext) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- doSearchRewrite(SearchExecutionContext) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- doSetNextReader(LeafReaderContext) - Method in class org.elasticsearch.lucene.grouping.SinglePassGroupingCollector
- doShapeQueryXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
writes the xcontent specific to this shape query
- doShapeQueryXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- doStart() - Method in class org.elasticsearch.cluster.coordination.Coordinator
- doStart() - Method in class org.elasticsearch.cluster.NodeConnectionsService
- doStart() - Method in class org.elasticsearch.cluster.routing.DelayedAllocationService
- doStart() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- doStart() - Method in class org.elasticsearch.cluster.service.ClusterService
- doStart() - Method in class org.elasticsearch.cluster.service.MasterService
- doStart() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
-
Start this component.
- doStart() - Method in class org.elasticsearch.common.file.AbstractFileWatchingService
- doStart() - Method in class org.elasticsearch.common.file.MasterNodeFileWatchingService
- doStart() - Method in class org.elasticsearch.discovery.SeedHostsResolver
- doStart() - Method in class org.elasticsearch.gateway.GatewayService
- doStart() - Method in class org.elasticsearch.health.HealthPeriodicLogger
- doStart() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
- doStart() - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
- doStart() - Method in class org.elasticsearch.indices.IndicesService
- doStart() - Method in class org.elasticsearch.indices.recovery.PeerRecoverySourceService
- doStart() - Method in class org.elasticsearch.indices.TimestampFieldMapperService
- doStart() - Method in class org.elasticsearch.monitor.fs.FsHealthService
- doStart() - Method in class org.elasticsearch.monitor.jvm.JvmGcMonitorService
- doStart() - Method in class org.elasticsearch.monitor.metrics.IndicesMetrics
- doStart() - Method in class org.elasticsearch.monitor.metrics.NodeMetrics
- doStart() - Method in class org.elasticsearch.monitor.MonitorService
- doStart() - Method in class org.elasticsearch.readiness.ReadinessService
- doStart() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- doStart() - Method in class org.elasticsearch.repositories.InvalidRepository
- doStart() - Method in class org.elasticsearch.repositories.RepositoriesService
- doStart() - Method in class org.elasticsearch.repositories.UnknownTypeRepository
- doStart() - Method in class org.elasticsearch.search.SearchService
- doStart() - Method in class org.elasticsearch.snapshots.SnapshotShardsService
- doStart() - Method in class org.elasticsearch.snapshots.SnapshotsService
- doStart() - Method in class org.elasticsearch.transport.TransportService
- doStart(RejectAwareActionListener<ScrollableHitSource.Response>) - Method in class org.elasticsearch.index.reindex.ClientScrollableHitSource
- doStart(RejectAwareActionListener<ScrollableHitSource.Response>) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource
- doStartNextScroll(String, TimeValue, RejectAwareActionListener<ScrollableHitSource.Response>) - Method in class org.elasticsearch.index.reindex.ClientScrollableHitSource
- doStartNextScroll(String, TimeValue, RejectAwareActionListener<ScrollableHitSource.Response>) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource
- doStop() - Method in class org.elasticsearch.cluster.coordination.Coordinator
- doStop() - Method in class org.elasticsearch.cluster.NodeConnectionsService
- doStop() - Method in class org.elasticsearch.cluster.routing.DelayedAllocationService
- doStop() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- doStop() - Method in class org.elasticsearch.cluster.service.ClusterService
- doStop() - Method in class org.elasticsearch.cluster.service.MasterService
- doStop() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
-
Stop this component.
- doStop() - Method in class org.elasticsearch.common.file.AbstractFileWatchingService
- doStop() - Method in class org.elasticsearch.common.file.MasterNodeFileWatchingService
- doStop() - Method in class org.elasticsearch.discovery.SeedHostsResolver
- doStop() - Method in class org.elasticsearch.gateway.GatewayService
- doStop() - Method in class org.elasticsearch.health.HealthPeriodicLogger
-
Stopping means that the periodic health logger will not schedule any more runs.
- doStop() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
-
Gracefully shut down.
- doStop() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
- doStop() - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
- doStop() - Method in class org.elasticsearch.indices.IndicesService
- doStop() - Method in class org.elasticsearch.indices.recovery.PeerRecoverySourceService
- doStop() - Method in class org.elasticsearch.indices.TimestampFieldMapperService
- doStop() - Method in class org.elasticsearch.monitor.fs.FsHealthService
- doStop() - Method in class org.elasticsearch.monitor.jvm.JvmGcMonitorService
- doStop() - Method in class org.elasticsearch.monitor.metrics.IndicesMetrics
- doStop() - Method in class org.elasticsearch.monitor.metrics.NodeMetrics
- doStop() - Method in class org.elasticsearch.monitor.MonitorService
- doStop() - Method in class org.elasticsearch.readiness.ReadinessService
- doStop() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- doStop() - Method in class org.elasticsearch.repositories.InvalidRepository
- doStop() - Method in class org.elasticsearch.repositories.RepositoriesService
- doStop() - Method in class org.elasticsearch.repositories.UnknownTypeRepository
- doStop() - Method in class org.elasticsearch.search.SearchService
- doStop() - Method in class org.elasticsearch.snapshots.SnapshotShardsService
- doStop() - Method in class org.elasticsearch.snapshots.SnapshotsService
- doStop() - Method in class org.elasticsearch.transport.TcpTransport
- doStop() - Method in class org.elasticsearch.transport.TransportService
- DOT_PRODUCT - Enum constant in enum class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.VectorSimilarity
- DOT_PRODUCT - Enum constant in enum class org.elasticsearch.inference.SimilarityMeasure
- doToFunction(SearchExecutionContext) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- doToFunction(SearchExecutionContext) - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- doToFunction(SearchExecutionContext) - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- doToFunction(SearchExecutionContext) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Build the Lucene ScoreFunction for this builder.
- doToFunction(SearchExecutionContext) - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- doToFunction(SearchExecutionContext) - Method in class org.elasticsearch.index.query.functionscore.WeightBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.DistanceFeatureQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.ExistsQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.IntervalQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.MatchNoneQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.RankDocsQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.ScriptQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.SpanTermQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.TermQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.TypeQueryV7Builder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.search.vectors.ExactKnnQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.search.vectors.KnnScoreDocQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.search.vectors.KnnVectorQueryBuilder
- doToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.rank.feature.RankFeatureDoc
- doToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.rank.RankDoc
- doToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.retriever.KnnRetrieverBuilder
- doToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.retriever.RankDocsRetrieverBuilder
- doToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.retriever.RetrieverBuilder
- doToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.retriever.RetrieverBuilderWrapper
- doToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.retriever.StandardRetrieverBuilder
- dotProduct() - Method in class org.elasticsearch.script.VectorScoreScriptUtils.BitDotProduct
- dotProduct() - Method in class org.elasticsearch.script.VectorScoreScriptUtils.ByteDotProduct
- dotProduct() - Method in class org.elasticsearch.script.VectorScoreScriptUtils.DotProduct
- dotProduct() - Method in interface org.elasticsearch.script.VectorScoreScriptUtils.DotProductInterface
- dotProduct() - Method in class org.elasticsearch.script.VectorScoreScriptUtils.FloatDotProduct
- dotProduct(byte[]) - Method in class org.elasticsearch.script.field.vectors.BinaryDenseVector
- dotProduct(byte[]) - Method in class org.elasticsearch.script.field.vectors.BitBinaryDenseVector
- dotProduct(byte[]) - Method in class org.elasticsearch.script.field.vectors.BitKnnDenseVector
- dotProduct(byte[]) - Method in class org.elasticsearch.script.field.vectors.ByteBinaryDenseVector
- dotProduct(byte[]) - Method in class org.elasticsearch.script.field.vectors.ByteKnnDenseVector
- dotProduct(byte[]) - Method in interface org.elasticsearch.script.field.vectors.DenseVector
- dotProduct(byte[]) - Method in class org.elasticsearch.script.field.vectors.KnnDenseVector
- dotProduct(float[]) - Method in class org.elasticsearch.script.field.vectors.BinaryDenseVector
- dotProduct(float[]) - Method in class org.elasticsearch.script.field.vectors.BitBinaryDenseVector
- dotProduct(float[]) - Method in class org.elasticsearch.script.field.vectors.BitKnnDenseVector
- dotProduct(float[]) - Method in class org.elasticsearch.script.field.vectors.ByteBinaryDenseVector
- dotProduct(float[]) - Method in class org.elasticsearch.script.field.vectors.ByteKnnDenseVector
- dotProduct(float[]) - Method in interface org.elasticsearch.script.field.vectors.DenseVector
- dotProduct(float[]) - Method in class org.elasticsearch.script.field.vectors.KnnDenseVector
- dotProduct(Object) - Method in interface org.elasticsearch.script.field.vectors.DenseVector
- dotProduct(List<Number>) - Method in class org.elasticsearch.script.field.vectors.BinaryDenseVector
- dotProduct(List<Number>) - Method in class org.elasticsearch.script.field.vectors.BitBinaryDenseVector
- dotProduct(List<Number>) - Method in class org.elasticsearch.script.field.vectors.BitKnnDenseVector
- dotProduct(List<Number>) - Method in class org.elasticsearch.script.field.vectors.ByteBinaryDenseVector
- dotProduct(List<Number>) - Method in class org.elasticsearch.script.field.vectors.ByteKnnDenseVector
- dotProduct(List<Number>) - Method in interface org.elasticsearch.script.field.vectors.DenseVector
- dotProduct(List<Number>) - Method in class org.elasticsearch.script.field.vectors.KnnDenseVector
- DotProduct(ScoreScript, Object, String) - Constructor for class org.elasticsearch.script.VectorScoreScriptUtils.DotProduct
- DOUBLE - Enum constant in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- DOUBLE - Enum constant in enum class org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- DOUBLE - Enum constant in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- DOUBLE - Enum constant in enum class org.elasticsearch.index.mapper.RangeType
- DOUBLE - Enum constant in enum class org.elasticsearch.search.aggregations.support.ValueType
-
Deprecated.
- DOUBLE_PAGE_SIZE - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- DOUBLE_PROCESSORS_SUPPORT_TRANSPORT_VERSION - Static variable in class org.elasticsearch.common.unit.Processors
- DOUBLE_PROCESSORS_SUPPORTED - Static variable in class org.elasticsearch.cluster.metadata.DesiredNode
- DoubleArray - Interface in org.elasticsearch.common.util
-
Abstraction of an array of double values.
- DoubleAsyncCounter - Interface in org.elasticsearch.telemetry.metric
-
A monotonically increasing double based on a callback.
- DoubleBinarySearcher(DoubleArray) - Constructor for class org.elasticsearch.common.util.BigArrays.DoubleBinarySearcher
- DoubleBounds - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
Represent hard_bounds and extended_bounds in histogram aggregations.
- DoubleBounds(Double, Double) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DoubleBounds
-
Construct with bounds.
- DoubleBounds(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DoubleBounds
-
Read from a stream.
- DoubleCounter - Interface in org.elasticsearch.telemetry.metric
-
A monotonically increasing metric that uses a double.
- DoubleDocValuesField - Class in org.elasticsearch.script.field
- DoubleDocValuesField(SortedNumericDoubleValues, String) - Constructor for class org.elasticsearch.script.field.DoubleDocValuesField
- doubleField(FieldInfo, double) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- doubleField(FieldInfo, double) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- doubleField(FieldInfo, double) - Method in class org.elasticsearch.search.internal.FilterFieldNamesProvidingStoredFieldsVisitor
- doubleField(FieldInfo, double) - Method in class org.elasticsearch.search.internal.FilterStoredFieldVisitor
- DoubleFieldScript - Class in org.elasticsearch.script
- DoubleFieldScript(String, Map<String, Object>, SearchLookup, OnScriptError, LeafReaderContext) - Constructor for class org.elasticsearch.script.DoubleFieldScript
- DoubleFieldScript.Emit - Class in org.elasticsearch.script
- DoubleFieldScript.Factory - Interface in org.elasticsearch.script
- DoubleFieldScript.LeafFactory - Interface in org.elasticsearch.script
- DoubleGauge - Interface in org.elasticsearch.telemetry.metric
-
Record non-additive double values based on a callback.
- DoubleHistogram - Interface in org.elasticsearch.telemetry.metric
-
Record arbitrary values that are summarized statistically, useful for percentiles and histograms.
- doubleRangeQuery(Object, Object, boolean, boolean, BiFunction<Double, Double, Query>) - Static method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- doubles(int) - Method in interface org.elasticsearch.index.mapper.BlockLoader.BlockFactory
-
Build a builder to load doubles without any loading constraints.
- Doubles(ScriptDocValues.Supplier<Double>) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- DoublesBlockLoader(String, BlockDocValuesReader.ToDouble) - Constructor for class org.elasticsearch.index.mapper.BlockDocValuesReader.DoublesBlockLoader
- DoublesBlockLoader(ValueFetcher, BlockSourceReader.LeafIteratorLookup) - Constructor for class org.elasticsearch.index.mapper.BlockSourceReader.DoublesBlockLoader
- DoubleScriptBlockDocValuesReader - Class in org.elasticsearch.index.mapper
-
BlockDocValuesReader
implementation fordouble
scripts. - DoubleScriptDocValues - Class in org.elasticsearch.index.fielddata
- DoubleScriptFieldData - Class in org.elasticsearch.index.fielddata
- DoubleScriptFieldData.Builder - Class in org.elasticsearch.index.fielddata
- DoubleScriptFieldData.DoubleScriptLeafFieldData - Class in org.elasticsearch.index.fielddata
- DoubleScriptFieldExistsQuery - Class in org.elasticsearch.search.runtime
- DoubleScriptFieldExistsQuery(Script, DoubleFieldScript.LeafFactory, String) - Constructor for class org.elasticsearch.search.runtime.DoubleScriptFieldExistsQuery
- DoubleScriptFieldRangeQuery - Class in org.elasticsearch.search.runtime
- DoubleScriptFieldRangeQuery(Script, DoubleFieldScript.LeafFactory, String, double, double) - Constructor for class org.elasticsearch.search.runtime.DoubleScriptFieldRangeQuery
- DoubleScriptFieldTermQuery - Class in org.elasticsearch.search.runtime
- DoubleScriptFieldTermQuery(Script, DoubleFieldScript.LeafFactory, String, double) - Constructor for class org.elasticsearch.search.runtime.DoubleScriptFieldTermQuery
- DoubleScriptFieldTermsQuery - Class in org.elasticsearch.search.runtime
- DoubleScriptFieldTermsQuery(Script, DoubleFieldScript.LeafFactory, String, Set<Long>) - Constructor for class org.elasticsearch.search.runtime.DoubleScriptFieldTermsQuery
-
Build the query.
- DoubleScriptFieldType - Class in org.elasticsearch.index.mapper
- doubleSetting(String, double, double, double, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- doubleSetting(String, double, double, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- doublesFromDocValues(int) - Method in interface org.elasticsearch.index.mapper.BlockLoader.BlockFactory
-
Build a builder to load doubles as loaded from doc values.
- DoublesSupplier(SortedNumericDoubleValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.DoublesSupplier
- DoubleTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Result of the
TermsAggregator
when the field is some kind of decimal number like a float, double, or distance. - DoubleTerms(String, BucketOrder, BucketOrder, int, long, Map<String, Object>, DocValueFormat, int, boolean, long, List<DoubleTerms.Bucket>, Long) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- DoubleTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
-
Read from a stream.
- DoubleTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- doubleToBytes(double) - Static method in class org.elasticsearch.common.Numbers
-
Converts a double to a byte array.
- DoubleUpDownCounter - Interface in org.elasticsearch.telemetry.metric
-
A counter that supports decreasing and increasing values.
- doubleValue() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic.LongAccessor
- doubleValue(Object) - Method in enum class org.elasticsearch.index.mapper.RangeType
-
Given the Range.to or Range.from Object value from a Range instance, converts that value into a Double.
- doubleValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.CellIdSource
- doubleValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
-
Get a double precision floating point view into the values in this leaf.
- doubleValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
- doubleValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
- doubleValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
- DoubleValuesComparatorSource - Class in org.elasticsearch.index.fielddata.fieldcomparator
-
Comparator source for double values.
- DoubleValuesComparatorSource(IndexNumericFieldData, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Constructor for class org.elasticsearch.index.fielddata.fieldcomparator.DoubleValuesComparatorSource
- DoubleValuesScript - Class in org.elasticsearch.script
-
A custom script that can be used for various DoubleValue Lucene operations.
- DoubleValuesScript() - Constructor for class org.elasticsearch.script.DoubleValuesScript
- DoubleValuesScript.Factory - Interface in org.elasticsearch.script
-
A factory to construct
DoubleValuesScript
instances. - DoubleWithAttributes - Record Class in org.elasticsearch.telemetry.metric
- DoubleWithAttributes(double) - Constructor for record class org.elasticsearch.telemetry.metric.DoubleWithAttributes
- DoubleWithAttributes(double, Map<String, Object>) - Constructor for record class org.elasticsearch.telemetry.metric.DoubleWithAttributes
-
Creates an instance of a
DoubleWithAttributes
record class. - doValidate(MappingLookup) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper
- doValidate(MappingLookup) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper
- doValidate(MappingLookup) - Method in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper
- doValidate(MappingLookup) - Method in class org.elasticsearch.index.mapper.FieldMapper
- doValidate(MappingLookup) - Method in class org.elasticsearch.index.mapper.IpFieldMapper
- doValidate(MappingLookup) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper
- doValidate(MappingLookup) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper
- DownsampleAction - Class in org.elasticsearch.action.downsample
- DownsampleAction.Request - Class in org.elasticsearch.action.downsample
- DownsampleConfig - Class in org.elasticsearch.action.downsample
-
This class holds the configuration details of a DownsampleAction that downsamples time series (TSDB) indices.
- DownsampleConfig(StreamInput) - Constructor for class org.elasticsearch.action.downsample.DownsampleConfig
- DownsampleConfig(DateHistogramInterval) - Constructor for class org.elasticsearch.action.downsample.DownsampleConfig
-
Create a new
DownsampleConfig
using the given configuration parameters. - downsampleIndexName() - Method in record class org.elasticsearch.cluster.metadata.LifecycleExecutionState
-
Returns the value of the
downsampleIndexName
record component. - DownsampleTask - Class in org.elasticsearch.action.downsample
-
This class contains the high-level logic that drives the rollup job.
- DownsampleTask(long, String, String, TaskId, String, DownsampleConfig, Map<String, String>) - Constructor for class org.elasticsearch.action.downsample.DownsampleTask
- downsampling(DataStreamLifecycle.Downsampling) - Method in class org.elasticsearch.cluster.metadata.DataStreamLifecycle.Builder
- Downsampling(List<DataStreamLifecycle.Downsampling.Round>) - Constructor for record class org.elasticsearch.cluster.metadata.DataStreamLifecycle.Downsampling
-
Creates an instance of a
Downsampling
record class. - DOWNSAMPLING_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStreamLifecycle
- doWrapDirectoryReader(DirectoryReader) - Method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
- doWrapDirectoryReader(DirectoryReader) - Method in class org.elasticsearch.index.engine.LazySoftDeletesDirectoryReaderWrapper
- doWrapDirectoryReader(DirectoryReader) - Method in class org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.BaseTermQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.DistanceFeatureQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.ExistsQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Write the subclass's components into the stream.
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.functionscore.WeightBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.IntervalQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.MatchNoneQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.RankDocsQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.ScriptQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.TermQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.TypeQueryV7Builder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.prefix.InternalIpPrefix
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.random.InternalRandomSampler
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.random.RandomSamplerAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalAvg
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalBounds
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalCardinality
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalCentroid
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalMedianAbsoluteDeviation
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalScriptedMetric
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTopHits
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalValueCount
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalWeightedAvg
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.Max
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.Min
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.Sum
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalBucketMetricValue
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Deprecated.
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.rank.feature.RankFeatureDoc
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.rank.RankBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.rank.RankDoc
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.vectors.ExactKnnQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.vectors.KnnScoreDocQueryBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.vectors.KnnVectorQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.DenseVectorFieldStats
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.FieldStats
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.IndexFeatureStats
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.SynonymsStats
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.RootObjectMapper
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.BaseTermQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.DistanceFeatureQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.ExistsQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Convert this subclass's data into XContent.
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.WeightBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IntervalQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MatchNoneQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.RankDocsQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.ScriptQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.TypeQueryV7Builder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.rank.RankBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.vectors.ExactKnnQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.vectors.KnnScoreDocQueryBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.vectors.KnnVectorQueryBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.FieldMapper
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.TextFieldMapper
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.composite.GeoTileGridValuesSourceBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.countedterms.CountedTermsAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.prefix.InternalIpPrefix
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.prefix.IpPrefixAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.random.InternalRandomSampler
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalAvg
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalBounds
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalCardinality
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalCentroid
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalMedianAbsoluteDeviation
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalScriptedMetric
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTopHits
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalValueCount
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalWeightedAvg
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.Max
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.Min
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.Sum
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalBucketMetricValue
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.MaxBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.MinBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.StatsBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.SumBucketPipelineAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- doXContentCommon(XContentBuilder, ToXContent.Params, Long, long, List<? extends AbstractInternalTerms.AbstractTermsBucket<?>>) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- doXContentCommon(XContentBuilder, ToXContent.Params, List<? extends InternalRareTerms.Bucket<?>>) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
- drain() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Drains all unassigned shards and returns it.
- drainTo(Collection<? super E>) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- drainTo(Collection<? super E>, int) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- drawCandidates(DirectCandidateGenerator.CandidateSet) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
- drawCandidates(DirectCandidateGenerator.CandidateSet) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- drawCandidates(DirectCandidateGenerator.CandidateSet) - Method in class org.elasticsearch.search.suggest.phrase.MultiCandidateGeneratorWrapper
- dropCorruptMarkerFiles(Terminal, Path, Directory, boolean) - Static method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- DROPDOWN - Enum constant in enum class org.elasticsearch.inference.configuration.SettingsConfigurationDisplayType
- dropHeadersContext() - Method in record class org.elasticsearch.cluster.ClusterStateTaskExecutor.BatchExecutionContext
-
Creates a context (a resource for use in a try-with-resources block) which captures and drops any emitted response headers, for cases where things like deprecation warnings may be emitted but cannot be associated with any specific task.
- dropHeadersContextSupplier() - Method in record class org.elasticsearch.cluster.ClusterStateTaskExecutor.BatchExecutionContext
-
Returns the value of the
dropHeadersContextSupplier
record component. - DropProcessor - Class in org.elasticsearch.ingest
-
Drop processor only returns
null
for the execution result to indicate that any document executed by it should not be indexed. - DropProcessor.Factory - Class in org.elasticsearch.ingest
- dryRun() - Method in class org.elasticsearch.action.admin.cluster.desirednodes.UpdateDesiredNodesResponse
- dryRun() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Returns the current dry run flag which allows to run the commands without actually applying them, just to get back the resulting cluster state back.
- dryRun(boolean) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Sets a dry run flag (defaults to
false
) allowing to run the commands without actually applying them to the cluster state, and getting the resulting cluster state back. - dryRun(boolean) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Sets if the rollover should not be executed when conditions are met
- dryRun(boolean) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- DslErrorInfo - Record Class in org.elasticsearch.health.node
-
Represents a reduced view into an
ErrorEntry
, removing the exception message and last occurrence timestamp as we could potentially send thousands of entries over the wire and the omitted fields would not be used. - DslErrorInfo(String, long, int) - Constructor for record class org.elasticsearch.health.node.DslErrorInfo
-
Creates an instance of a
DslErrorInfo
record class. - DslErrorInfo(StreamInput) - Constructor for record class org.elasticsearch.health.node.DslErrorInfo
- dslErrorsInfo() - Method in record class org.elasticsearch.health.node.DataStreamLifecycleHealthInfo
-
Returns the value of the
dslErrorsInfo
record component. - dslHealthInfo() - Method in record class org.elasticsearch.health.node.HealthInfo
-
Returns the value of the
dslHealthInfo
record component. - dslHealthInfo(DataStreamLifecycleHealthInfo) - Method in class org.elasticsearch.health.node.UpdateHealthInfoCacheAction.Request.Builder
- DUMMY_ENCODED_VALUE - Static variable in class org.elasticsearch.index.mapper.TimeSeriesRoutingHashFieldMapper
- DUMMY_TIMEOUT - Static variable in interface org.elasticsearch.reservedstate.ReservedClusterStateHandler
-
Reserved-state handlers create master-node requests but never actually send them to the master node so the timeouts are not relevant.
- duplicateBindingAnnotations(Member, Class<? extends Annotation>, Class<? extends Annotation>) - Method in class org.elasticsearch.injection.guice.internal.Errors
- DuplicateByteSequenceSpotter - Class in org.elasticsearch.lucene.analysis.miscellaneous
-
A Trie structure for analysing byte streams for duplicate sequences.
- DuplicateByteSequenceSpotter() - Constructor for class org.elasticsearch.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
- DuplicateSequenceAttribute - Interface in org.elasticsearch.lucene.analysis.miscellaneous
-
Provides statistics useful for detecting duplicate sections of text
- DuplicateSequenceAttributeImpl - Class in org.elasticsearch.lucene.analysis.miscellaneous
- DuplicateSequenceAttributeImpl() - Constructor for class org.elasticsearch.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- duration - Variable in class org.elasticsearch.script.TimeSeriesCounter.Counter
- DURATION - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.get.SnapshotSortKey
-
Sort by snapshot duration (end time minus start time).
- DVD - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- DVM - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- dvRangeQuery(String, BinaryDocValuesRangeQuery.QueryType, Object, Object, boolean, boolean) - Method in enum class org.elasticsearch.index.mapper.RangeType
- dvSupplier - Variable in class org.elasticsearch.index.mapper.vectors.DenseVectorScriptDocValues
- dvSupplier - Variable in class org.elasticsearch.index.mapper.vectors.MultiDenseVectorScriptDocValues
- dynamic - Variable in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- dynamic - Variable in class org.elasticsearch.index.mapper.ObjectMapper
- dynamic() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- dynamic() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- dynamic() - Method in record class org.elasticsearch.index.mapper.ObjectMapper.MergeResult
-
Returns the value of the
dynamic
record component. - dynamic(ObjectMapper.Dynamic) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- Dynamic - Enum constant in enum class org.elasticsearch.common.settings.Setting.Property
-
iff this setting can be dynamically updateable
- DYNAMIC - Static variable in class org.elasticsearch.index.mapper.ObjectMapper.Defaults
- DYNAMIC_DATE_TIME_FORMATTERS - Static variable in class org.elasticsearch.index.mapper.RootObjectMapper.Defaults
- DYNAMIC_TEMPLATES - Enum constant in enum class org.elasticsearch.ingest.IngestDocument.Metadata
- DYNAMIC_TEMPLATES - Static variable in class org.elasticsearch.script.Metadata
- DYNAMICALLY_MAP_DENSE_VECTORS_INDEX_VERSION - Static variable in class org.elasticsearch.index.mapper.DocumentParser
- DynamicContextDataProvider - Class in org.elasticsearch.common.logging
-
An implementation of log4j2's
ContextDataProvider
that can be configured at runtime (after being loaded by log4j's init mechanism). - DynamicContextDataProvider() - Constructor for class org.elasticsearch.common.logging.DynamicContextDataProvider
- dynamicDateTimeFormatter(Collection<DateFormatter>) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- dynamicDateTimeFormatters - Variable in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- dynamicDateTimeFormatters() - Method in class org.elasticsearch.index.mapper.RootObjectMapper
-
Public API
- DynamicFieldType - Interface in org.elasticsearch.index.mapper
-
Defines a MappedFieldType that exposes dynamic child field types If the field is named 'my_field', then a user is able to search on the field in both of the following ways: - Using the field name 'my_field', which will delegate to the field type as usual.
- DynamicMap - Class in org.elasticsearch.script
-
DynamicMap is used to wrap a Map for a script parameter.
- DynamicMap(Map<String, Object>, Map<String, Function<Object, Object>>) - Constructor for class org.elasticsearch.script.DynamicMap
- dynamicMappingsUpdate() - Method in class org.elasticsearch.index.mapper.ParsedDocument
-
Return dynamic updates to mappings or
null
if there were no updates to the mappings. - DynamicTemplate - Class in org.elasticsearch.index.mapper
- DynamicTemplate.MatchType - Enum Class in org.elasticsearch.index.mapper
- DynamicTemplate.XContentFieldType - Enum Class in org.elasticsearch.index.mapper
-
The type of a field as detected while parsing a json document.
- dynamicTemplateParserContext(DateFormatter) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- dynamicTemplates - Variable in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- dynamicTemplates() - Method in class org.elasticsearch.index.mapper.RootObjectMapper
-
Public API
- dynamicTemplates() - Method in class org.elasticsearch.index.mapper.SourceToParse
-
Returns a map from the full path (i.e.
- dynamicTemplates(Collection<DynamicTemplate>) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
E
- EAGER_SINGLETON - Static variable in class org.elasticsearch.injection.guice.internal.Scoping
- eagerGlobalOrdinals() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.RootFlattenedFieldType
- eagerGlobalOrdinals() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- eagerGlobalOrdinals() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- eagerGlobalOrdinals() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- eagerPartition(List<E>, int) - Static method in class org.elasticsearch.common.util.CollectionUtils
- EARTH_EQUATOR - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Earth ellipsoid equator length in meters
- EARTH_MEAN_RADIUS - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Earth mean radius defined by WGS 84 in meters
- EARTH_POLAR_DISTANCE - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Earth ellipsoid polar distance in meters
- EARTH_SEMI_MAJOR_AXIS - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Earth ellipsoid major axis defined by WGS 84 in meters
- EARTH_SEMI_MINOR_AXIS - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Earth ellipsoid minor axis defined by WGS 84 in meters
- ECS_VERSION - Static variable in class org.elasticsearch.common.logging.DeprecatedMessage
- ECSJsonLayout - Class in org.elasticsearch.common.logging
-
This is a wrapper class around
co.elastic.logging.log4j2.EcsLayout
in order to avoid a duplication of configuration in log4j2.properties - ECSJsonLayout() - Constructor for class org.elasticsearch.common.logging.ECSJsonLayout
- ECSJsonLayout.Builder - Class in org.elasticsearch.common.logging
- EFFECTIVE_RETENTION_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStreamLifecycle
- EFFECTIVE_RETENTION_REST_API_CAPABILITY - Static variable in class org.elasticsearch.cluster.metadata.DataStreamLifecycle
- ELASTIC_ORIGIN_FIELD_NAME - Static variable in class org.elasticsearch.common.logging.DeprecatedMessage
- Elasticsearch814Codec - Class in org.elasticsearch.index.codec
-
Elasticsearch codec as of 8.14.
- Elasticsearch814Codec() - Constructor for class org.elasticsearch.index.codec.Elasticsearch814Codec
-
Public no-arg constructor, needed for SPI loading at read-time.
- Elasticsearch814Codec(Zstd814StoredFieldsFormat.Mode) - Constructor for class org.elasticsearch.index.codec.Elasticsearch814Codec
-
Constructor.
- Elasticsearch816Codec - Class in org.elasticsearch.index.codec
-
Elasticsearch codec as of 8.16.
- Elasticsearch816Codec() - Constructor for class org.elasticsearch.index.codec.Elasticsearch816Codec
-
Public no-arg constructor, needed for SPI loading at read-time.
- Elasticsearch816Codec(Zstd814StoredFieldsFormat.Mode) - Constructor for class org.elasticsearch.index.codec.Elasticsearch816Codec
-
Constructor.
- ElasticsearchAuthenticationProcessingError - Exception in org.elasticsearch
-
Used to indicate that the authentication process encountered a server-side error (5xx) that prevented the credentials verification.
- ElasticsearchAuthenticationProcessingError(String, RestStatus, Throwable, Object...) - Constructor for exception org.elasticsearch.ElasticsearchAuthenticationProcessingError
- ElasticsearchAuthenticationProcessingError(StreamInput) - Constructor for exception org.elasticsearch.ElasticsearchAuthenticationProcessingError
- ElasticsearchClient - Interface in org.elasticsearch.client.internal
- ElasticsearchConcurrentMergeScheduler - Class in org.elasticsearch.index.engine
-
An extension to the
ConcurrentMergeScheduler
that provides tracking on merge times, total and current merges. - ElasticsearchCorruptionException - Exception in org.elasticsearch
-
This exception is thrown when Elasticsearch detects an inconsistency in one of it's persistent files.
- ElasticsearchCorruptionException(String) - Constructor for exception org.elasticsearch.ElasticsearchCorruptionException
-
Creates a new
ElasticsearchCorruptionException
- ElasticsearchCorruptionException(Throwable) - Constructor for exception org.elasticsearch.ElasticsearchCorruptionException
-
Creates a new
ElasticsearchCorruptionException
with the given exceptions stacktrace. - ElasticsearchDirectoryReader - Class in org.elasticsearch.common.lucene.index
-
A
FilterDirectoryReader
that exposes Elasticsearch internal per shard / index information like the shard ID. - ElasticsearchException - Exception in org.elasticsearch
-
A base class for all elasticsearch exceptions.
- ElasticsearchException(String, Object...) - Constructor for exception org.elasticsearch.ElasticsearchException
-
Construct a
ElasticsearchException
with the specified detail message. - ElasticsearchException(String, Throwable, Object...) - Constructor for exception org.elasticsearch.ElasticsearchException
-
Construct a
ElasticsearchException
with the specified detail message and nested exception. - ElasticsearchException(Throwable) - Constructor for exception org.elasticsearch.ElasticsearchException
-
Construct a
ElasticsearchException
with the specified cause exception. - ElasticsearchException(StreamInput) - Constructor for exception org.elasticsearch.ElasticsearchException
- ElasticsearchGenerationException - Exception in org.elasticsearch
-
A generic exception indicating failure to generate.
- ElasticsearchGenerationException(String) - Constructor for exception org.elasticsearch.ElasticsearchGenerationException
- ElasticsearchGenerationException(String, Throwable) - Constructor for exception org.elasticsearch.ElasticsearchGenerationException
- ElasticsearchGenerationException(StreamInput) - Constructor for exception org.elasticsearch.ElasticsearchGenerationException
- ElasticsearchLeafReader - Class in org.elasticsearch.common.lucene.index
-
A
FilterLeafReader
that exposes Elasticsearch internal per shard / index information like the shard ID. - ElasticsearchLeafReader(LeafReader, ShardId) - Constructor for class org.elasticsearch.common.lucene.index.ElasticsearchLeafReader
-
Construct a FilterLeafReader based on the specified base reader.
- ElasticsearchMergeScheduler - Interface in org.elasticsearch.index.engine
- ElasticsearchNodeCommand - Class in org.elasticsearch.cluster.coordination
- ElasticsearchNodeCommand(String) - Constructor for class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- ElasticsearchNodeCommand.UnknownCondition - Class in org.elasticsearch.cluster.coordination
- ElasticsearchNodeCommand.UnknownMetadataCustom - Record Class in org.elasticsearch.cluster.coordination
- ElasticsearchParseException - Exception in org.elasticsearch
-
Unchecked exception that is translated into a
400 BAD REQUEST
error when it bubbles out over HTTP. - ElasticsearchParseException(String, Object...) - Constructor for exception org.elasticsearch.ElasticsearchParseException
- ElasticsearchParseException(String, Throwable, Object...) - Constructor for exception org.elasticsearch.ElasticsearchParseException
- ElasticsearchParseException(StreamInput) - Constructor for exception org.elasticsearch.ElasticsearchParseException
- ElasticsearchProcess - Class in org.elasticsearch.bootstrap
-
Helper class to determine if the ES process is shutting down
- ElasticsearchProcess() - Constructor for class org.elasticsearch.bootstrap.ElasticsearchProcess
- ElasticsearchReaderManager - Class in org.elasticsearch.index.engine
-
Utility class to safely share
ElasticsearchDirectoryReader
instances across multiple threads, while periodically reopening. - ElasticsearchReaderManager(ElasticsearchDirectoryReader) - Constructor for class org.elasticsearch.index.engine.ElasticsearchReaderManager
-
Creates and returns a new ElasticsearchReaderManager from the given already-opened
ElasticsearchDirectoryReader
, stealing the incoming reference. - ElasticsearchRoleRestrictionException - Exception in org.elasticsearch
-
This exception is thrown to indicate that the access has been denied because of role restrictions that an authenticated subject might have (e.g.
- ElasticsearchRoleRestrictionException(String, Object...) - Constructor for exception org.elasticsearch.ElasticsearchRoleRestrictionException
- ElasticsearchRoleRestrictionException(String, Throwable, Object...) - Constructor for exception org.elasticsearch.ElasticsearchRoleRestrictionException
- ElasticsearchRoleRestrictionException(StreamInput) - Constructor for exception org.elasticsearch.ElasticsearchRoleRestrictionException
- ElasticsearchSecurityException - Exception in org.elasticsearch
-
Generic security exception
- ElasticsearchSecurityException(String, Exception, Object...) - Constructor for exception org.elasticsearch.ElasticsearchSecurityException
-
Build the exception with the status derived from the cause.
- ElasticsearchSecurityException(String, Object...) - Constructor for exception org.elasticsearch.ElasticsearchSecurityException
-
Build the exception with a status of
RestStatus.INTERNAL_SERVER_ERROR
without a cause. - ElasticsearchSecurityException(String, RestStatus, Object...) - Constructor for exception org.elasticsearch.ElasticsearchSecurityException
-
Build the exception without a cause.
- ElasticsearchSecurityException(String, RestStatus, Throwable, Object...) - Constructor for exception org.elasticsearch.ElasticsearchSecurityException
-
Build the exception with a specific status and cause.
- ElasticsearchSecurityException(StreamInput) - Constructor for exception org.elasticsearch.ElasticsearchSecurityException
-
Read from a stream.
- ElasticsearchStatusException - Exception in org.elasticsearch
-
Exception who's
RestStatus
is arbitrary rather than derived. - ElasticsearchStatusException(String, RestStatus, Object...) - Constructor for exception org.elasticsearch.ElasticsearchStatusException
-
Build the exception without a cause.
- ElasticsearchStatusException(String, RestStatus, Throwable, Object...) - Constructor for exception org.elasticsearch.ElasticsearchStatusException
-
Build the exception with a specific status and cause.
- ElasticsearchStatusException(StreamInput) - Constructor for exception org.elasticsearch.ElasticsearchStatusException
-
Read from a stream.
- ElasticsearchTimeoutException - Exception in org.elasticsearch
-
The same as
TimeoutException
simply a runtime one. - ElasticsearchTimeoutException(String, Object...) - Constructor for exception org.elasticsearch.ElasticsearchTimeoutException
- ElasticsearchTimeoutException(String, Throwable, Object...) - Constructor for exception org.elasticsearch.ElasticsearchTimeoutException
- ElasticsearchTimeoutException(Throwable) - Constructor for exception org.elasticsearch.ElasticsearchTimeoutException
- ElasticsearchTimeoutException(StreamInput) - Constructor for exception org.elasticsearch.ElasticsearchTimeoutException
- ElasticsearchWrapperException - Interface in org.elasticsearch
-
An exception that is meant to be "unwrapped" when sent back to the user as an error because its is
cause
, if non-null is always more useful to the user than the exception itself. - ELECTION_BACK_OFF_TIME_SETTING - Static variable in class org.elasticsearch.cluster.coordination.ElectionSchedulerFactory
- ELECTION_DURATION_SETTING - Static variable in class org.elasticsearch.cluster.coordination.ElectionSchedulerFactory
- ELECTION_INITIAL_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.ElectionSchedulerFactory
- ELECTION_MAX_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.ElectionSchedulerFactory
- ELECTION_STRATEGY_SETTING - Static variable in class org.elasticsearch.discovery.DiscoveryModule
- ElectionSchedulerFactory - Class in org.elasticsearch.cluster.coordination
-
It's provably impossible to guarantee that any leader election algorithm ever elects a leader, but they generally work (with probability that approaches 1 over time) as long as elections occur sufficiently infrequently, compared to the time it takes to send a message to another node and receive a response back.
- ElectionSchedulerFactory(Settings, Random, ThreadPool) - Constructor for class org.elasticsearch.cluster.coordination.ElectionSchedulerFactory
- ElectionStrategy - Class in org.elasticsearch.cluster.coordination
-
Allows plugging in a custom election strategy, restricting the notion of an election quorum.
- ElectionStrategy() - Constructor for class org.elasticsearch.cluster.coordination.ElectionStrategy
- ElectionStrategy.NodeEligibility - Record Class in org.elasticsearch.cluster.coordination
-
Contains a result for whether a node may win an election and the reason if not.
- electionWon() - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- element() - Method in class org.elasticsearch.common.collect.EvictingQueue
- Element - Interface in org.elasticsearch.injection.guice.spi
-
A core component of a module or injector.
- elements - Variable in class org.elasticsearch.injection.guice.internal.AbstractBindingBuilder
- Elements - Class in org.elasticsearch.injection.guice.spi
-
Exposes elements of a module so they can be inspected or validated.
- Elements() - Constructor for class org.elasticsearch.injection.guice.spi.Elements
- elementType - Variable in class org.elasticsearch.script.field.vectors.DenseVectorDocValuesField
- elementType - Variable in class org.elasticsearch.script.field.vectors.MultiDenseVectorDocValuesField
- elementType() - Method in interface org.elasticsearch.inference.ServiceSettings
-
The data type for the embeddings this service works with.
- elementType(DenseVectorFieldMapper.ElementType) - Method in class org.elasticsearch.index.mapper.vectors.DenseVectorFieldMapper.Builder
- elementType(DenseVectorFieldMapper.ElementType) - Method in class org.elasticsearch.index.mapper.vectors.MultiDenseVectorFieldMapper.Builder
- ElementVisitor<V> - Interface in org.elasticsearch.injection.guice.spi
-
Visit elements.
- emit(boolean) - Method in class org.elasticsearch.script.BooleanFieldScript
- emit(double) - Method in class org.elasticsearch.script.DoubleFieldScript
- emit(double) - Method in class org.elasticsearch.script.DoubleFieldScript.Emit
- emit(double, double) - Method in class org.elasticsearch.script.GeoPointFieldScript
- emit(double, double) - Method in class org.elasticsearch.script.GeoPointFieldScript.Emit
- emit(long) - Method in class org.elasticsearch.script.AbstractLongFieldScript
- emit(long) - Method in class org.elasticsearch.script.DateFieldScript.Emit
- emit(long) - Method in class org.elasticsearch.script.LongFieldScript.Emit
- emit(Object) - Method in class org.elasticsearch.script.GeometryFieldScript.Emit
- emit(String) - Method in class org.elasticsearch.script.IpFieldScript
- emit(String) - Method in class org.elasticsearch.script.IpFieldScript.Emit
- emit(String) - Method in class org.elasticsearch.script.StringFieldScript
- emit(String) - Method in class org.elasticsearch.script.StringFieldScript.Emit
- emit(String, Object) - Method in class org.elasticsearch.script.CompositeFieldScript
- emit(String, Object) - Method in class org.elasticsearch.script.CompositeFieldScript.EmitField
-
Emits a value for the provided field.
- emit(Map<String, Object>) - Method in class org.elasticsearch.script.CompositeFieldScript.EmitMap
-
Emits all the subfields in one go.
- Emit(BooleanFieldScript) - Constructor for class org.elasticsearch.script.BooleanFieldScript.Emit
- Emit(DateFieldScript) - Constructor for class org.elasticsearch.script.DateFieldScript.Emit
- Emit(DoubleFieldScript) - Constructor for class org.elasticsearch.script.DoubleFieldScript.Emit
- Emit(GeometryFieldScript) - Constructor for class org.elasticsearch.script.GeometryFieldScript.Emit
- Emit(GeoPointFieldScript) - Constructor for class org.elasticsearch.script.GeoPointFieldScript.Emit
- Emit(IpFieldScript) - Constructor for class org.elasticsearch.script.IpFieldScript.Emit
- Emit(LongFieldScript) - Constructor for class org.elasticsearch.script.LongFieldScript.Emit
- Emit(StringFieldScript) - Constructor for class org.elasticsearch.script.StringFieldScript.Emit
- EmitField(CompositeFieldScript) - Constructor for class org.elasticsearch.script.CompositeFieldScript.EmitField
- emitFromCompositeScript(CompositeFieldScript) - Method in class org.elasticsearch.script.AbstractFieldScript
- emitFromObject(Object) - Method in class org.elasticsearch.script.AbstractFieldScript
- emitFromObject(Object) - Method in class org.elasticsearch.script.BooleanFieldScript
- emitFromObject(Object) - Method in class org.elasticsearch.script.CompositeFieldScript
- emitFromObject(Object) - Method in class org.elasticsearch.script.DateFieldScript
- emitFromObject(Object) - Method in class org.elasticsearch.script.DoubleFieldScript
- emitFromObject(Object) - Method in class org.elasticsearch.script.GeometryFieldScript
- emitFromObject(Object) - Method in class org.elasticsearch.script.GeoPointFieldScript
- emitFromObject(Object) - Method in class org.elasticsearch.script.IpFieldScript
- emitFromObject(Object) - Method in class org.elasticsearch.script.LongFieldScript
- emitFromObject(Object) - Method in class org.elasticsearch.script.SortedNumericDocValuesLongFieldScript
- emitFromObject(Object) - Method in class org.elasticsearch.script.StringFieldScript
- emitFromSource() - Method in class org.elasticsearch.script.AbstractFieldScript
- EmitMap(CompositeFieldScript) - Constructor for class org.elasticsearch.script.CompositeFieldScript.EmitMap
- emitValueFromCompositeScript(Object) - Method in class org.elasticsearch.script.AbstractFieldScript
- emitValueFromCompositeScript(Object) - Method in class org.elasticsearch.script.StringFieldScript
- empty() - Static method in record class org.elasticsearch.cluster.metadata.Manifest
- empty() - Static method in interface org.elasticsearch.cluster.SimpleDiffable
- empty() - Static method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- empty() - Method in class org.elasticsearch.gateway.PersistedClusterStateService.OnDiskState
- empty() - Static method in interface org.elasticsearch.http.HttpBody
- empty() - Static method in class org.elasticsearch.index.fieldvisitor.StoredFieldLoader
-
Creates a no-op StoredFieldLoader that will not load any fields from disk
- empty() - Static method in record class org.elasticsearch.index.mapper.FieldMapper.BuilderParams
- empty() - Static method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo
- empty() - Static method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields
- empty() - Static method in class org.elasticsearch.index.mapper.IgnoreMalformedStoredValues
-
Build a
IgnoreMalformedStoredValues
that never contains any values. - empty() - Static method in class org.elasticsearch.search.sort.SortValue
-
Get a SortValue for data which cannot be sorted.
- empty(String, boolean, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- empty(String, double[], boolean, DocValueFormat, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks
- empty(String, double[], boolean, DocValueFormat, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- empty(String, double[], boolean, DocValueFormat, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- empty(String, double[], double, TDigestExecutionHint, boolean, DocValueFormat, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks
- empty(String, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- empty(String, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalValueCount
- empty(String, DocValueFormat, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalAvg
- empty(String, DocValueFormat, Map<String, Object>) - Static method in class org.elasticsearch.search.aggregations.metrics.Sum
- empty(Executor, ActionListener<Void>) - Static method in interface org.elasticsearch.transport.TransportResponseHandler
- empty(Supplier<Long>, SearchResponse.Clusters) - Static method in class org.elasticsearch.action.search.SearchResponse
- empty(TotalHits, float) - Static method in class org.elasticsearch.search.SearchHits
- empty(ToScriptFieldFactory<SortedSetDocValues>) - Static method in class org.elasticsearch.index.fielddata.plain.AbstractLeafOrdinalsFieldData
- empty(XContentType) - Static method in interface org.elasticsearch.search.lookup.Source
-
An empty Source, represented as an empty map
- Empty() - Constructor for class org.elasticsearch.action.ActionResponse.Empty
- Empty() - Constructor for class org.elasticsearch.transport.TransportResponseHandler.Empty
- EMPTY - Enum constant in enum class org.elasticsearch.index.query.RegexpFlag
-
Enables empty language expression:
#
- EMPTY - Static variable in record class org.elasticsearch.action.admin.cluster.allocation.DesiredBalanceResponse.ShardAssignmentView
- EMPTY - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotResponse
- EMPTY - Static variable in record class org.elasticsearch.action.admin.cluster.stats.RepositoryUsageStats
- EMPTY - Static variable in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse
- EMPTY - Static variable in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse
- EMPTY - Static variable in record class org.elasticsearch.action.search.SearchPhaseController.SortedTopDocs
- EMPTY - Static variable in class org.elasticsearch.action.search.SearchResponse.Clusters
- EMPTY - Static variable in class org.elasticsearch.action.support.broadcast.BaseBroadcastResponse
- EMPTY - Static variable in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- EMPTY - Static variable in class org.elasticsearch.cluster.ClusterInfo
- EMPTY - Static variable in record class org.elasticsearch.cluster.ClusterInfo.ReservedSpace
- EMPTY - Static variable in record class org.elasticsearch.cluster.ClusterSnapshotStats
- EMPTY - Static variable in class org.elasticsearch.cluster.coordination.ClusterStateSerializationStats
- EMPTY - Static variable in record class org.elasticsearch.cluster.coordination.CoordinationDiagnosticsService.CoordinationDiagnosticsDetails
- EMPTY - Static variable in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- EMPTY - Static variable in record class org.elasticsearch.cluster.metadata.DataStreamOptions
- EMPTY - Static variable in class org.elasticsearch.cluster.metadata.DesiredNodesMetadata
- EMPTY - Static variable in class org.elasticsearch.cluster.metadata.DiffableStringMap.DiffableStringMapDiff
- EMPTY - Static variable in class org.elasticsearch.cluster.metadata.DiffableStringMap
- EMPTY - Static variable in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- EMPTY - Static variable in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
- EMPTY - Static variable in class org.elasticsearch.cluster.RepositoryCleanupInProgress
- EMPTY - Static variable in class org.elasticsearch.cluster.RestoreInProgress
- EMPTY - Static variable in record class org.elasticsearch.cluster.routing.allocation.allocator.ClusterBalanceStats
- EMPTY - Static variable in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- EMPTY - Static variable in interface org.elasticsearch.cluster.SimpleDiffable
- EMPTY - Static variable in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- EMPTY - Static variable in class org.elasticsearch.cluster.SnapshotsInProgress
- EMPTY - Static variable in record class org.elasticsearch.cluster.version.CompatibilityVersions
- EMPTY - Static variable in class org.elasticsearch.common.blobstore.BlobPath
- EMPTY - Static variable in class org.elasticsearch.common.blobstore.OptionalBytesReference
- EMPTY - Static variable in class org.elasticsearch.common.bytes.BytesArray
- EMPTY - Static variable in class org.elasticsearch.common.settings.Settings
- EMPTY - Static variable in interface org.elasticsearch.common.xcontent.ChunkedToXContent
-
A
ChunkedToXContent
that yields no chunks - EMPTY - Static variable in interface org.elasticsearch.health.HealthIndicatorDetails
- EMPTY - Static variable in record class org.elasticsearch.http.HttpRouteStats
- EMPTY - Static variable in record class org.elasticsearch.index.engine.SafeCommitInfo
- EMPTY - Static variable in class org.elasticsearch.index.mapper.Mapping
- EMPTY - Static variable in class org.elasticsearch.index.mapper.MappingLookup
-
A lookup representing an empty mapping.
- EMPTY - Static variable in interface org.elasticsearch.index.mapper.NestedLookup
-
A NestedLookup for a mapping with no nested mappers
- EMPTY - Static variable in interface org.elasticsearch.index.mapper.ValueFetcher
- EMPTY - Static variable in class org.elasticsearch.index.seqno.RetentionLeases
-
Represents an empty an un-versioned retention lease collection.
- EMPTY - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseSyncer
- EMPTY - Static variable in class org.elasticsearch.index.shard.IndexLongFieldRange
-
Sentinel value indicating an empty range, for instance because the field is missing or has no values in any shard.
- EMPTY - Static variable in class org.elasticsearch.index.shard.ShardLongFieldRange
-
Sentinel value indicating an empty range, for instance because the field is missing or has no values.
- EMPTY - Static variable in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
- EMPTY - Static variable in record class org.elasticsearch.index.store.Store.MetadataSnapshot
- EMPTY - Static variable in interface org.elasticsearch.index.store.Store.OnClose
- EMPTY - Static variable in record class org.elasticsearch.index.translog.Translog.Location
- EMPTY - Static variable in interface org.elasticsearch.index.translog.Translog.Snapshot
- EMPTY - Static variable in record class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan.SnapshotFilesToRecover
- EMPTY - Static variable in record class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
- EMPTY - Static variable in class org.elasticsearch.repositories.IndexMetaDataGenerations
- EMPTY - Static variable in class org.elasticsearch.repositories.RepositoryData
-
An instance initialized for an empty repository.
- EMPTY - Static variable in class org.elasticsearch.repositories.RepositoryData.SnapshotDetails
- EMPTY - Static variable in class org.elasticsearch.repositories.ShardGenerations
- EMPTY - Static variable in interface org.elasticsearch.script.field.vectors.DenseVector
- EMPTY - Static variable in interface org.elasticsearch.script.field.vectors.MultiDenseVector
- EMPTY - Static variable in class org.elasticsearch.search.aggregations.AggregatorFactories
- EMPTY - Static variable in interface org.elasticsearch.search.aggregations.bucket.terms.BytesKeyedBucketOrds.BucketOrdsEnum
-
An BytesKeyedBucketOrds.BucketOrdsEnum that is empty.
- EMPTY - Static variable in interface org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.BucketOrdsEnum
-
An LongKeyedBucketOrds.BucketOrdsEnum that is empty.
- EMPTY - Static variable in class org.elasticsearch.search.aggregations.InternalAggregations
- EMPTY - Static variable in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.PipelineTree
-
An empty tree of
PipelineAggregator
s. - EMPTY - Static variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
- EMPTY - Static variable in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint
- EMPTY - Static variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
- EMPTY - Static variable in class org.elasticsearch.search.fetch.subphase.UnmappedFieldFetcher
- EMPTY - Static variable in class org.elasticsearch.search.internal.AliasFilter
- EMPTY - Static variable in class org.elasticsearch.search.RescoreDocIds
- EMPTY - Static variable in class org.elasticsearch.search.SearchHits
- EMPTY - Static variable in class org.elasticsearch.search.suggest.phrase.Correction
- EMPTY - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- EMPTY - Static variable in class org.elasticsearch.snapshots.RegisteredPolicySnapshots
- EMPTY - Static variable in class org.elasticsearch.snapshots.SnapshotShardSizeInfo
- EMPTY - Static variable in class org.elasticsearch.transport.RemoteClusterCredentialsManager
- EMPTY - Static variable in class org.elasticsearch.transport.TransportRequestOptions
- EMPTY_ARRAY - Static variable in exception org.elasticsearch.action.search.ShardSearchFailure
- EMPTY_ARRAY - Static variable in class org.elasticsearch.common.Strings
- EMPTY_ARRAY - Static variable in class org.elasticsearch.common.text.Text
- EMPTY_ARRAY - Static variable in class org.elasticsearch.index.Index
- EMPTY_ARRAY - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- EMPTY_CLUSTER_BLOCK - Static variable in class org.elasticsearch.cluster.block.ClusterBlocks
- EMPTY_CONFIG - Static variable in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfiguration
- EMPTY_FIELDS - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.SourceSimpleFragmentsBuilder
- EMPTY_HEALTH_INFO - Static variable in record class org.elasticsearch.health.node.HealthInfo
- EMPTY_INSTANCE - Static variable in interface org.elasticsearch.plugins.internal.DocumentParsingProvider
- EMPTY_INSTANCE - Static variable in interface org.elasticsearch.plugins.internal.DocumentSizeAccumulator
- EMPTY_INSTANCE - Static variable in interface org.elasticsearch.plugins.internal.DocumentSizeReporter
-
a default noop implementation
- EMPTY_ITERATOR - Static variable in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- EMPTY_ITERATOR - Static variable in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- EMPTY_MAPPINGS - Static variable in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- EMPTY_MAPPINGS - Static variable in class org.elasticsearch.cluster.metadata.MappingMetadata
- EMPTY_METADATA - Static variable in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- EMPTY_METADATA - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- EMPTY_NODES - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodes
- EMPTY_REPO_GEN - Static variable in class org.elasticsearch.repositories.RepositoryData
-
The generation value indicating the repository has no index generational files.
- EMPTY_RESULT - Static variable in class org.elasticsearch.search.rank.feature.RankFeatureShardPhase
- EMPTY_ROUTING_TABLE - Static variable in class org.elasticsearch.cluster.routing.RoutingTable
- EMPTY_SCORE_DOCS - Static variable in class org.elasticsearch.common.lucene.Lucene
- EMPTY_STATE - Static variable in class org.elasticsearch.action.bulk.IncrementalBulkService.Handler
- EMPTY_STATE - Static variable in class org.elasticsearch.cluster.ClusterState
- EMPTY_STATE - Static variable in record class org.elasticsearch.cluster.metadata.LifecycleExecutionState
- EMPTY_STATS - Static variable in class org.elasticsearch.repositories.RepositoryStats
- EMPTY_STORE - Enum constant in enum class org.elasticsearch.cluster.routing.RecoverySource.Type
- EMPTY_TASK_ID - Static variable in class org.elasticsearch.tasks.TaskId
- EMPTY_TOP_DOCS - Static variable in class org.elasticsearch.common.lucene.Lucene
- EMPTY_TRANSLOG_BUFFER_SIZE - Static variable in class org.elasticsearch.index.translog.TranslogConfig
- EMPTY_TYPE_ARRAY - Static variable in class org.elasticsearch.injection.guice.internal.MoreTypes
- EMPTY_VERSION - Static variable in record class org.elasticsearch.cluster.metadata.ReservedStateMetadata
- EMPTY_WITH_TOTAL_HITS - Static variable in class org.elasticsearch.action.search.SearchResponseSections
- EMPTY_WITH_TOTAL_HITS - Static variable in class org.elasticsearch.search.SearchHits
- EMPTY_WITHOUT_TOTAL_HITS - Static variable in class org.elasticsearch.action.search.SearchResponseSections
- EMPTY_WITHOUT_TOTAL_HITS - Static variable in class org.elasticsearch.search.SearchHits
- EmptyBucketInfo(double, double, double, double, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.EmptyBucketInfo
- EmptyClusterInfoService - Class in org.elasticsearch.cluster
-
ClusterInfoService
that provides empty maps for disk usage and shard sizes - EmptyClusterInfoService() - Constructor for class org.elasticsearch.cluster.EmptyClusterInfoService
- emptyDiff() - Static method in class org.elasticsearch.cluster.DiffableUtils
- EmptyDoubleHdrHistogram - Class in org.elasticsearch.search.aggregations.metrics
- EmptyDoubleHdrHistogram() - Constructor for class org.elasticsearch.search.aggregations.metrics.EmptyDoubleHdrHistogram
- EmptyField - Class in org.elasticsearch.script.field
-
A script
Field
with no mapping, always returnsdefaultValue
. - EmptyField(String) - Constructor for class org.elasticsearch.script.field.EmptyField
- emptyNumericDouble() - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Return a
NumericDoubleValues
that doesn't contain any value. - emptyResponse() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportUnpromotableShardRefreshAction
- emptyResponse() - Method in class org.elasticsearch.action.support.broadcast.unpromotable.TransportBroadcastUnpromotableAction
- emptyResponse(String) - Static method in class org.elasticsearch.action.RemoteClusterActionType
- EmptySecretSettings - Record Class in org.elasticsearch.inference
-
This class defines an empty secret settings object.
- EmptySecretSettings() - Constructor for record class org.elasticsearch.inference.EmptySecretSettings
-
Creates an instance of a
EmptySecretSettings
record class. - EmptySecretSettings(StreamInput) - Constructor for record class org.elasticsearch.inference.EmptySecretSettings
- emptySeqID() - Static method in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SequenceIDFields
-
Build and empty sequence ID who's values can be assigned later by calling
SeqNoFieldMapper.SequenceIDFields.set(long, long)
. - EmptySettingsConfiguration - Class in org.elasticsearch.inference
- EmptySettingsConfiguration() - Constructor for class org.elasticsearch.inference.EmptySettingsConfiguration
- EmptySnapshotsInfoService - Class in org.elasticsearch.snapshots
- EmptySnapshotsInfoService() - Constructor for class org.elasticsearch.snapshots.EmptySnapshotsInfoService
- emptySortedBinary() - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Return a
SortedBinaryDocValues
that doesn't contain any value. - emptySortedNumericDoubles() - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Return a
SortedNumericDoubleValues
that doesn't contain any value. - EmptyStoreRecoverySource() - Constructor for class org.elasticsearch.cluster.routing.RecoverySource.EmptyStoreRecoverySource
- emptySuggestion(String, CompletionSuggestionContext, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggester
- emptySuggestion(String, PhraseSuggestionContext, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggester
- emptySuggestion(String, TermSuggestionContext, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.term.TermSuggester
- emptySuggestion(String, T, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.Suggester
- EmptyTaskSettings - Record Class in org.elasticsearch.inference
-
This class defines an empty task settings object.
- EmptyTaskSettings() - Constructor for record class org.elasticsearch.inference.EmptyTaskSettings
-
Creates an instance of a
EmptyTaskSettings
record class. - EmptyTaskSettings(StreamInput) - Constructor for record class org.elasticsearch.inference.EmptyTaskSettings
- EmptyTDigestState - Class in org.elasticsearch.search.aggregations.metrics
- EmptyTDigestState() - Constructor for class org.elasticsearch.search.aggregations.metrics.EmptyTDigestState
- ENABLE_CLUSTER_ALLOCATION_ACTION_GUIDE - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ENABLE_FOR_SINGLE_DATA_NODE - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
- ENABLE_IGNORE_ABOVE_LOGSDB - Static variable in class org.elasticsearch.index.IndexVersions
- ENABLE_IGNORE_MALFORMED_LOGSDB - Static variable in class org.elasticsearch.index.IndexVersions
- ENABLE_INDEX_ALLOCATION_GUIDE - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- ENABLE_LUCENE_SEGMENT_INFOS_TRACE_SETTING - Static variable in class org.elasticsearch.env.NodeEnvironment
-
If true the [verbose] SegmentInfos.infoStream logging is sent to System.out.
- ENABLE_REWRITE_AGGS_TO_FILTER_BY_FILTER - Static variable in class org.elasticsearch.search.SearchService
- ENABLE_STACK_OVERFLOW_AVOIDANCE - Static variable in class org.elasticsearch.transport.TransportService
-
Undocumented on purpose, may be removed at any time.
- ENABLE_TIER_ACTION_GUIDE - Static variable in class org.elasticsearch.cluster.routing.allocation.shards.ShardsAvailabilityHealthIndicatorService
- EnableAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This allocation decider allows shard allocations / rebalancing via the cluster wide settings
EnableAllocationDecider.CLUSTER_ROUTING_ALLOCATION_ENABLE_SETTING
/EnableAllocationDecider.CLUSTER_ROUTING_REBALANCE_ENABLE_SETTING
and the per index settingEnableAllocationDecider.INDEX_ROUTING_ALLOCATION_ENABLE_SETTING
/EnableAllocationDecider.INDEX_ROUTING_REBALANCE_ENABLE_SETTING
. - EnableAllocationDecider(ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
- EnableAllocationDecider.Allocation - Enum Class in org.elasticsearch.cluster.routing.allocation.decider
-
Allocation values or rather their string representation to be used used with
EnableAllocationDecider.CLUSTER_ROUTING_ALLOCATION_ENABLE_SETTING
/EnableAllocationDecider.INDEX_ROUTING_ALLOCATION_ENABLE_SETTING
via cluster / index settings. - EnableAllocationDecider.Rebalance - Enum Class in org.elasticsearch.cluster.routing.allocation.decider
-
Rebalance values or rather their string representation to be used used with
EnableAllocationDecider.CLUSTER_ROUTING_REBALANCE_ENABLE_SETTING
/EnableAllocationDecider.INDEX_ROUTING_REBALANCE_ENABLE_SETTING
via cluster / index settings. - EnableAssignmentDecider - Class in org.elasticsearch.persistent.decider
-
EnableAssignmentDecider
is used to allow/disallow the persistent tasks to be assigned to cluster nodes. - EnableAssignmentDecider(Settings, ClusterSettings) - Constructor for class org.elasticsearch.persistent.decider.EnableAssignmentDecider
- EnableAssignmentDecider.Allocation - Enum Class in org.elasticsearch.persistent.decider
-
Allocation values or rather their string representation to be used used with
EnableAssignmentDecider.CLUSTER_TASKS_ALLOCATION_ENABLE_SETTING
via cluster settings. - enabled - Variable in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- enabled - Variable in class org.elasticsearch.index.mapper.ObjectMapper
- enabled() - Method in record class org.elasticsearch.cluster.metadata.AutoExpandReplicas
-
Returns the value of the
enabled
record component. - enabled() - Method in record class org.elasticsearch.cluster.metadata.DataStreamFailureStore
-
Returns the value of the
enabled
record component. - enabled() - Method in record class org.elasticsearch.index.mapper.ObjectMapper.MergeResult
-
Returns the value of the
enabled
record component. - enabled() - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- enabled(boolean) - Method in class org.elasticsearch.cluster.metadata.DataStreamLifecycle.Builder
- enabled(boolean) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- enabled(Environment) - Static method in class org.elasticsearch.readiness.ReadinessService
-
Checks to see if the readiness service is enabled in the current environment
- Enabled() - Constructor for class org.elasticsearch.action.bulk.IncrementalBulkService.Enabled
- Enabled(ClusterSettings) - Constructor for class org.elasticsearch.action.bulk.IncrementalBulkService.Enabled
- ENABLED - Enum constant in enum class org.elasticsearch.index.mapper.ObjectMapper.Subobjects
- ENABLED - Static variable in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.Defaults
- ENABLED - Static variable in class org.elasticsearch.index.mapper.ObjectMapper.Defaults
- ENABLED - Static variable in class org.elasticsearch.watcher.ResourceWatcherService
- ENABLED_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- ENABLED_FIELD - Static variable in record class org.elasticsearch.cluster.metadata.DataStreamFailureStore
- ENABLED_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStreamLifecycle
- ENABLED_INSTANCE - Static variable in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper
- ENABLED_SETTING - Static variable in class org.elasticsearch.health.HealthPeriodicLogger
- ENABLED_SETTING - Static variable in class org.elasticsearch.health.node.selection.HealthNodeTaskExecutor
- ENABLED_SETTING - Static variable in class org.elasticsearch.monitor.fs.FsHealthService
- ENABLED_SETTING - Static variable in class org.elasticsearch.monitor.jvm.JvmGcMonitorService
- enableFormatSortValues(DocValueFormat) - Static method in interface org.elasticsearch.search.DocValueFormat
- enablePositionIncrements - Variable in class org.elasticsearch.index.search.MatchQueryParser
- enablePositionIncrements() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- enablePositionIncrements(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Set to
true
to enable position increments in result query. - enableRecoverySource - Variable in class org.elasticsearch.index.engine.Engine
- enableRewriteToFilterByFilter() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Are aggregations allowed to try to rewrite themselves into
FilterByFilterAggregator
aggregations? Often FilterByFilterAggregator is faster to execute, but it isn't always. - enableRewriteToFilterByFilter() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- encode(byte[]) - Static method in class org.elasticsearch.common.network.CIDRUtils
- encode(int) - Static method in class org.elasticsearch.index.mapper.TimeSeriesRoutingHashFieldMapper
- encode(long[], int, DataOutput) - Static method in class org.elasticsearch.index.codec.ForUtil
-
Encode 128 integers from
longs
intoout
. - encode(long[], int, DataOutput) - Method in class org.elasticsearch.index.codec.tsdb.DocValuesForUtil
- encode(List<SearchPhaseResult>, Map<String, AliasFilter>, TransportVersion, ShardSearchFailure[]) - Static method in class org.elasticsearch.action.search.SearchContextId
- encode(LogEvent, ByteBufferDestination) - Method in class org.elasticsearch.common.logging.ESJsonLayout
-
Deprecated.
- encodeAfterQueryParam(SnapshotInfo) - Method in enum class org.elasticsearch.action.admin.cluster.snapshots.get.SnapshotSortKey
- encodeChunk(int, Recycler<BytesRef>) - Method in interface org.elasticsearch.rest.ChunkedRestResponseBodyPart
-
Serializes approximately as many bytes of the response as request by
sizeHint
to aReleasableBytesReference
that is created from buffers backed by the givenrecycler
. - encodeChunk(int, Recycler<BytesRef>) - Method in class org.elasticsearch.rest.LoggingChunkedRestResponseBodyPart
- ENCODED_LATITUDE_MASK - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
- ENCODED_NEGATIVE_LATITUDE_MASK - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
- encodeFromMap(IgnoredSourceFieldMapper.MappedNameValue, Map<String, Object>) - Static method in class org.elasticsearch.index.mapper.IgnoredSourceFieldMapper
-
Clones the passed NameValue, using the passed map to produce its value.
- encodeId(String) - Static method in class org.elasticsearch.index.mapper.Uid
-
Encode an id for storage in the index.
- encoder - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- encoder() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- encoder() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- encoder(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set the encoder, defaults to
HighlightBuilder.DEFAULT_ENCODER
- ENCODER_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- encodeRanges(Set<RangeFieldMapper.Range>) - Method in enum class org.elasticsearch.index.mapper.RangeType
- Encoders() - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightUtils.Encoders
- encodeShardAndDoc(int, int) - Static method in class org.elasticsearch.search.sort.ShardDocSortField
- encodeTsid(BytesRef) - Static method in class org.elasticsearch.index.mapper.TimeSeriesIdFieldMapper
- encodeTsid(StreamInput) - Static method in class org.elasticsearch.index.mapper.TimeSeriesIdFieldMapper
-
Decode the
_tsid
into a human readable map. - encodeX(double) - Method in class org.elasticsearch.lucene.spatial.CoordinateEncoder
-
encode X value
- encodeXContentBuilder(XContentBuilder) - Static method in class org.elasticsearch.index.mapper.XContentDataHelper
-
Build a
BytesRef
wrapping a byte array containing an encoded form of the passed XContentBuilder contents. - encodeY(double) - Method in class org.elasticsearch.lucene.spatial.CoordinateEncoder
-
encode Y value
- end - Variable in class org.elasticsearch.script.ScriptException.Position
- end() - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- end() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- endArray() - Static method in enum class org.elasticsearch.common.xcontent.ChunkedToXContentHelper
- endHeaders() - Method in class org.elasticsearch.common.Table
- endObject() - Static method in enum class org.elasticsearch.common.xcontent.ChunkedToXContentHelper
- endOffset() - Method in class org.elasticsearch.lucene.search.uhighlight.LimitedOffsetsEnum
- endPositionEntry() - Method in interface org.elasticsearch.index.mapper.BlockLoader.Builder
-
End a multivalued field.
- endRow() - Method in class org.elasticsearch.common.Table
- endRow(boolean) - Method in class org.elasticsearch.common.Table
- endTime() - Method in class org.elasticsearch.index.TimestampBounds
-
The first invalid
@timestamp
for the index. - endTime() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns time when snapshot ended; a value of
0L
will be returned if the snapshot is still running or ifSnapshotInfo.state()
returnsnull
. - endVerification(String) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- endVerification(String) - Method in class org.elasticsearch.repositories.FilterRepository
- endVerification(String) - Method in class org.elasticsearch.repositories.InvalidRepository
- endVerification(String) - Method in interface org.elasticsearch.repositories.Repository
-
Called at the end of repository verification process.
- endVerification(String) - Method in class org.elasticsearch.repositories.UnknownTypeRepository
- ENFORCE_DEFAULT_TIER_PREFERENCE - Static variable in class org.elasticsearch.cluster.routing.allocation.DataTier
- ENFORCE_DEFAULT_TIER_PREFERENCE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.DataTier
- Engine - Class in org.elasticsearch.index.engine
- Engine(EngineConfig) - Constructor for class org.elasticsearch.index.engine.Engine
- Engine.Delete - Class in org.elasticsearch.index.engine
- Engine.DeleteResult - Class in org.elasticsearch.index.engine
- Engine.EventListener - Interface in org.elasticsearch.index.engine
- Engine.FlushResult - Record Class in org.elasticsearch.index.engine
- Engine.Get - Class in org.elasticsearch.index.engine
- Engine.GetResult - Class in org.elasticsearch.index.engine
- Engine.Index - Class in org.elasticsearch.index.engine
- Engine.IndexCommitListener - Interface in org.elasticsearch.index.engine
- Engine.IndexCommitRef - Class in org.elasticsearch.index.engine
- Engine.IndexResult - Class in org.elasticsearch.index.engine
- Engine.IndexThrottle - Class in org.elasticsearch.index.engine
-
A throttling class that can be activated, causing the
acquireThrottle
method to block on a lock when throttling is enabled - Engine.NoOp - Class in org.elasticsearch.index.engine
- Engine.NoOpLock - Class in org.elasticsearch.index.engine
-
A Lock implementation that always allows the lock to be acquired
BulkRequestBuilder.add(DeleteRequestBuilder)
instead