Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- 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.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) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- abortOnFailure() - Method in class org.elasticsearch.repositories.GetSnapshotInfoContext
- abortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Set whether or not version conflicts cause the action to abort.
- abortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequestBuilder
- abortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequestBuilder
- abortRelocationHandoff() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Fails a relocation handoff attempt.
- absoluteTimeInMillis() - Method in class org.elasticsearch.threadpool.ThreadPool
-
Returns the value of milliseconds since UNIX epoch.
- AbstractAggregationBuilder<AB extends AbstractAggregationBuilder<AB>> - Class in org.elasticsearch.search.aggregations
-
Base implementation of a
AggregationBuilder
. - AbstractAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Constructs a new aggregation builder.
- AbstractAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Read from a stream.
- AbstractAggregationBuilder(AbstractAggregationBuilder<AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- AbstractAllocateAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Abstract base class for allocating an unassigned shard to a node
- AbstractAllocateAllocationCommand(String, int, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- AbstractAllocateAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Read from a stream.
- AbstractAllocateAllocationCommand.Builder<T extends AbstractAllocateAllocationCommand> - Class in org.elasticsearch.cluster.routing.allocation.command
-
Works around ObjectParser not supporting constructor arguments.
- AbstractAllocationDecision - Class in org.elasticsearch.cluster.routing.allocation
-
An abstract class for representing various types of allocation decisions.
- AbstractAllocationDecision(DiscoveryNode, List<NodeAllocationResult>) - Constructor for class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- AbstractAllocationDecision(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- AbstractAsyncTask - Class in org.elasticsearch.common.util.concurrent
-
A base class for tasks that need to repeat.
- AbstractAsyncTask(Logger, ThreadPool, TimeValue, boolean) - Constructor for class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- AbstractBinaryDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractBinaryDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractBinaryDocValues
- AbstractBindingBuilder<T> - Class in org.elasticsearch.common.inject.internal
-
Bind a value or constant.
- AbstractBindingBuilder(Binder, List<Element>, Object, Key<T>) - Constructor for class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- AbstractBlobContainer - Class in org.elasticsearch.common.blobstore.support
-
A base abstract blob container that implements higher level container methods.
- AbstractBlobContainer(BlobPath) - Constructor for class org.elasticsearch.common.blobstore.support.AbstractBlobContainer
- AbstractBulkByScrollRequest<Self extends AbstractBulkByScrollRequest<Self>> - Class in org.elasticsearch.index.reindex
- AbstractBulkByScrollRequest(SearchRequest, boolean) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Constructor for actual use.
- AbstractBulkByScrollRequest(StreamInput) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- AbstractBulkByScrollRequestBuilder<Request extends AbstractBulkByScrollRequest<Request>,
Self extends AbstractBulkByScrollRequestBuilder<Request, Self>> - Class in org.elasticsearch.index.reindex - AbstractBulkByScrollRequestBuilder(ElasticsearchClient, ActionType<BulkByScrollResponse>, SearchRequestBuilder, Request) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
- AbstractBulkIndexByScrollRequest<Self extends AbstractBulkIndexByScrollRequest<Self>> - Class in org.elasticsearch.index.reindex
- AbstractBulkIndexByScrollRequest(SearchRequest, boolean) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
-
Constructor for actual use.
- AbstractBulkIndexByScrollRequest(StreamInput) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
- AbstractBulkIndexByScrollRequestBuilder<Request extends AbstractBulkIndexByScrollRequest<Request>,
Self extends AbstractBulkIndexByScrollRequestBuilder<Request, Self>> - Class in org.elasticsearch.index.reindex - AbstractBulkIndexByScrollRequestBuilder(ElasticsearchClient, ActionType<BulkByScrollResponse>, SearchRequestBuilder, Request) - Constructor for class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequestBuilder
- AbstractBytesReference - Class in org.elasticsearch.common.bytes
- AbstractBytesReference() - 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(IndexSettings, String) - Constructor for class org.elasticsearch.index.analysis.AbstractCharFilterFactory
- AbstractClient - Class in org.elasticsearch.client.support
- AbstractClient(Settings, ThreadPool) - Constructor for class org.elasticsearch.client.support.AbstractClient
- AbstractDiffable<T extends Diffable<T>> - Class in org.elasticsearch.cluster
-
Abstract diffable object with simple diffs implementation that sends the entire object if object has changed or nothing if object remained the same.
- AbstractDiffable() - Constructor for class org.elasticsearch.cluster.AbstractDiffable
- AbstractDistanceScoreFunction(double, double, double, DecayFunction, MultiValueMode) - Constructor for class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- AbstractFieldScript - Class in org.elasticsearch.script
-
Abstract base for scripts to execute to build scripted fields.
- AbstractFieldScript(String, Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.AbstractFieldScript
- AbstractGeometryFieldMapper<T> - Class in org.elasticsearch.index.mapper
-
Base field mapper class for all spatial field types
- AbstractGeometryFieldMapper(String, MappedFieldType, Map<String, NamedAnalyzer>, Explicit<Boolean>, Explicit<Boolean>, FieldMapper.MultiFields, FieldMapper.CopyTo, AbstractGeometryFieldMapper.Parser<T>) - Constructor for class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- AbstractGeometryFieldMapper(String, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, FieldMapper.MultiFields, FieldMapper.CopyTo, AbstractGeometryFieldMapper.Parser<T>) - Constructor for class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- AbstractGeometryFieldMapper(String, MappedFieldType, FieldMapper.MultiFields, FieldMapper.CopyTo, AbstractGeometryFieldMapper.Parser<T>, String) - Constructor for class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- AbstractGeometryFieldMapper.AbstractGeometryFieldType<T> - 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>, 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, String, String) - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Deprecated.
- AbstractGeometryQueryBuilder(String, Supplier<Geometry>, String, 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, 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
- AbstractHttpServerTransport - Class in org.elasticsearch.http
- AbstractHttpServerTransport(Settings, NetworkService, BigArrays, ThreadPool, NamedXContentRegistry, HttpServerTransport.Dispatcher, ClusterSettings) - 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
- AbstractIndexAnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer> - Class in org.elasticsearch.index.analysis
- AbstractIndexAnalyzerProvider(IndexSettings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.AbstractIndexAnalyzerProvider
-
Constructs a new analyzer component, with the index name and its settings and the analyzer name.
- AbstractIndexComponent - Class in org.elasticsearch.index
- AbstractIndexComponent(IndexSettings) - Constructor for class org.elasticsearch.index.AbstractIndexComponent
-
Constructs a new index component, with the index name and its settings.
- AbstractIndexOrdinalsFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractIndexOrdinalsFieldData(String, ValuesSourceType, IndexFieldDataCache, CircuitBreakerService, Function<SortedSetDocValues, ScriptDocValues<?>>) - 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> - 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 - Class in org.elasticsearch.search.aggregations.bucket.terms
- AbstractLatLonPointIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractLatLonPointIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
- AbstractLatLonPointIndexFieldData.LatLonPointIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractLeafGeoPointFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractLeafGeoPointFieldData() - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractLeafGeoPointFieldData
- AbstractLeafOrdinalsFieldData - Class in org.elasticsearch.index.fielddata.plain
- AbstractLeafOrdinalsFieldData(Function<SortedSetDocValues, ScriptDocValues<?>>) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractLeafOrdinalsFieldData
- AbstractLifecycleComponent - Class in org.elasticsearch.common.component
- AbstractLifecycleComponent() - Constructor for class org.elasticsearch.common.component.AbstractLifecycleComponent
- AbstractLifecycleRunnable - Class in org.elasticsearch.common.util.concurrent
-
AbstractLifecycleRunnable
is a service-lifecycle awareAbstractRunnable
. - AbstractLifecycleRunnable(Lifecycle, Logger) - Constructor for class org.elasticsearch.common.util.concurrent.AbstractLifecycleRunnable
-
AbstractLifecycleRunnable
must be aware of the actuallifecycle
to react properly. - 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
- AbstractLongFieldScript - Class in org.elasticsearch.script
-
Common base class for script field scripts that return long values.
- AbstractLongFieldScript(String, Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.AbstractLongFieldScript
- AbstractMatcher<T> - Class in org.elasticsearch.common.inject.matcher
-
Implements
and()
andor()
. - AbstractMatcher() - Constructor for class org.elasticsearch.common.inject.matcher.AbstractMatcher
- AbstractModelParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.MovAvgModel.AbstractModelParser
- AbstractModule - Class in org.elasticsearch.common.inject
-
A support class for
Module
s which reduces repetition and results in a more readable configuration. - AbstractModule() - Constructor for class org.elasticsearch.common.inject.AbstractModule
- AbstractNamedDiffable<T extends NamedDiffable<T>> - Class in org.elasticsearch.cluster
-
Abstract diffable object with simple diffs implementation that sends the entire object if object has changed or nothing is object remained the same.
- AbstractNamedDiffable() - Constructor for class org.elasticsearch.cluster.AbstractNamedDiffable
- AbstractNumericDocValues - Class in org.elasticsearch.index.fielddata
-
Base implementation that throws an
IOException
for theDocIdSetIterator
APIs. - AbstractNumericDocValues() - Constructor for class org.elasticsearch.index.fielddata.AbstractNumericDocValues
- 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.
- AbstractPointGeometryFieldMapper<T> - Class in org.elasticsearch.index.mapper
-
Base class for for spatial fields that only support indexing points
- AbstractPointGeometryFieldMapper(String, MappedFieldType, FieldMapper.MultiFields, Explicit<Boolean>, Explicit<Boolean>, T, FieldMapper.CopyTo, AbstractGeometryFieldMapper.Parser<T>) - Constructor for class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper
- AbstractPointGeometryFieldMapper(String, MappedFieldType, FieldMapper.MultiFields, FieldMapper.CopyTo, AbstractGeometryFieldMapper.Parser<T>, String) - Constructor for class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper
- AbstractPointGeometryFieldMapper.PointParser<T> - Class in org.elasticsearch.index.mapper
-
A base parser implementation for point formats
- 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, ValuesSourceRegistry.RegistryKey<RangeAggregatorSupplier>, 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.
- AbstractRoutingChangesObserver() - Constructor for class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- AbstractRunnable - Class in org.elasticsearch.common.util.concurrent
-
An extension to runnable.
- AbstractRunnable() - Constructor for class org.elasticsearch.common.util.concurrent.AbstractRunnable
- AbstractScopedSettings - Class in org.elasticsearch.common.settings
-
A basic setting service that can be used for per-index and per-cluster settings.
- AbstractScopedSettings(Settings, Set<Setting<?>>, Set<SettingUpgrader<?>>, Setting.Property) - Constructor for class org.elasticsearch.common.settings.AbstractScopedSettings
- AbstractScopedSettings(Settings, Settings, AbstractScopedSettings, Logger) - Constructor for class org.elasticsearch.common.settings.AbstractScopedSettings
- AbstractScopedSettings.SettingUpdater<T> - Interface in org.elasticsearch.common.settings
-
Transactional interface to update settings.
- AbstractScriptFieldQuery<S extends AbstractFieldScript> - Class in org.elasticsearch.search.runtime
-
Abstract base class for building queries based on script fields.
- AbstractShapeGeometryFieldMapper<T> - Class in org.elasticsearch.index.mapper
-
Base class for
GeoShapeFieldMapper
- AbstractShapeGeometryFieldMapper(String, MappedFieldType, Map<String, NamedAnalyzer>, Explicit<Boolean>, Explicit<Boolean>, Explicit<Boolean>, Explicit<Orientation>, FieldMapper.MultiFields, FieldMapper.CopyTo, AbstractGeometryFieldMapper.Parser<T>) - Constructor for class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper
- AbstractShapeGeometryFieldMapper(String, MappedFieldType, Explicit<Boolean>, Explicit<Boolean>, Explicit<Boolean>, Explicit<Orientation>, FieldMapper.MultiFields, FieldMapper.CopyTo, 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
- AbstractTermsBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms.AbstractTermsBucket
- AbstractTokenFilterFactory - Class in org.elasticsearch.index.analysis
- AbstractTokenFilterFactory(IndexSettings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.AbstractTokenFilterFactory
- AbstractTokenizerFactory - Class in org.elasticsearch.index.analysis
- AbstractTokenizerFactory(IndexSettings, Settings, String) - Constructor for class org.elasticsearch.index.analysis.AbstractTokenizerFactory
- accept() - Method in class org.apache.lucene.analysis.miscellaneous.DeDuplicatingTokenFilter
- accept(int) - Method in class org.elasticsearch.search.aggregations.MultiBucketConsumerService.MultiBucketConsumer
- accept(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.LongFilter
- accept(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.PartitionedLongFilter
- accept(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.SetBackedLongFilter
- accept(long, Exception) - Method in interface org.elasticsearch.index.shard.GlobalCheckpointListeners.GlobalCheckpointListener
-
Callback when the global checkpoint is updated or the shard is closed.
- accept(BytesRef) - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
-
Always accept the term.
- accept(BytesRef) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.StringFilter
- accept(ReplicationGroup) - Method in class org.elasticsearch.action.support.replication.PendingReplicationActions
- 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
- 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
- acceptIncomingRequests() - Method in class org.elasticsearch.transport.TransportService
-
Start accepting incoming requests.
- acceptScopingVisitor(BindingScopingVisitor<V>) - Method in interface org.elasticsearch.common.inject.Binding
-
Accepts a scoping visitor.
- acceptScopingVisitor(BindingScopingVisitor<V>) - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- 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.common.inject.Binding
-
Accepts a target visitor.
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- acceptVisitor(BindingScopingVisitor<V>) - Method in class org.elasticsearch.common.inject.internal.Scoping
- acceptVisitor(ElementVisitor<R>) - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- acceptVisitor(ElementVisitor<T>) - Method in interface org.elasticsearch.common.inject.spi.Element
-
Accepts an element visitor.
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.Message
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.ScopeBinding
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.StaticInjectionRequest
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.TypeConverterBinding
- acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.common.inject.spi.TypeListenerBinding
- acceptVisitor(ElementVisitor<V>) - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- ACCESS_CONTROL_ALLOW_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
- ACCOUNTING - Static variable in interface org.elasticsearch.common.breaker.CircuitBreaker
-
The accounting breaker tracks things held in memory that is independent of the request lifecycle.
- ACCOUNTING_CIRCUIT_BREAKER_LIMIT_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- ACCOUNTING_CIRCUIT_BREAKER_OVERHEAD_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- ACCOUNTING_CIRCUIT_BREAKER_TYPE_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- accuracy() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- accuracy() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the accuracy setting.
- accuracy(float) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- accuracy(float) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets how similar the suggested terms at least need to be compared to the original suggest text tokens.
- accuracy(float) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
s how similar the suggested terms at least need to be compared to the original suggest text tokens.
- ACCURACY_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- AckClusterStatePublishResponseHandler - Class in org.elasticsearch.discovery
-
Allows to wait for all nodes to reply to the publish of a new cluster state and notifies the
ClusterStatePublisher.AckListener
so that the cluster state update can be acknowledged - AckClusterStatePublishResponseHandler(Set<DiscoveryNode>, ClusterStatePublisher.AckListener) - Constructor for class org.elasticsearch.discovery.AckClusterStatePublishResponseHandler
-
Creates a new AckClusterStatePublishResponseHandler
- AckedClusterStateTaskListener - Interface in org.elasticsearch.cluster
- AckedClusterStateUpdateTask - Class in org.elasticsearch.cluster
-
An extension interface to
ClusterStateUpdateTask
that allows to be notified when all the nodes have acknowledged a cluster state update request - AckedClusterStateUpdateTask(AckedRequest, ActionListener<? extends AcknowledgedResponse>) - Constructor for class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- AckedClusterStateUpdateTask(Priority, AckedRequest, ActionListener<? extends AcknowledgedResponse>) - Constructor for class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- AckedRequest - Interface in org.elasticsearch.cluster.ack
-
Identifies a cluster state update request with acknowledgement support
- acknowledged - Variable in class org.elasticsearch.action.support.master.AcknowledgedResponse
- acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutResponse
- AcknowledgedRequest<Request extends MasterNodeRequest<Request>> - Class in org.elasticsearch.action.support.master
-
Abstract class that allows to mark action requests that support acknowledgements.
- AcknowledgedRequest() - Constructor for class org.elasticsearch.action.support.master.AcknowledgedRequest
- AcknowledgedRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedRequest
- AcknowledgedRequest(TimeValue) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedRequest
- AcknowledgedRequestBuilder<Request extends AcknowledgedRequest<Request>,
Response extends AcknowledgedResponse, RequestBuilder extends AcknowledgedRequestBuilder<Request, Response, RequestBuilder>> - Class in org.elasticsearch.action.support.master -
Base request builder for master node operations that support acknowledgements
- AcknowledgedRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedRequestBuilder
- AcknowledgedResponse - Class in org.elasticsearch.action.support.master
-
A response that indicates that a request has been acknowledged
- AcknowledgedResponse(boolean) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
- AcknowledgedResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
- AcknowledgedResponse(StreamInput, boolean) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedResponse
- 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, String) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedTransportMasterNodeAction
- AcknowledgedTransportMasterNodeAction(String, TransportService, ClusterService, ThreadPool, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver, String) - Constructor for class org.elasticsearch.action.support.master.AcknowledgedTransportMasterNodeAction
- ackTimeout() - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
- ackTimeout() - Method in interface org.elasticsearch.cluster.ack.AckedRequest
-
Returns the acknowledgement timeout
- ackTimeout() - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
-
Returns the maximum time interval to wait for acknowledgements
- ackTimeout() - Method in interface org.elasticsearch.cluster.AckedClusterStateTaskListener
-
Acknowledgement timeout, maximum time interval to wait for acknowledgements
- ackTimeout() - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
-
Acknowledgement timeout, maximum time interval to wait for acknowledgements
- ackTimeout(TimeValue) - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
-
Sets the acknowledgement timeout
- acquire() - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
- acquire(T) - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
-
Acquires a lock for the given key.
- acquireAllPrimaryOperationsPermits(ActionListener<Releasable>, TimeValue) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire all primary operation permits.
- acquireAllReplicaOperationsPermits(long, long, long, ActionListener<Releasable>, TimeValue) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire all replica operation permits whenever the shard is ready for indexing (see
IndexShard.acquireAllPrimaryOperationsPermits(ActionListener, TimeValue)
. - acquireFSLockForPaths(IndexSettings, Path...) - Static method in class org.elasticsearch.env.NodeEnvironment
-
Acquires, then releases, all
write.lock
files in the given shard paths. - acquireHistoryRetentionLock(Engine.HistorySource) - Method in class org.elasticsearch.index.engine.Engine
-
Acquires a lock on the translog files and Lucene soft-deleted documents to prevent them from being trimmed
- acquireHistoryRetentionLock(Engine.HistorySource) - Method in class org.elasticsearch.index.engine.InternalEngine
- acquireHistoryRetentionLock(Engine.HistorySource) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- acquireHistoryRetentionLock(Engine.HistorySource) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquires a lock on the translog files and Lucene soft-deleted documents to prevent them from being trimmed
- 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. - acquirePrimaryOperationPermit(ActionListener<Releasable>, String, Object) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire a primary operation permit whenever the shard is ready for indexing.
- acquirePrimaryOperationPermit(ActionListener<Releasable>, String, Object, 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>, String, Object) - Method in class org.elasticsearch.index.shard.IndexShard
-
Acquire a replica operation permit whenever the shard is ready for indexing (see
IndexShard.acquirePrimaryOperationPermit(ActionListener, String, Object)
). - acquireReplicaOperationPermit(IndexShard, TransportVerifyShardBeforeCloseAction.ShardRequest, ActionListener<Releasable>, long, long, long) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- acquireReplicaOperationPermit(IndexShard, 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() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
- action() - Method in exception org.elasticsearch.transport.ActionNotFoundTransportException
- action() - Method in exception org.elasticsearch.transport.ActionTransportException
-
The action to invoke.
- action() - Method in class org.elasticsearch.transport.Transport.ResponseContext
- ACTION_NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- ACTION_NAME - Static variable in class org.elasticsearch.action.bulk.TransportShardBulkAction
- ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.UnicastZenPing
- ACTION_NAME - Static variable in class org.elasticsearch.gateway.LocalAllocateDangledIndices
- ACTION_NAME - Static variable in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- ACTION_NAME - Static variable in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Add
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Renew
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- ACTION_NAME - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- ACTION_NAME - Static variable in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata
- ACTION_NAME - Static variable in class org.elasticsearch.repositories.VerifyNodeRepositoryAction
- ACTION_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_SHARD_EXISTS - Static variable in class org.elasticsearch.indices.store.IndicesStore
- ACTION_SHARD_NAME - Static variable in class org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesAction
- ActionFilter - Interface in org.elasticsearch.action.support
-
A filter allowing to filter transport actions
- ActionFilter.Simple - Class in org.elasticsearch.action.support
-
A simple base class for injectable action filters that spares the implementation from handling the filter chain.
- ActionFilterChain<Request extends ActionRequest,
Response extends ActionResponse> - Interface in org.elasticsearch.action.support -
A filter chain allowing to continue and process the transport action request
- ActionFilters - Class in org.elasticsearch.action.support
-
Holds the action filters injected through plugins, properly sorted by
ActionFilter.order()
- ActionFilters(Set<ActionFilter>) - Constructor for class org.elasticsearch.action.support.ActionFilters
- ActionFuture<T> - Interface in org.elasticsearch.action
-
An extension to
Future
allowing for simplified "get" operations. - actionGet() - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get()
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet() - Method in class org.elasticsearch.action.support.AdapterActionFuture
- actionGet(long) - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get(long, java.util.concurrent.TimeUnit)
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet(long) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- actionGet(long, TimeUnit) - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get(long, java.util.concurrent.TimeUnit)
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet(long, TimeUnit) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- actionGet(String) - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get(long, java.util.concurrent.TimeUnit)
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet(String) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- actionGet(TimeValue) - Method in interface org.elasticsearch.action.ActionFuture
-
Similar to
Future.get(long, java.util.concurrent.TimeUnit)
, just catching theInterruptedException
and throwing anIllegalStateException
instead. - actionGet(TimeValue) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- ActionHandler(ActionType<Response>, Class<? extends TransportAction<Request, Response>>, Class<?>...) - Constructor for class org.elasticsearch.plugins.ActionPlugin.ActionHandler
-
Create a record of an action, the TransportAction that handles it, and any supporting TransportActions that are needed by that TransportAction.
- ActionListener<Response> - Interface in org.elasticsearch.action
-
A listener for action responses or failures.
- ActionListener.Delegating<Response,
DelegateResponse> - Class in org.elasticsearch.action - ActionListener.DelegatingActionListener<T> - Class in org.elasticsearch.action
- ActionListener.DelegatingFailureActionListener<T,
R> - Class in org.elasticsearch.action - ActionListener.MappedActionListener<Response,
MappedResponse> - Class in org.elasticsearch.action - ActionListener.RunAfterActionListener<T> - Class in org.elasticsearch.action
- ActionListener.RunBeforeActionListener<T> - Class in org.elasticsearch.action
- ActionListenerResponseHandler<Response extends TransportResponse> - Class in org.elasticsearch.action
-
A simple base class for action response listeners, defaulting to using the SAME executor (as its very common on response handlers).
- ActionListenerResponseHandler(ActionListener<? super Response>, Writeable.Reader<Response>) - Constructor for class org.elasticsearch.action.ActionListenerResponseHandler
- ActionListenerResponseHandler(ActionListener<? super Response>, Writeable.Reader<Response>, String) - Constructor for class org.elasticsearch.action.ActionListenerResponseHandler
- ActionModule - Class in org.elasticsearch.action
-
Builds and binds the generic action map, all
TransportAction
s, andActionFilters
. - ActionModule(boolean, Settings, IndexNameExpressionResolver, IndexScopedSettings, ClusterSettings, SettingsFilter, ThreadPool, List<ActionPlugin>, NodeClient, CircuitBreakerService, UsageService, SystemIndices) - Constructor for class org.elasticsearch.action.ActionModule
- actionName - Variable in class org.elasticsearch.action.support.TransportAction
- ActionNotFoundTransportException - Exception in org.elasticsearch.transport
-
An exception indicating that a transport action was not found.
- ActionNotFoundTransportException(String) - Constructor for exception org.elasticsearch.transport.ActionNotFoundTransportException
- ActionNotFoundTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.ActionNotFoundTransportException
- ActionPlugin - Interface in org.elasticsearch.plugins
-
An additional extension point for
Plugin
s that extends Elasticsearch's scripting functionality. - ActionPlugin.ActionHandler<Request extends ActionRequest,
Response extends ActionResponse> - Class in org.elasticsearch.plugins - ActionRequest - Class in org.elasticsearch.action
- ActionRequest() - Constructor for class org.elasticsearch.action.ActionRequest
- ActionRequest(StreamInput) - Constructor for class org.elasticsearch.action.ActionRequest
- ActionRequestBuilder<Request extends ActionRequest,
Response extends ActionResponse> - Class in org.elasticsearch.action - ActionRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.ActionRequestBuilder
- ActionRequestValidationException - Exception in org.elasticsearch.action
- ActionRequestValidationException() - Constructor for exception org.elasticsearch.action.ActionRequestValidationException
- ActionResponse - Class in org.elasticsearch.action
-
Base class for responses to action requests.
- ActionResponse() - Constructor for class org.elasticsearch.action.ActionResponse
- ActionResponse(StreamInput) - Constructor for class org.elasticsearch.action.ActionResponse
- ActionResponse.Empty - Class in org.elasticsearch.action
- ActionRunnable<Response> - Class in org.elasticsearch.action
-
Base class for
Runnable
s that need to callActionListener.onFailure(Exception)
in case an uncaught exception or error is thrown while the actual action is run. - ActionRunnable(ActionListener<Response>) - Constructor for class org.elasticsearch.action.ActionRunnable
- actions() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesClusterStateUpdateRequest
-
Returns the alias actions to be performed
- Actions() - Constructor for class org.elasticsearch.indices.recovery.PeerRecoverySourceService.Actions
- Actions() - Constructor for class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- ActionTransportException - Exception in org.elasticsearch.transport
-
An action invocation failure.
- ActionTransportException(String, TransportAddress, String, String, Throwable) - Constructor for exception org.elasticsearch.transport.ActionTransportException
- ActionTransportException(String, TransportAddress, String, Throwable) - Constructor for exception org.elasticsearch.transport.ActionTransportException
- ActionTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.ActionTransportException
- actionType() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Type of the action to perform.
- ActionType<Response extends ActionResponse> - Class in org.elasticsearch.action
-
A generic action.
- ActionType(String, Writeable.Reader<Response>) - Constructor for class org.elasticsearch.action.ActionType
- activate() - Method in class org.elasticsearch.index.engine.Engine.IndexThrottle
-
Activate throttling, which switches the lock to be a real lock
- activate(Optional<DiscoveryNode>, ClusterState) - Method in class org.elasticsearch.cluster.coordination.DiscoveryUpgradeService
- activate(DiscoveryNodes) - Method in class org.elasticsearch.discovery.PeerFinder
- activatePrimaryMode(long) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Initializes the global checkpoint tracker in primary mode (see
ReplicationTracker.primaryMode
. - activateThrottling() - Method in class org.elasticsearch.index.engine.Engine
-
Request that this engine throttle incoming indexing requests to one thread.
- activateThrottling() - Method in class org.elasticsearch.index.engine.InternalEngine
- activateThrottling() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- activateThrottling() - Method in class org.elasticsearch.index.shard.IndexShard
- activateThrottling(IndexShard) - Method in class org.elasticsearch.indices.IndexingMemoryController
-
Asks this shard to throttle indexing to one thread
- activateWithPrimaryContext(ReplicationTracker.PrimaryContext) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Activates the global checkpoint tracker in primary mode (see
ReplicationTracker.primaryMode
. - activateWithPrimaryContext(ReplicationTracker.PrimaryContext) - Method in class org.elasticsearch.index.shard.IndexShard
-
Updates the known allocation IDs and the local checkpoints for the corresponding allocations from a primary relocation source.
- active() - Method in class org.elasticsearch.cluster.routing.ShardRouting
- activeInitializingShardsIt(int) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns an iterator over active and initializing shards.
- activeInitializingShardsRandomIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns an iterator over active and initializing shards.
- activeInitializingShardsRankedIt(ResponseCollectorService, Map<String, Long>) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns an iterator over active and initializing shards, ordered by the adaptive replica selection formula.
- activeOnly() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
-
True if activeOnly flag is set, false otherwise.
- activeOnly(boolean) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
-
Set value of the activeOnly flag.
- activePrimary(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns the active primary shard for the given shard id or
null
if no primary is found or the primary is not active. - activePrimaryShardsGrouped(String[], boolean) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
All the *active* primary shards for the provided indices grouped (each group is a single element, consisting of the primary shard).
- activeReplicaWithHighestVersion(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns one active replica shard for the given shard id or
null
if no active replica is found. - ActiveShardCount - Class in org.elasticsearch.action.support
-
A class whose instances represent a value for counting the number of active shard copies for a given shard in an index.
- activeShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of active shards - ActiveShardsObserver - Class in org.elasticsearch.action.support
-
This class provides primitives for waiting for a configured number of shards to become active before sending a response on an
ActionListener
. - ActiveShardsObserver(ClusterService, ThreadPool) - Constructor for class org.elasticsearch.action.support.ActiveShardsObserver
- activityTimeout() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- actualSizeToRead() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- 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.
- AdapterActionFuture<T,
L> - Class in org.elasticsearch.action.support - AdapterActionFuture() - Constructor for class org.elasticsearch.action.support.AdapterActionFuture
- AdapterBuilder(String, 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.NodesStatsRequest.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
- adaptUserMetadata(Map<String, Object>) - Method in interface org.elasticsearch.repositories.Repository
-
Hook that allows a repository to filter the user supplied snapshot metadata in
SnapshotsInProgress.Entry.userMetadata()
during snapshot initialization. - add() - Static method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Build a new
AliasAction
to add aliases. - add(byte[]) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.CustomBinaryDocValuesField
- add(byte[], int, int, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Deprecated.
- add(byte[], int, int, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Deprecated.
- add(byte[], int, int, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(byte[], int, int, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds a framed data in binary format
- add(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds a framed data in binary format
- add(double) - Method in class org.elasticsearch.search.aggregations.metrics.CompensatedSum
-
Increments the Kahan sum by adding a value without a correction term.
- 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(int, GetResponse) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
- add(int, MultiGetResponse.Failure) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
- add(int, MultiTermVectorsResponse.Failure) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardResponse
- add(int, TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- add(int, TermVectorsResponse) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardResponse
- add(int, T) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
- add(long) - Method in class org.elasticsearch.common.util.LongHash
-
Try to add
key
. - add(long) - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
-
Add's the provided value to the set for tracking
- add(long, long) - Method in class org.elasticsearch.common.blobstore.DeleteResult
- add(long, long) - Method in class org.elasticsearch.common.util.LongLongHash
-
Try to add
key
. - add(long, long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- 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.flush.FlushStats
- add(long, long, long) - Method in class org.elasticsearch.index.warmer.WarmerStats
- add(long, long, long, long, long, long, long, long, long, double) - Method in class org.elasticsearch.index.merge.MergeStats
- add(long, BytesRef) - Method in class org.elasticsearch.search.aggregations.bucket.terms.BytesKeyedBucketOrds
-
Add the
owningBucketOrd, value
pair. - add(Iterable<DocWriteRequest<?>>) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a list of requests to be executed.
- add(String) - Method in class org.elasticsearch.common.blobstore.BlobPath
- add(String) - Method in class org.elasticsearch.index.mapper.ContentPath
- add(String) - Method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo.Builder
- add(String, Object) - Method in class org.elasticsearch.common.inject.internal.ToStringBuilder
- add(String, String) - Method in class org.elasticsearch.action.get.MultiGetRequest
- add(String, String, Iterable<String>) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- add(String, String, Iterable<String>) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
- add(String, String, String) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
Deprecated.Types are in the process of being removed, use
MultiGetRequest.add(String, String)
instead. - add(String, String, String) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- add(String, String, String) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- add(String, String, String...) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- add(String, String, String...) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
- add(String, String, String[], FetchSourceContext, String, XContentParser, boolean) - Method in class org.elasticsearch.action.get.MultiGetRequest
- add(String, Query) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterByFilterAggregator.AdapterBuilder
- 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(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
-
Adds an
DeleteRequest
to the list of actions to execute. - add(DeleteRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
DeleteRequest
to the list of actions to execute. - add(DocWriteRequest<?>) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds either a delete or an index request.
- add(DocWriteRequest<?>) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Add a request to the current BulkRequest.
- add(DocWriteRequest<?>...) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a list of requests to be executed.
- add(MultiGetRequest.Item) - Method in class org.elasticsearch.action.get.MultiGetRequest
- add(MultiGetRequest.Item) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- add(IndexRequest) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds an
IndexRequest
to the list of actions to execute. - add(IndexRequest) - Method in class org.elasticsearch.action.bulk.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
-
Adds an
IndexRequest
to the list of actions to execute. - add(IndexRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
IndexRequest
to the list of actions to execute. - add(SearchRequest) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
Add a search request to execute.
- add(SearchRequest) - Method in class org.elasticsearch.action.search.MultiSearchRequestBuilder
-
Add a search request to execute.
- add(SearchRequestBuilder) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
Add a search request to execute.
- add(SearchRequestBuilder) - Method in class org.elasticsearch.action.search.MultiSearchRequestBuilder
-
Add a search request to execute.
- add(TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- add(TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
- add(TermVectorsRequest, XContentParser) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- add(UpdateRequest) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds an
UpdateRequest
to the list of actions to execute. - add(UpdateRequest) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
UpdateRequest
to the list of actions to execute. - add(UpdateRequestBuilder) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Adds an
UpdateRequest
to the list of actions to execute. - add(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
-
adds a disco node to the builder.
- add(RestoreInProgress.Entry) - Method in class org.elasticsearch.cluster.RestoreInProgress.Builder
- add(AllocationCommand...) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Adds allocation commands to be applied to the cluster.
- add(AllocationCommand...) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
-
Adds allocation commands to be applied to the cluster.
- add(AllocationCommand...) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Adds a set of commands to this collection
- add(Decision) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
-
Add a decision to this
Decision.Multi
decision instance - add(RerouteExplanation) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
- add(IndexRoutingTable) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- add(IndexRoutingTable.Builder) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- add(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- add(DeleteResult) - Method in class org.elasticsearch.common.blobstore.DeleteResult
- add(BytesReference, long) - Method in class org.elasticsearch.index.translog.TranslogWriter
-
Add the given bytes to the translog with the specified sequence number; returns the location the bytes were written to.
- add(BytesReference, String, boolean, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(BytesReference, String, String, boolean, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Deprecated.
- add(BytesReference, String, String, String, FetchSourceContext, String, Boolean, boolean, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
- add(BytesReference, String, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds the data from the bytes to be processed by the bulk processor
- add(BytesReference, String, String, FetchSourceContext, String, boolean, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
- add(BytesReference, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Adds the data from the bytes to be processed by the bulk processor
- add(BytesReference, String, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Deprecated.
- add(BytesReference, String, XContentType) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Adds a framed data in binary format
- add(FieldMemoryStats) - Method in class org.elasticsearch.common.FieldMemoryStats
-
Adds / merges the given field memory stats into this stats instance
- add(Module...) - Method in class org.elasticsearch.common.inject.ModulesBuilder
- add(QueryCacheStats) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- add(RequestCacheStats) - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- add(SegmentsStats) - Method in class org.elasticsearch.index.engine.SegmentsStats
- add(FieldDataStats) - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- add(FlushStats) - Method in class org.elasticsearch.index.flush.FlushStats
- add(GetStats) - Method in class org.elasticsearch.index.get.GetStats
- add(FieldMapper) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- 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.RootObjectMapper.Builder
- add(MergeStats) - Method in class org.elasticsearch.index.merge.MergeStats
- add(QueryBuilder) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
-
Add a sub-query to this disjunction.
- add(RecoveryStats) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- add(RefreshStats) - Method in class org.elasticsearch.index.refresh.RefreshStats
- add(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(DocsStats) - Method in class org.elasticsearch.index.shard.DocsStats
- add(IndexingStats) - Method in class org.elasticsearch.index.shard.IndexingStats
- add(IndexingStats.Stats) - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
- add(IndexingStats, boolean) - Method in class org.elasticsearch.index.shard.IndexingStats
- add(ShardCountStats) - Method in class org.elasticsearch.index.shard.ShardCountStats
- add(ShardId, long) - Method in class org.elasticsearch.cluster.ClusterInfo.ReservedSpace.Builder
- add(StoreStats) - Method in class org.elasticsearch.index.store.StoreStats
- add(Translog.Operation) - Method in class org.elasticsearch.index.translog.Translog
-
Adds an operation to the transaction log.
- add(TranslogStats) - Method in class org.elasticsearch.index.translog.TranslogStats
- add(WarmerStats) - Method in class org.elasticsearch.index.warmer.WarmerStats
- add(FsInfo.Path) - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- add(DelayedBucket<B>) - Method in class org.elasticsearch.search.aggregations.TopBucketBuilder
-
Add a bucket if it is competitive.
- add(ScriptFieldsContext.ScriptField) - Method in class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext
- add(CompletionStats) - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- add(Transport.ResponseContext<? extends TransportResponse>) - Method in class org.elasticsearch.transport.Transport.ResponseHandlers
-
Adds a new response context and associates it with a new request ID.
- add(T) - Method in class org.elasticsearch.common.collect.EvictingQueue
-
Add the given element to the queue, possibly forcing an eviction from the head if
EvictingQueue.remainingCapacity()
is zero. - add(W) - Method in class org.elasticsearch.watcher.ResourceWatcherService
-
Register new resource watcher that will be checked in default
MEDIUM
frequency - add(W, ResourceWatcherService.Frequency) - Method in class org.elasticsearch.watcher.ResourceWatcherService
-
Register new resource watcher that will be checked in the given frequency
- Add(String, String, String, String, String, Boolean, 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_BACKING_INDEX - Enum constant in enum class org.elasticsearch.cluster.metadata.DataStreamAction.Type
- addAdditionalFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource
-
to be overridden by subclasses
- addAdditionalFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- addAdditionalFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- addAdditionalIndexSettingProvider(IndexSettingProvider) - Method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
-
Add a provider to be invoked to get additional index settings prior to an index being created
- addAffixGroupUpdateConsumer(List<Setting.AffixSetting<?>>, BiConsumer<String, Settings>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a affix settings consumer that accepts the settings for a group of settings.
- addAffixMapUpdateConsumer(Setting.AffixSetting<T>, Consumer<Map<String, T>>, BiConsumer<String, T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer for affix settings.
- addAffixUpdateConsumer(Setting.AffixSetting<A>, Setting.AffixSetting<B>, BiConsumer<String, Tuple<A, B>>, BiConsumer<String, Tuple<A, B>>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a affix settings consumer that accepts the values for two settings.
- addAffixUpdateConsumer(Setting.AffixSetting<T>, BiConsumer<String, T>, BiConsumer<String, T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer for affix settings.
- addAggregation(AggregationBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds an aggregation to the search operation.
- addAggregation(PipelineAggregationBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds an aggregation to the search operation.
- addAggregator(AggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- addAlias(String[], String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String[], String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String[], String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String[], String, QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, boolean) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(String, String, QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias to the index.
- addAlias(Alias) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds an alias that will be associated with the index when it gets created
- addAlias(Alias) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Adds an alias that will be added when the index template gets created.
- addAliasAction(IndicesAliasesRequest.AliasActions) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
-
Add the action to this request and validate it.
- addAliasAction(IndicesAliasesRequest.AliasActions) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Adds an alias action to the request.
- addAliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
- addAll(Collection<? extends T>) - Method in class org.elasticsearch.common.collect.EvictingQueue
-
Add the given elements to the queue, possibly forcing evictions from the head if
EvictingQueue.remainingCapacity()
is zero or becomes zero during the execution of this method. - addAll(List<? extends IndexableField>) - Method in class org.elasticsearch.index.mapper.LuceneDocument
- addAppender(Logger, Appender) - Static method in class org.elasticsearch.common.logging.Loggers
- addAsFromCloseToOpen(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsFromDangling(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsFromOpenToClose(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsNew(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsNewRestore(IndexMetadata, RecoverySource.SnapshotRecoverySource, IntSet) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsRecovery(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- addAsRestore(IndexMetadata, RecoverySource.SnapshotRecoverySource) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- 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.common.inject.multibindings.Multibinder
-
Returns a binding builder used to add a new element in the set.
- addBinding() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
- addBinding(K) - Method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a binding builder used to add a new entry in the map.
- addBinding(K) - Method in class org.elasticsearch.common.inject.multibindings.MapBinder.RealMapBinder
-
This creates two bindings.
- addBitsetMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addBlock(AddIndexBlockRequest, ActionListener<AddIndexBlockResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Adds a block to an index
- 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
- 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
- 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.JoinTaskExecutor
- addByte(byte) - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
-
Add a byte to the sequence.
- addCandidateGenerator(PhraseSuggestionBuilder.CandidateGenerator) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Adds a
PhraseSuggestionBuilder.CandidateGenerator
to this suggester. - addCandidates(List<DirectCandidateGenerator.Candidate>) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.CandidateSet
- addCell(Object) - Method in class org.elasticsearch.common.Table
- addCell(Object, String) - Method in class org.elasticsearch.common.Table
- addCharFilter(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- addCharFilter(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Add a name of char filter that will be used before the tokenizer.
- addCharFilter(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- addCharFilter(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Add char filter setting that will be used on top of a tokenizer provided.
- addClause(SpanQueryBuilder) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
-
Add a span clause to the current list of clauses
- addClause(SpanQueryBuilder) - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
-
Add a span clause to the current list of clauses
- 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
- 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.reroute.ClusterRerouteResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- addCustomFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.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.diskusage.AnalyzeIndexDiskUsageResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
- addCustomXContentFields(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
Override in subclass to add custom fields following the common `_shards` field
- 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.
- 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
- 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
- addDocValuesMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- 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
- addDynamicRuntimeField(RuntimeField) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Add a new runtime field dynamically created while parsing.
- added() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- addedNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- addEncoded(long, int) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractLinearCounting
-
Add encoded value to the linear counting.
- addError(String, Object...) - Method in class org.elasticsearch.common.inject.AbstractModule
- addError(String, Object...) - Method in interface org.elasticsearch.common.inject.Binder
-
Records an error message which will be presented to the user at a later time.
- addError(String, Object...) - Method in class org.elasticsearch.common.inject.PrivateModule
- addError(String, Object...) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Records an error message for type
I
which will be presented to the user at a later time. - addError(Throwable) - Method in class org.elasticsearch.common.inject.AbstractModule
- addError(Throwable) - Method in interface org.elasticsearch.common.inject.Binder
-
Records an exception, the full details of which will be logged, and the message of which will be presented to the user at a later time.
- addError(Throwable) - Method in class org.elasticsearch.common.inject.PrivateModule
- addError(Throwable) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Records an exception for type
I
, the full details of which will be logged, and the message of which will be presented to the user at a later time. - addError(Message) - Method in class org.elasticsearch.common.inject.AbstractModule
- addError(Message) - Method in interface org.elasticsearch.common.inject.Binder
-
Records an error message to be presented to the user at a later time.
- addError(Message) - Method in class org.elasticsearch.common.inject.PrivateModule
- addError(Message) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Records an error message to be presented to the user at a later time.
- addEstimateBytesAndMaybeBreak(long, String) - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
-
Add a number of bytes, tripping the circuit breaker if the aggregated estimates are above the limit.
- addEstimateBytesAndMaybeBreak(long, String) - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
-
Add bytes to the breaker and trip if the that puts breaker over the limit.
- addEstimateBytesAndMaybeBreak(long, String) - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- addExposureBuilder(ExposureBuilder<?>) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- addExtraXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.BaseTermQueryBuilder
- addExtraXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.TermQueryBuilder
- 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.
- 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
- addFieldStringsFromParameter(TermVectorsRequest, String) - Static method in class org.elasticsearch.rest.action.document.RestTermVectorsAction
- addFileDetail(String, long, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addFileDetails(String, long, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- addFiles(ImmutableOpenMap<String, SegmentsStats.FileStats>) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addFilterSettingParams(RestRequest) - Method in class org.elasticsearch.common.settings.SettingsFilter
- addForClosingShard(SearchStats.Stats) - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- addGlobalBlock(ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- addGlobalCheckpointListener(long, GlobalCheckpointListeners.GlobalCheckpointListener, TimeValue) - Method in class org.elasticsearch.index.shard.IndexShard
-
Add a global checkpoint listener.
- addGroup(TaskGroup.Builder) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup.Builder
- addHeader(String, String) - Method in class org.elasticsearch.http.HttpPipelinedResponse
- addHeader(String, String) - Method in interface org.elasticsearch.http.HttpResponse
- addHeader(String, String) - Method in class org.elasticsearch.rest.RestResponse
-
Add a custom header.
- addHeader(String, String...) - Method in exception org.elasticsearch.ElasticsearchException
-
Adds a new header with the given key.
- addHeader(String, List<String>) - Method in exception org.elasticsearch.ElasticsearchException
-
Adds a new header with the given key.
- addHighPriorityApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Adds a high priority applier of updated cluster states.
- addHighPriorityApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Adds a high priority applier of updated cluster states.
- addHumanReadableSettings(Settings) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Adds human readable version and creation date settings.
- addIds(String...) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
-
Adds ids to the query.
- addIgnoredField(String) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Add the given
field
to the set of ignored fields. - 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.
- AddIndexBlockAction - Class in org.elasticsearch.action.admin.indices.readonly
- AddIndexBlockClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.readonly
-
Cluster state update request that allows to add a block to one or more indices
- AddIndexBlockClusterStateUpdateRequest(IndexMetadata.APIBlock, long) - Constructor for class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockClusterStateUpdateRequest
- 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, AddIndexBlockAction, 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
- addIndexBoost(String, float) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the boost a specific index will receive when the query is executed against it.
- addIndexEventListener(IndexEventListener) - Method in class org.elasticsearch.index.IndexModule
-
Adds an
IndexEventListener
for this index. - addIndexOperationListener(IndexingOperationListener) - Method in class org.elasticsearch.index.IndexModule
-
Adds an
IndexingOperationListener
for this index. - addIndexShard(IndexShardRoutingTable) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- addIndexShardCount(ClusterStatsIndices.ShardStats) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
- addIndexTemplateV2(ClusterState, boolean, String, ComposableIndexTemplate) - 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
- addInvertedIndex(String, long) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- additionalSettings() - Method in class org.elasticsearch.plugins.Plugin
-
Additional node settings loaded by the plugin.
- ADDITIVE - Enum constant in enum class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.SeasonalityType
- addJoinVote(Join) - Method in class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- addLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
- addLifecycleListener(LifecycleListener) - Method in interface org.elasticsearch.common.component.LifecycleComponent
- addLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.repositories.FilterRepository
- addListener() - Method in enum class org.elasticsearch.action.ThreadingModel
- addListener(Consumer<ClusterInfo>) - Method in interface org.elasticsearch.cluster.ClusterInfoService
-
Add a listener for new cluster information
- addListener(Consumer<ClusterInfo>) - Method in class org.elasticsearch.cluster.EmptyClusterInfoService
- addListener(Consumer<ClusterInfo>) - Method in class org.elasticsearch.cluster.InternalClusterInfoService
- addListener(Listener) - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Registers new listener
- addListener(ActionListener<RecoveryResponse>) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
- addListener(ActionListener<Response>) - Method in class org.elasticsearch.action.StepListener
-
Registers the given listener to be notified with the result of this step.
- addListener(ActionListener<T>) - Method in class org.elasticsearch.action.support.ListenableActionFuture
-
Registers an
ActionListener
to be notified when this future is completed. - addListener(ActionListener<V>) - Method in class org.elasticsearch.common.util.concurrent.ListenableFuture
-
Adds a listener to this future.
- addListener(ActionListener<V>, ExecutorService, ThreadContext) - Method in class org.elasticsearch.common.util.concurrent.ListenableFuture
-
Adds a listener to this future.
- addListener(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Add a listener for updated cluster states.
- addListener(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Add a listener for updated cluster states
- addListener(MasterFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- addListener(NodesFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
- addListener(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
- addLowPriorityApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Adds an applier which will be called after all high priority and normal appliers have been called.
- addLowPriorityApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Adds an applier which will be called after all high priority and normal appliers have been called.
- addMapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- addMapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- addMapping(String, String, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds mapping that will be added when the index gets created.
- addMapping(String, String, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Adds mapping that will be added when the index template gets created.
- addMapping(String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds mapping that will be added when the index gets created.
- addMapping(String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Adds mapping that will be added when the index gets created.
- addMapping(String, XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Adds mapping that will be added when the index gets created.
- addMapping(String, XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Adds mapping that will be added when the index template gets created.
- addMaskRange(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addMaskRange(String, String)
but uses the mask itself as a key. - addMaskRange(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Add a new range to this aggregation using the CIDR notation.
- addMaxIndexAgeCondition(TimeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Adds condition to check if the index is at least
age
old - addMaxIndexAgeCondition(TimeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- addMaxIndexDocsCondition(long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Adds condition to check if the index has at least
numDocs
- addMaxIndexDocsCondition(long) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- addMaxIndexSizeCondition(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Adds a size-based condition to check if the index size is at least
size
. - addMaxIndexSizeCondition(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- addMaxPrimaryShardSizeCondition(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Adds a size-based condition to check if the size of the largest primary shard is at least
size
. - addMaxPrimaryShardSizeCondition(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- addMessage(String, Object...) - Method in class org.elasticsearch.common.inject.internal.Errors
- addMessage(Message) - Method in class org.elasticsearch.common.inject.internal.Errors
- addMessageListener(TransportMessageListener) - Method in class org.elasticsearch.transport.TransportService
- addMetadata(String, String...) - Method in exception org.elasticsearch.ElasticsearchException
-
Adds a new piece of metadata with the given key.
- addMetadata(String, List<String>) - Method in exception org.elasticsearch.ElasticsearchException
-
Adds a new piece of metadata with the given key.
- 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(String) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Add a single metric to the request.
- addMetric(String) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Add metric
- addMetric(String) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Add a single metric to the request.
- addMetrics(String...) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Add multiple metrics
- addMetrics(String...) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
-
Add an array of metrics to the request.
- addMetrics(String...) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Add an array of metric names
- addMetrics(String...) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Add an array of metrics to the request.
- addModule(PluginDescriptor) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- addMultiField(FieldMapper.Builder) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- addNamedQuery(String, Query) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- addNewHistoryCommit(Directory, Terminal, boolean) - 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
- addNormsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- 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
- addOperation() - Method in enum class org.elasticsearch.action.ThreadingModel
- addOption(O) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- addOption(PhraseSuggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- addOptions(List<O>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- addOrNotify(long, 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.
- addPeerRecoveryRetentionLease(String, long, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Retention leases for peer recovery have source
ReplicationTracker.PEER_RECOVERY_RETENTION_LEASE_SOURCE
, a lease ID containing the persistent node ID calculated byReplicationTracker.getPeerRecoveryRetentionLeaseId(java.lang.String)
, and retain operations with sequence numbers strictly greater than the given global checkpoint. - addPeerRecoveryRetentionLease(String, long, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.shard.IndexShard
- addPending(ClusterState) - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
Add an incoming, not yet committed cluster state
- 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.
- addPing(ZenPing.PingResponse) - Method in class org.elasticsearch.discovery.zen.ZenPing.PingCollection
-
adds a ping if newer than previous pings from the same node
- addPingResponseToCollection(ZenPing.PingResponse) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.PingingRound
- addPipelineAggregator(PipelineAggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- addPlugin(PluginDescriptor) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- addPlugins(Collection<Class<? extends Plugin>>, Class<? extends Plugin>...) - Static method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- addPlugins(Collection<Class<? extends Plugin>>, Collection<Class<? extends Plugin>>) - Static method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- addPoints(String, long) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- addPointsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addProcessedFile(long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Increments number of processed files
- 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.Profilers
-
Begin profiling a new query.
- addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addRange(String, double, double)
but the key will be automatically generated based onfrom
andto
. - addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Same as
GeoDistanceAggregationBuilder.addRange(String, double, double)
but the key will be automatically generated based onfrom
andto
. - addRange(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Same as
RangeAggregationBuilder.addRange(String, double, double)
but the key will be automatically generated based onfrom
andto
. - addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, double, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addRange(String, String, String)
but the key will be automatically generated based onfrom
andto
. - addRange(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addRange(String, String, String)
but the key will be automatically generated. - addRange(String, String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(String, ZonedDateTime, ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range to this aggregation.
- addRange(ZonedDateTime, ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addRange(String, ZonedDateTime, ZonedDateTime)
but the key will be automatically generated based onfrom
andto
. - addRange(GeoDistanceAggregationBuilder.Range) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- addRange(IpRangeAggregationBuilder.Range) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Add a new
IpRangeAggregationBuilder.Range
to this aggregation. - addRange(R) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- addReaderCloseListener(DirectoryReader, IndexReader.ClosedListener) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
-
Adds the given listener to the provided directory reader.
- addRecoveredBytesToFile(String, long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- 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
- addRefreshListener(long, 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(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() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- addRepositories(String...) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequestBuilder
-
Adds repositories to the list of repositories to get
- AddRequest(ShardId, String, long, String) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.AddRequest
- addRequestCircuitBreakerBytes(long) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Increment or decrement the number of bytes that have been allocated to service this request and potentially trigger a
CircuitBreakingException
. - addRescore(RescoreContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- addRescore(RescoreContext) - Method in class org.elasticsearch.search.internal.SearchContext
- addRescorer(RescorerBuilder<?>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a new rescorer.
- addRescorer(RescorerBuilder<?>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- addRescorer(RescorerBuilder<?>, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a new rescorer.
- addResponseHeader(String, String) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Add the
value
for the specifiedkey
Any duplicatevalue
is ignored. - addResponseHeader(String, String, Function<String, String>) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Add the
value
for the specifiedkey
with the specifieduniqueValue
used for de-duplication. - address() - Method in class org.elasticsearch.common.transport.TransportAddress
-
Returns the enclosed
InetSocketAddress
- address() - Method in class org.elasticsearch.http.HttpInfo
- address() - Method in exception org.elasticsearch.transport.ActionTransportException
-
The target address to invoke the action on.
- address() - Method in class org.elasticsearch.transport.TransportInfo
- addressesFromString(String) - Method in class org.elasticsearch.transport.TcpTransport
- addressesFromString(String) - Method in interface org.elasticsearch.transport.Transport
-
Returns an address from its string representation.
- addressesFromString(String) - Method in class org.elasticsearch.transport.TransportService
- addRestHandler(BaseRestHandler) - Method in class org.elasticsearch.usage.UsageService
-
Add a REST handler to this service.
- addResultReader(String, Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Add a reader for the shard level results of the aggregation.
- addResultReader(String, Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Add a reader for the shard level results of the aggregation.
- addResultReader(Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Add a reader for the shard level results of the aggregation with SearchPlugin.SearchExtensionSpec.getName()'s
ParseField.getPreferredName()
as theNamedWriteable.getWriteableName()
. - addResultReader(Writeable.Reader<? extends InternalAggregation>) - Method in class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Add a reader for the shard level results of the aggregation with SearchPlugin.SearchExtensionSpec.getName()'s
ParseField.getPreferredName()
as theNamedWriteable.getWriteableName()
. - addRetentionLease(String, long, String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Adds a new retention lease.
- addRetentionLease(String, long, String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Adds a new retention lease.
- 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
- addScriptField(String, Script) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds a script based field to load and return.
- addScriptField(String, Script) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- addScriptParam(String, Object) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - 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
- addSearchExt(SearchExtBuilder) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- addSearchExt(SearchExtBuilder) - Method in class org.elasticsearch.search.internal.SearchContext
- addSearchOperationListener(SearchOperationListener) - Method in class org.elasticsearch.index.IndexModule
-
Adds an
SearchOperationListener
for this index. - addSettingsUpdateConsumer(Consumer<Settings>, List<? extends Setting<?>>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Adds a settings consumer that is only executed if any setting in the supplied list of settings is changed.
- addSettingsUpdateConsumer(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, Version, ScriptService, Similarity>) - Method in class org.elasticsearch.index.IndexModule
-
Registers the given
Similarity
with the given name. - addSingleFilePath(Permissions, Path, String) - Static method in class org.elasticsearch.bootstrap.FilePermissionUtils
-
Add access to single file path
- addSnapshot(SnapshotId, 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
- addStoredFieldsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addSuggestion(String, SuggestionBuilder<?>) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
Adds an
SuggestionBuilder
instance under a user defined name. - addSuggestion(String, SuggestionSearchContext.SuggestionContext) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext
- addTargetThrottling(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- addTask(String, String, Params, PersistentTasksCustomMetadata.Assignment) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Builder
-
Adds a new task to the builder
- addTerm(T) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- addTermsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addTermVectors(String, long) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- addTermVectorsMemoryInBytes(long) - Method in class org.elasticsearch.index.engine.SegmentsStats
- addThrottleTime(long) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- addTimeoutListener(TimeValue, TimeoutClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Adds a cluster state listener that is expected to be removed during a short period of time.
- 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.
- addToSliceStatuses(BulkByScrollTask.StatusOrException) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- addTotals(FlushStats) - Method in class org.elasticsearch.index.flush.FlushStats
- addTotals(GetStats) - Method in class org.elasticsearch.index.get.GetStats
- addTotals(MergeStats) - Method in class org.elasticsearch.index.merge.MergeStats
- addTotals(RecoveryStats) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- addTotals(RefreshStats) - Method in class org.elasticsearch.index.refresh.RefreshStats
- addTotals(SearchStats) - Method in class org.elasticsearch.index.search.stats.SearchStats
- addTotals(IndexingStats) - Method in class org.elasticsearch.index.shard.IndexingStats
- addTotalsForClosingShard(SearchStats) - Method in class org.elasticsearch.index.search.stats.SearchStats
- addTransportAddress(TransportAddress) - Method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.Adds a transport address that will be used to connect to.
- addTransportAddresses(TransportAddress...) - Method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.Adds a list of transport addresses that will be used to connect to.
- addTypes(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
- addTypes(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequestBuilder
- addUnboundedFrom(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedFrom(String, double)
but the key will be computed automatically. - addUnboundedFrom(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Same as
GeoDistanceAggregationBuilder.addUnboundedFrom(String, double)
but the key will be computed automatically. - addUnboundedFrom(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Same as
RangeAggregationBuilder.addUnboundedFrom(String, double)
but the key will be computed automatically. - addUnboundedFrom(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedFrom(String, String)
but the key will be computed automatically. - addUnboundedFrom(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addUnboundedFrom(String, String)
but the key will be generated automatically. - addUnboundedFrom(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addRange(String, String, String)
but there will be no upper bound. - addUnboundedFrom(String, ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no upper bound.
- addUnboundedFrom(ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedFrom(String, ZonedDateTime)
but the key will be computed automatically. - addUnboundedTo(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedTo(String, double)
but the key will be computed automatically. - addUnboundedTo(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Same as
GeoDistanceAggregationBuilder.addUnboundedTo(String, double)
but the key will be computed automatically. - addUnboundedTo(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Same as
RangeAggregationBuilder.addUnboundedTo(String, double)
but the key will be computed automatically. - addUnboundedTo(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedTo(String, String)
but the key will be computed automatically. - addUnboundedTo(String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addUnboundedTo(String, String)
but the key will be generated automatically. - addUnboundedTo(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(String, double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(String, String) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Same as
IpRangeAggregationBuilder.addRange(String, String, String)
but there will be no lower bound. - addUnboundedTo(String, ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Add a new range with no lower bound.
- addUnboundedTo(ZonedDateTime) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
-
Same as
DateRangeAggregationBuilder.addUnboundedTo(String, ZonedDateTime)
but the key will be computed automatically. - addValidationError(String) - Method in exception org.elasticsearch.common.ValidationException
-
Add a new validation error to the accumulating validation errors
- addValidationError(String) - 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
- AddVotingConfigExclusionsAction - Class in org.elasticsearch.action.admin.cluster.configuration
- AddVotingConfigExclusionsRequest - Class in org.elasticsearch.action.admin.cluster.configuration
-
A request to add voting config exclusions for certain master-eligible nodes, and wait for these nodes to be removed from the voting configuration.
- AddVotingConfigExclusionsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
-
Construct a request to add voting config exclusions for master-eligible nodes matching the given node names, and wait for a default 30 seconds for these exclusions to take effect, removing the nodes from the voting configuration.
- AddVotingConfigExclusionsRequest(String[], 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.
- AddVotingConfigExclusionsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
- addWarning(String, Object...) - Static method in class org.elasticsearch.common.logging.HeaderWarning
- 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
- addZen1Attribute(boolean, Settings.Builder) - Static method in class org.elasticsearch.cluster.coordination.Coordinator
- adjacencyMatrix(String, String, Map<String, QueryBuilder>) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
AdjacencyMatrix
aggregation with the given name and separator - adjacencyMatrix(String, Map<String, QueryBuilder>) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
AdjacencyMatrix
aggregation with the given name. - AdjacencyMatrix - Interface in org.elasticsearch.search.aggregations.bucket.adjacency
-
A multi bucket aggregation where the buckets are defined by a set of filters (a bucket is produced per filter plus a bucket for each non-empty filter intersection so A, B and A&B).
- AdjacencyMatrix.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.adjacency
-
A bucket associated with a specific filter or pair (identified by its key)
- AdjacencyMatrixAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- AdjacencyMatrixAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregationBuilder(String, String, Map<String, QueryBuilder>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregationBuilder(String, Map<String, QueryBuilder>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
-
Read from a stream.
- AdjacencyMatrixAggregationBuilder(AdjacencyMatrixAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- AdjacencyMatrixAggregator - Class in org.elasticsearch.search.aggregations.bucket.adjacency
-
Aggregation for adjacency matrices.
- AdjacencyMatrixAggregator(String, AggregatorFactories, String, String[], Weight[], AggregationContext, Aggregator, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator
- AdjacencyMatrixAggregator.KeyedFilter - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- AdjacencyMatrixAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- AdjacencyMatrixAggregatorFactory(String, List<AdjacencyMatrixAggregator.KeyedFilter>, String, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregatorFactory
- ADJUST_PURE_NEGATIVE_DEFAULT - Static variable in class org.elasticsearch.index.query.BoolQueryBuilder
- AdjustableSemaphore - Class in org.elasticsearch.common.util.concurrent
- AdjustableSemaphore(int, boolean) - Constructor for class org.elasticsearch.common.util.concurrent.AdjustableSemaphore
- adjustPureNegative() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- adjustPureNegative(boolean) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
If a boolean query contains only negative ("must not") clauses should the BooleanQuery be enhanced with a
MatchAllDocsQuery
in order to act as a pure exclude. - admin() - Method in interface org.elasticsearch.client.Client
-
The admin client that can be used to perform administrative operations.
- admin() - Method in class org.elasticsearch.client.support.AbstractClient
- AdminClient - Interface in org.elasticsearch.client
-
Administrative actions/operations against the cluster or the indices.
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractBinaryDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractNumericDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortedDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortedNumericDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortedSetDocValues
- advance(int) - Method in class org.elasticsearch.index.fielddata.AbstractSortingNumericDocValues
- advance(int) - Method in interface org.elasticsearch.search.LeafNestedDocuments
-
Advance to a specific doc, and return its NestedIdentity, or
null
if not a child - ADVANCE - Enum constant in enum class org.elasticsearch.search.profile.query.QueryTimingType
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
- 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.GeoPointValues
-
Advance this instance to the given document id
- 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.MultiGeoPointValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.SortedBinaryDocValues
-
Advance this instance to the given document id
- advanceExact(int) - Method in class org.elasticsearch.index.fielddata.SortedNumericDoubleValues
-
Advance the iterator to exactly
target
and return whethertarget
has a value. - advanceExact(int) - Method in class org.elasticsearch.index.fielddata.StringScriptDocValues
- 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.
- 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(GetSnapshotsRequest.After) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- after(Priority) - Method in enum class org.elasticsearch.common.Priority
- after(Version) - Method in class org.elasticsearch.Version
- After(String, String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.After
- AFTER_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- 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.QueueResizingEsThreadPoolExecutor
- afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.threadpool.Scheduler.SafeScheduledThreadPoolExecutor
- afterIndexCreated(IndexService) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index has been created.
- afterIndexRemoved(Index, IndexSettings, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index has been removed.
- afterIndexRemoved(Index, IndexSettings, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason) - Method in class org.elasticsearch.search.SearchService
- afterIndexShardClosed(ShardId, IndexShard, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been closed.
- afterIndexShardCreated(IndexShard) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been created.
- afterIndexShardDeleted(ShardId, Settings) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been deleted from disk.
- afterIndexShardStarted(IndexShard) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after the index shard has been started.
- afterInjection(I) - Method in interface org.elasticsearch.common.inject.spi.InjectionListener
-
Invoked by Guice after it injects the fields and methods of instance.
- afterKey() - Method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation
-
Returns the last key in this aggregation.
- afterKey() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- afterKey() - Method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite
- afterLoad(TermsEnum, long) - Method in interface org.elasticsearch.index.fielddata.plain.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.
- afterPrimariesBeforeReplicas(RoutingAllocation) - 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) - Method in class org.elasticsearch.gateway.GatewayAllocator
- afterRefresh(boolean) - Method in class org.elasticsearch.index.shard.RefreshListeners
- afterRelease(boolean) - Method in class org.elasticsearch.common.recycler.ConcurrentDequeRecycler
- afterRelease(boolean) - Method in class org.elasticsearch.common.recycler.DequeRecycler
-
Called after a release.
- afterStart() - Method in class org.elasticsearch.common.component.LifecycleListener
- afterStop() - Method in class org.elasticsearch.common.component.LifecycleListener
- 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.
- aggReduceContextBuilder(Supplier<Boolean>, SearchRequest) - Method in class org.elasticsearch.search.SearchService
-
Returns a builder for
InternalAggregation.ReduceContext
. - 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(ObjectObjectHashMap<Term, TermStatistics>, ObjectObjectHashMap<String, CollectionStatistics>, long) - Constructor for class org.elasticsearch.search.dfs.AggregatedDfs
- AggregatedDfs(StreamInput) - Constructor for class org.elasticsearch.search.dfs.AggregatedDfs
- aggregateDfs(Collection<DfsSearchResult>) - Method in class org.elasticsearch.action.search.SearchPhaseController
- aggregation() - Method in class org.elasticsearch.search.aggregations.metrics.InternalScriptedMetric
- aggregation() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedScriptedMetric
- aggregation() - Method in interface org.elasticsearch.search.aggregations.metrics.ScriptedMetric
-
The result of the aggregation.
- aggregation(String, boolean) - Static method in class org.elasticsearch.search.aggregations.BucketOrder
-
Creates a bucket ordering strategy which sorts buckets based on a single-valued sub-aggregation.
- aggregation(String, String, boolean) - Static method in class org.elasticsearch.search.aggregations.BucketOrder
-
Creates a bucket ordering strategy which sorts buckets based on a metric from a multi-valued sub-aggregation.
- aggregation(AggregationBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Add an aggregation to perform as part of the search.
- aggregation(PipelineAggregationBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Add an aggregation to perform as part of the search.
- Aggregation - Interface in org.elasticsearch.search.aggregations
-
An aggregation.
- Aggregation.CommonFields - Class in org.elasticsearch.search.aggregations
-
Common xcontent fields that are shared among addAggregation
- AggregationBuilder - Class in org.elasticsearch.search.aggregations
-
A factory that knows how to create an
Aggregator
of a specific type. - AggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.AggregationBuilder
-
Constructs a new aggregation builder.
- AggregationBuilder(AggregationBuilder, AggregatorFactories.Builder) - Constructor for class org.elasticsearch.search.aggregations.AggregationBuilder
- AggregationBuilder.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. - 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
- 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) - Constructor for exception org.elasticsearch.search.aggregations.AggregationInitializationException
- AggregationInitializationException(String, Throwable) - Constructor for exception org.elasticsearch.search.aggregations.AggregationInitializationException
- AggregationInitializationException(StreamInput) - Constructor for exception org.elasticsearch.search.aggregations.AggregationInitializationException
- AggregationInspectionHelper - Class in org.elasticsearch.search.aggregations.support
-
Provides a set of static helpers to determine if a particular type of InternalAggregation "has a value" or not.
- AggregationInspectionHelper() - Constructor for class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- AggregationPath - Class in org.elasticsearch.search.aggregations.support
-
A path that can be used to sort/order buckets (in some multi-bucket aggregations, e.g.
- AggregationPath(List<AggregationPath.PathElement>) - Constructor for class org.elasticsearch.search.aggregations.support.AggregationPath
- AggregationPath.PathElement - Class in org.elasticsearch.search.aggregations.support
- AggregationPhase - Class in org.elasticsearch.search.aggregations
-
Aggregation phase of a search request, used to collect aggregations
- AggregationPhase() - Constructor for class org.elasticsearch.search.aggregations.AggregationPhase
- AggregationProfileBreakdown - Class in org.elasticsearch.search.profile.aggregation
-
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.
- aggregations - Variable in class org.elasticsearch.action.search.SearchResponseSections
- aggregations - Variable in class org.elasticsearch.search.aggregations.Aggregations
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.ParsedSingleBucketAggregation
- aggregations - Variable in class org.elasticsearch.search.aggregations.bucket.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 class org.elasticsearch.action.search.SearchResponseSections
- aggregations() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the bytes representing the aggregation builders for this request.
- aggregations() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- aggregations() - Method in class org.elasticsearch.search.internal.SearchContext
- aggregations() - Method in class org.elasticsearch.search.query.QuerySearchResult
- 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 - Class in org.elasticsearch.search.aggregations
-
Represents a set of
Aggregation
s - Aggregations(List<? extends Aggregation>) - Constructor for class org.elasticsearch.search.aggregations.Aggregations
- AGGREGATIONS - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.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.Aggregations
- AGGREGATIONS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- AggregationScript - Class in org.elasticsearch.script
- AggregationScript() - Constructor for class org.elasticsearch.script.AggregationScript
- AggregationScript(Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.AggregationScript
- AggregationScript.Factory - Interface in org.elasticsearch.script
-
A factory to construct stateful
AggregationScript
factories for a specific index. - AggregationScript.LeafFactory - Interface in org.elasticsearch.script
-
A factory to construct
AggregationScript
instances. - AggregationSpec(String, Writeable.Reader<? extends AggregationBuilder>, Aggregator.Parser) - Constructor for class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
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.
- 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.
- aggregators() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.PipelineTree
-
The
PipelineAggregator
s for the aggregation at this position in the tree. - aggregators() - Method in class org.elasticsearch.search.aggregations.SearchContextAggregations
- aggregators(Aggregator[]) - Method in class org.elasticsearch.search.aggregations.SearchContextAggregations
-
Registers all the created aggregators (top level aggregators) for the search execution context.
- AGGS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- aggsUsedForSorting - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- 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.
- 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(Set<Alias>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- aliases(Set<Alias>) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutRequest
- aliases(IndicesAliasesRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Allows to add/remove aliases from indices.
- aliases(IndicesAliasesRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Allows to add/remove aliases from indices.
- aliases(BytesReference) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the aliases that will be associated with the index when it gets created
- aliases(BytesReference) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Sets the aliases that will be associated with the index when it gets created
- aliases(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the aliases that will be associated with the index when it gets created
- aliases(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Sets the aliases that will be associated with the index when it gets created
- ALIASES - 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
- aliasesExist(GetAliasesRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Check to existence of index aliases.
- aliasesExist(GetAliasesRequest, ActionListener<AliasesExistResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Check the existence of specified index aliases.
- AliasesExistAction - Class in org.elasticsearch.action.admin.indices.alias.exists
- AliasesExistRequestBuilder - Class in org.elasticsearch.action.admin.indices.alias.exists
- AliasesExistRequestBuilder(ElasticsearchClient, AliasesExistAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistRequestBuilder
- AliasesExistResponse - Class in org.elasticsearch.action.admin.indices.alias.exists
- AliasesExistResponse(boolean) - Constructor for class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistResponse
- AliasesNotFoundException - Exception in org.elasticsearch.rest.action.admin.indices
- AliasesNotFoundException(String...) - Constructor for exception org.elasticsearch.rest.action.admin.indices.AliasesNotFoundException
- AliasesNotFoundException(StreamInput) - Constructor for exception org.elasticsearch.rest.action.admin.indices.AliasesNotFoundException
- AliasesRequest - Interface in org.elasticsearch.action
-
Needs to be implemented by all
ActionRequest
subclasses that relate to one or more indices and one or more aliases. - aliasesVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- aliasesVersion(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- aliasFilter() - Method in class org.elasticsearch.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. - AliasFilter(StreamInput) - Constructor for class org.elasticsearch.search.internal.AliasFilter
- AliasFilter(QueryBuilder, String...) - Constructor for class org.elasticsearch.search.internal.AliasFilter
- AliasFilterParsingException - Exception in org.elasticsearch.indices
- AliasFilterParsingException(StreamInput) - Constructor for exception org.elasticsearch.indices.AliasFilterParsingException
- AliasFilterParsingException(Index, String, String, Throwable) - Constructor for exception org.elasticsearch.indices.AliasFilterParsingException
- AliasMetadata - Class in org.elasticsearch.cluster.metadata
- AliasMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.AliasMetadata
- AliasMetadata.Builder - Class in org.elasticsearch.cluster.metadata
- AliasValidator - Class in org.elasticsearch.cluster.metadata
-
Validator for an alias, to be used before adding an alias to the index metadata and make sure the alias is valid
- AliasValidator() - Constructor for class org.elasticsearch.cluster.metadata.AliasValidator
- 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 - 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.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
- ALL - Enum constant in enum class org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
- ALL - Static variable in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- ALL - Static variable in class org.elasticsearch.action.support.ActiveShardCount
- ALL - Static variable in enum 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_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_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_NODES - Static variable in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- ALL_PATTERN - Static variable in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
- 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
- AllFieldMapper - Class in org.elasticsearch.index.mapper
-
Noop mapper that ensures that mappings created in 6x that explicitly disable the _all field can be restored in this version.
- AllFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- AllFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- allHeaders(String) - Method in interface org.elasticsearch.http.HttpRequest
- allMetrics() - Static method in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
- allocate(RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- allocate(RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.allocator.ShardsAllocator
-
Allocates shards to nodes in the cluster.
- allocateDangled(Collection<IndexMetadata>, ActionListener<LocalAllocateDangledIndices.AllocateDangledResponse>) - Method in class org.elasticsearch.gateway.LocalAllocateDangledIndices
- AllocateDangledRequest(StreamInput) - Constructor for class org.elasticsearch.gateway.LocalAllocateDangledIndices.AllocateDangledRequest
- AllocateDangledResponse(StreamInput) - Constructor for class org.elasticsearch.gateway.LocalAllocateDangledIndices.AllocateDangledResponse
- AllocatedPersistentTask - Class in org.elasticsearch.persistent
-
Represents a executor node operation that corresponds to a persistent task
- AllocatedPersistentTask(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.persistent.AllocatedPersistentTask
- AllocatedPersistentTask.State - Enum Class in org.elasticsearch.persistent
- allocatedProcessors(Settings) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
-
Returns the number of allocated processors.
- allocatedSizeInBytes(Path) - Static method in class org.elasticsearch.common.filesystem.FileSystemNatives
-
Returns the number of allocated bytes on disk for a given file.
- 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_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_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
- AllocationCommand - Interface in org.elasticsearch.cluster.routing.allocation.command
-
A command to move shards in some way.
- AllocationCommands - Class in org.elasticsearch.cluster.routing.allocation.command
-
A simple
AllocationCommand
composite managing severalAllocationCommand
implementations - AllocationCommands(AllocationCommand...) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Creates a new set of
AllocationCommands
- AllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
AllocationDecider
is an abstract base class that allows to make dynamic cluster- or index-wide shard allocation decisions on a per-node basis. - AllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
- AllocationDeciders - Class in org.elasticsearch.cluster.routing.allocation.decider
-
A composite
AllocationDecider
combining the "decision" of multipleAllocationDecider
implementations into a single allocation decision. - AllocationDeciders(Collection<AllocationDecider>) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- AllocationDecision - Enum 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.
- allocationExplain(ClusterAllocationExplainRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Explain the allocation of a shard
- allocationExplain(ClusterAllocationExplainRequest, ActionListener<ClusterAllocationExplainResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Explain the allocation of a shard
- allocationId - Variable in class org.elasticsearch.index.shard.ShardStateMetadata
- allocationId() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
An id that uniquely identifies an allocation.
- allocationId() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- AllocationId - Class in org.elasticsearch.cluster.routing
-
Uniquely identifies an allocation.
- AllocationService - Class in org.elasticsearch.cluster.routing.allocation
-
This service manages the node allocation of a cluster.
- AllocationService(AllocationDeciders, ShardsAllocator, ClusterInfoService, SnapshotsInfoService) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
- AllocationService(AllocationDeciders, GatewayAllocator, ShardsAllocator, ClusterInfoService, SnapshotsInfoService) - Constructor for class org.elasticsearch.cluster.routing.allocation.AllocationService
- AllocationService.CommandsResult - Class in org.elasticsearch.cluster.routing.allocation
-
this class is used to describe results of applying a set of
AllocationCommand
- ALLOCATOR_NAME - Static variable in class org.elasticsearch.gateway.GatewayAllocator
- ALLOW_CONCURRENT_MODIFICATION - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
When set to
true
,BlobStoreRepository.bestEffortConsistency
will be set totrue
and concurrent modifications of the repository contents will not result in the repository being marked as corrupted. - ALLOW_EXPENSIVE_QUERIES - Static variable in class org.elasticsearch.search.SearchService
- ALLOW_NO_INDICES - Enum constant in enum class org.elasticsearch.action.support.IndicesOptions.Option
- ALLOW_NONE - Static variable in class org.elasticsearch.script.ScriptService
- ALLOW_UNMAPPED - Static variable in class org.elasticsearch.index.IndexSettings
- allowAliasesToMultipleIndices() - Method in class org.elasticsearch.action.support.IndicesOptions
- allowAutoCreate(Boolean) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.Builder
- ALLOWED_CONTENT_FIELD_NAMES - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper
- ALLOWED_INTERVALS - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- allowedRequestHeaders() - Method in class org.elasticsearch.http.CorsHandler.Config
- allowedRequestMethods() - Method in class org.elasticsearch.http.CorsHandler.Config
- allowExpensiveQueries() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- allowLeadingWildcard() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- allowLeadingWildcard(Boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Should leading wildcards be allowed or not.
- allowNoIndices() - Method in class org.elasticsearch.action.support.IndicesOptions
- allowPartialSearchResults() - Method in class org.elasticsearch.action.search.SearchRequest
- allowPartialSearchResults() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- allowPartialSearchResults(boolean) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets if this request should allow partial results.
- allowPrimary() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- allowsNull(Annotation[]) - Static method in class org.elasticsearch.common.inject.internal.Nullability
- 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 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.BaseRestHandler.Wrapper
- 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 interface org.elasticsearch.rest.RestHandler
-
Controls whether requests handled by this class are allowed to to access system indices by default.
- 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. - allReplicasActive(ShardId, Metadata) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns
true
iff all replicas are active for the given shard routing. - allShards() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Indicates whether the query should be validated on all shards instead of one random shard
- allShards() - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
All the shards (replicas) for all indices in this routing table.
- allShards(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Indicates whether the query should be validated on all shards instead of one random shard
- allShards(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
All the shards (replicas) for the provided index.
- allShards(String[]) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- allShardsIncludingRelocationTargets(String[]) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- allShardsStarted() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns
true
iff all shards in the routing table are started otherwisefalse
- allUrls - Variable in class org.elasticsearch.plugins.PluginsService.Bundle
- alpha(double) - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel.EWMAModelBuilder
-
Alpha controls the smoothing of the data.
- alpha(double) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel.HoltLinearModelBuilder
-
Alpha controls the smoothing of the data.
- alpha(double) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
-
Alpha controls the smoothing of the data.
- ALPHA - Static variable in class org.elasticsearch.node.ResponseCollectorService
-
The weight parameter used for all moving averages of parameters.
- 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.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.common.inject.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>) - Constructor for class org.elasticsearch.indices.analysis.AnalysisModule
- AnalysisModule.AnalysisProvider<T> - Interface in org.elasticsearch.indices.analysis
-
The basic factory interface for analysis components.
- AnalysisPlugin - Interface in org.elasticsearch.plugins
-
An additional extension point for
Plugin
s that extends Elasticsearch's analysis functionality. - analysisRegistry - Variable in class org.elasticsearch.ingest.Processor.Parameters
-
Provide analyzer support
- AnalysisRegistry - Class in org.elasticsearch.index.analysis
-
An internal registry for tokenizer, token filter, char filter and analyzer.
- AnalysisRegistry(Environment, Map<String, AnalysisModule.AnalysisProvider<CharFilterFactory>>, Map<String, AnalysisModule.AnalysisProvider<TokenFilterFactory>>, Map<String, AnalysisModule.AnalysisProvider<TokenizerFactory>>, Map<String, AnalysisModule.AnalysisProvider<AnalyzerProvider<?>>>, Map<String, AnalysisModule.AnalysisProvider<AnalyzerProvider<?>>>, Map<String, PreConfiguredCharFilter>, Map<String, PreConfiguredTokenFilter>, Map<String, PreConfiguredTokenizer>, Map<String, PreBuiltAnalyzerProviderFactory>) - Constructor for class org.elasticsearch.index.analysis.AnalysisRegistry
- 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 interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text under the provided index.
- analyze(AnalyzeAction.Request, ActionListener<AnalyzeAction.Response>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text under the provided index.
- analyze(AnalyzeAction.Request, AnalysisRegistry, IndexService, int) - Static method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- ANALYZE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- AnalyzeAction - Class in org.elasticsearch.action.admin.indices.analyze
- AnalyzeAction.AnalyzeToken - Class in org.elasticsearch.action.admin.indices.analyze
- AnalyzeAction.AnalyzeTokenList - Class in org.elasticsearch.action.admin.indices.analyze
- AnalyzeAction.CharFilteredText - Class in org.elasticsearch.action.admin.indices.analyze
- AnalyzeAction.DetailAnalyzeResponse - Class in org.elasticsearch.action.admin.indices.analyze
- AnalyzeAction.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
- AnalyzeIndexDiskUsageAction - Class in org.elasticsearch.action.admin.indices.diskusage
- AnalyzeIndexDiskUsageAction() - Constructor for class org.elasticsearch.action.admin.indices.diskusage.AnalyzeIndexDiskUsageAction
- 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.CommonTermsQueryBuilder
-
Deprecated.
- analyzer() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Get the analyzer to use, if previously set, otherwise
null
- analyzer() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Get the analyzer to use, if previously set, otherwise
null
- analyzer() - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Get the analyzer to use, if previously set, otherwise
null
- analyzer() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Get the analyzer to use, if previously set, otherwise
null
- analyzer() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- analyzer() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- analyzer() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
The optional analyzer used to analyze the query string.
- analyzer() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns the analyzer to use for the query.
- analyzer() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the
SuggestionBuilder.analyzer()
parameter - analyzer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- analyzer(String) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
The analyzer that will be used to analyze the text.
- analyzer(String) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Explicitly set the analyzer to use.
- analyzer(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
The optional analyzer used to analyze the query string.
- analyzer(String) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Specify an analyzer to use for the query.
- analyzer(String) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
Sets the analyzer to analyse to suggest text with.
- ANALYZER - Static variable in class org.elasticsearch.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, AnalyzeAction) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
- AnalyzeRequestBuilder(ElasticsearchClient, AnalyzeAction, String, String...) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
- 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
- AnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer> - Interface in org.elasticsearch.index.analysis
- Analyzers(IndexAnalyzers, Function<FieldMapper, NamedAnalyzer>, Function<FieldMapper, Integer>) - 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(Matcher<? super T>) - Method in class org.elasticsearch.common.inject.matcher.AbstractMatcher
- and(Matcher<? super T>) - Method in interface org.elasticsearch.common.inject.matcher.Matcher
-
Returns a new matcher which returns
true
if both this and the given matcher returntrue
. - AND - 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
- AnnotatedBindingBuilder<T> - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - AnnotatedConstantBindingBuilder - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - AnnotatedElementBuilder - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedConstantBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedElementBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Annotation) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- annotatedWith(Annotation) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- annotatedWith(Annotation) - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- annotatedWith(Annotation) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches elements (methods, classes, etc.) with a given annotation.
- annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedConstantBindingBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.AnnotatedElementBuilder
-
See the EDSL examples at
Binder
. - annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- annotatedWith(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches elements (methods, classes, etc.) with a given annotation.
- annotatedWithInternal(Annotation) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
-
Sets the binding to a copy with the specified annotation on the bound key
- annotatedWithInternal(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
-
Sets the binding to a copy with the specified annotation on the bound key
- ANNOTATION_ALREADY_SPECIFIED - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- Annotations - Class in org.elasticsearch.common.inject.internal
-
Annotation utilities.
- Annotations() - Constructor for class org.elasticsearch.common.inject.internal.Annotations
- any() - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches any input.
- ANY - 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
- 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(LogEvent) - Method in class org.elasticsearch.common.logging.HeaderWarningAppender
- appendDescriptionWithoutAttributes(StringBuilder) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- appendElement(T[], T) - Static method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
- appendFieldValue(String, Object) - Method in class org.elasticsearch.ingest.IngestDocument
-
Appends the provided value to the provided path in the document.
- appendFieldValue(String, Object, boolean) - Method in class org.elasticsearch.ingest.IngestDocument
-
Appends the provided value to the provided path in the document.
- appendFieldValue(TemplateScript.Factory, ValueSource) - Method in class org.elasticsearch.ingest.IngestDocument
-
Appends the provided value to the provided path in the document.
- appendFieldValue(TemplateScript.Factory, ValueSource, boolean) - Method in class org.elasticsearch.ingest.IngestDocument
-
Appends the provided value to the provided path in the document.
- appendThreadPoolExecutorDetails(StringBuilder) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
-
Append details about this thread pool to the specified
StringBuilder
. - appendThreadPoolExecutorDetails(StringBuilder) - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
- 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.
- 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(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.upgrades.FeatureMigrationResults.ResultsDiff
- apply(ImmutableOpenMap<K, T>) - Method in class org.elasticsearch.cluster.DiffableUtils.ImmutableOpenMapDiff
- apply(Settings, Settings) - Method in interface org.elasticsearch.common.settings.AbstractScopedSettings.SettingUpdater
-
Updates this updaters value if it has changed.
- apply(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(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 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.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) - Method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
- applyCreateIndexRequest(ClusterState, CreateIndexClusterStateUpdateRequest, boolean, BiConsumer<Metadata.Builder, IndexMetadata>) - Method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
-
Handles the cluster state transition to a version that reflects the
CreateIndexClusterStateUpdateRequest
. - applyDeleteOperationOnPrimary(long, String, String, VersionType, long, long) - Method in class org.elasticsearch.index.shard.IndexShard
- applyDeleteOperationOnReplica(long, long, long, String, String) - Method in class org.elasticsearch.index.shard.IndexShard
- applyFailedShard(ClusterState, ShardRouting, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
- applyFailedShards(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>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
- applyFailedShards(ClusterState, List<FailedShard>, List<StaleShard>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Applies the failed shards.
- applyFilters(BytesReference, XContentType) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- applyHardSizeLimit(Settings, String) - Method in class org.elasticsearch.threadpool.ExecutorBuilder
- applyIndexOperationOnPrimary(long, VersionType, SourceToParse, long, long, long, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
- applyIndexOperationOnReplica(long, long, long, 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.LongScriptFieldType
- 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.
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- applyTo(Binder) - Method in interface org.elasticsearch.common.inject.spi.Element
-
Writes this module element to the given binder (optional operation).
- applyTo(Binder) - Method in interface org.elasticsearch.common.inject.spi.ExposedBinding
-
Unsupported.
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.Message
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.ScopeBinding
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.StaticInjectionRequest
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.TypeConverterBinding
- applyTo(Binder) - Method in class org.elasticsearch.common.inject.spi.TypeListenerBinding
- applyTo(ScopedBindingBuilder) - Method in class org.elasticsearch.common.inject.internal.Scoping
- applyTranslogOperation(Translog.Operation, Engine.Operation.Origin) - Method in class org.elasticsearch.index.shard.IndexShard
- approximateCardinality() - Method in class org.apache.lucene.util.CombinedBitSet
- ARC - 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
- ARCHIVED_SETTINGS_PREFIX - Static variable in class org.elasticsearch.common.settings.AbstractScopedSettings
- archiveUnknownOrInvalidSettings(Settings, Consumer<Map.Entry<String, String>>, BiConsumer<Map.Entry<String, String>, IllegalArgumentException>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Archives invalid or unknown settings.
- areAllConsistent() - Method in class org.elasticsearch.common.settings.ConsistentSettingsService
-
Verifies that the hashes of consistent secure settings in the latest
ClusterState
verify for the values of those same settings on the local node. - areValuesSourcesEmpty() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSource
- array() - Method in class org.elasticsearch.common.bytes.BytesArray
- 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()
. - arrayAsArrayList(E...) - Static method in class org.elasticsearch.common.util.CollectionUtils
- arrayOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns an array type whose elements are all instances of
componentType
. - 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
- 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
- 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
- asArrayList(E, E...) - Static method in class org.elasticsearch.common.util.CollectionUtils
- asArrayList(E, E, E...) - Static method in class org.elasticsearch.common.util.CollectionUtils
- ASC - 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.
- asCopy() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
-
Returns a copy of the current
IndexShardSnapshotStatus
. - asDistance() - Method in class org.elasticsearch.common.unit.Fuzziness
- asDistance(String) - Method in class org.elasticsearch.common.unit.Fuzziness
- asEagerSingleton() - Method in interface org.elasticsearch.common.inject.binder.ScopedBindingBuilder
-
Instructs the
Injector
to eagerly initialize this singleton-scoped binding upon creation. - asEagerSingleton() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- asFloat() - Method in class org.elasticsearch.common.unit.Fuzziness
- asFuture() - Method in class org.elasticsearch.action.StepListener
-
Returns the future associated with the given step listener
- 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.Aggregations
-
The list of
Aggregation
s. - asMap() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- asMap() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
- asMap() - Method in class org.elasticsearch.search.aggregations.Aggregations
-
Returns the
Aggregation
s keyed by aggregation name. - asMap() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
- 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
- asQueryParam() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.After
- 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.
- 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
- 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)
- Assertions - Class in org.elasticsearch
-
Provides a static final field that can be used to check if assertions are enabled.
- assertMasterUpdateThread() - Static method in class org.elasticsearch.cluster.service.MasterService
- assertMaxSeqNoEqualsToGlobalCheckpoint(long, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- assertNonPrimaryOrigin(Engine.Operation) - Method in class org.elasticsearch.index.engine.InternalEngine
- assertNoOpenTranslogRefs() - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
- assertNotClusterStateUpdateThread(String) - Static method in class org.elasticsearch.cluster.service.ClusterApplierService
-
asserts that the current thread is NOT the cluster state update thread
- assertNotMasterUpdateThread(String) - Static method in class org.elasticsearch.cluster.service.MasterService
- assertNotScheduleThread(String) - Static method in class org.elasticsearch.threadpool.ThreadPool
- assertNotTransportThread(String) - Static method in enum class org.elasticsearch.transport.Transports
- 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
- 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
- assertSnapshotOrGenericThread() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- assertTransportThread() - Static method in enum class org.elasticsearch.transport.Transports
- assertZValue(boolean, double) - Static method in class org.elasticsearch.common.geo.GeoPoint
- assignedShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of assigned shards, including relocation targets - assignedShards(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns all shards that are not in the state UNASSIGNED with the same shard ID as the given shard.
- assignedToNode() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns
true
iff this shard is assigned to a node ie. - Assignment(String, String) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Assignment
- ASSIGNMENT_PARSER - Static variable in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- AssignmentDecision - Class in org.elasticsearch.persistent.decider
-
AssignmentDecision
represents the decision made during the process of assigning a persistent task to a node of the cluster. - AssignmentDecision(AssignmentDecision.Type, String) - Constructor for class org.elasticsearch.persistent.decider.AssignmentDecision
- AssignmentDecision.Type - Enum Class in org.elasticsearch.persistent.decider
- assignRescoreDocIds(RescoreDocIds) - Method in class org.elasticsearch.search.internal.SearchContext
- Assisted - Annotation Interface in org.elasticsearch.common.inject.assistedinject
-
Annotates an injected parameter or field whose value comes from an argument to a factory method.
- AssistedInject - Annotation Interface in org.elasticsearch.common.inject.assistedinject
-
Deprecated.
FactoryProvider
now works better with the standard @Inject annotation. When using that annotation, parameters are matched by name and type rather than by position. In addition, values that use the standard @Inject constructor annotation are eligible for method interception. - AssociatedIndexDescriptor - Class in org.elasticsearch.indices
-
An "associated index" is an index that is related to or derived from a system index, but should not be considered a system index, usually because it is meant to be visible to users.
- 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
- asString() - Method in class org.elasticsearch.common.unit.Fuzziness
- asTuple() - Method in class org.elasticsearch.script.ScriptCache.CompilationRate
- ASYNC - Enum constant in enum class org.elasticsearch.index.translog.Translog.Durability
-
Async durability - translogs are synced based on a time interval.
- AsyncAction(Task, Request, ActionListener<Response>) - Constructor for class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- AsyncBiFunction<T,
U, C> - Interface in org.elasticsearch.common -
A
BiFunction
-like interface designed to be used with asynchronous executions. - AsyncBroadcastAction(Task, Request, ActionListener<Response>) - Constructor for class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- AsyncIOProcessor<Item> - Class in org.elasticsearch.common.util.concurrent
-
This async IO processor allows to batch IO operations and have a single writer processing the write operations.
- AsyncIOProcessor(Logger, int, ThreadContext) - Constructor for class org.elasticsearch.common.util.concurrent.AsyncIOProcessor
- AsyncShardFetch<T extends BaseNodeResponse> - Class in org.elasticsearch.gateway
-
Allows to asynchronously fetch shard related data from other nodes for allocation, without blocking the cluster update thread.
- AsyncShardFetch(Logger, String, ShardId, String, AsyncShardFetch.Lister<? extends BaseNodesResponse<T>, T>) - Constructor for class org.elasticsearch.gateway.AsyncShardFetch
- AsyncShardFetch.FetchResult<T extends BaseNodeResponse> - Class in org.elasticsearch.gateway
-
The result of a fetch operation.
- AsyncShardFetch.Lister<NodesResponse extends BaseNodesResponse<NodeResponse>,
NodeResponse extends BaseNodeResponse> - Interface in org.elasticsearch.gateway -
An action that lists the relevant shard data that needs to be fetched.
- asyncShardOperation(ExplainRequest, ShardId, ActionListener<ExplainResponse>) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- asyncShardOperation(GetRequest, ShardId, ActionListener<GetResponse>) - Method in class org.elasticsearch.action.get.TransportGetAction
- asyncShardOperation(MultiGetShardRequest, ShardId, ActionListener<MultiGetShardResponse>) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- asyncShardOperation(TermVectorsRequest, ShardId, ActionListener<TermVectorsResponse>) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- asyncShardOperation(Request, ShardId, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- asyncShardOperation(RetentionLeaseActions.RemoveRequest, ShardId, ActionListener<ActionResponse.Empty>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove.TransportAction
- 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
- attemptSyncedFlush(String[], IndicesOptions, ActionListener<SyncedFlushResponse>) - Method in class org.elasticsearch.indices.flush.SyncedFlushService
-
a utility method to perform a synced flush for all shards of multiple indices.
- attemptSyncedFlush(ShardId, ActionListener<ShardsSyncedFlushResult>) - Method in class org.elasticsearch.indices.flush.SyncedFlushService
- attr - Variable in class org.elasticsearch.common.Table.Cell
- attributes - Variable in class org.elasticsearch.index.engine.Segment
- attributes() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- attributes() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- attributes(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- attributes(List<String>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- ATTRIBUTES - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Fields
- 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_IMPORT_DANGLING_INDICES_SETTING - Static variable in class org.elasticsearch.gateway.DanglingIndicesState
-
Controls whether dangling indices should be automatically detected and imported into the cluster state upon discovery.
- AUTO_RELEASE_INDEX_ENABLED_KEY - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- AUTO_SLICES - Static variable in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- AUTO_SLICES_VALUE - Static variable in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- AUTO_THROTTLE_SETTING - Static variable in class org.elasticsearch.index.MergeSchedulerConfig
- 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
- AutoDateHistogramAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.histogram
- AutoDateHistogramAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
-
Create a new builder with the given name.
- AutoDateHistogramAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
-
Read from a stream, for internal use only.
- AutoDateHistogramAggregationBuilder(AutoDateHistogramAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- AutoDateHistogramAggregationBuilder.RoundingInfo - Class in org.elasticsearch.search.aggregations.bucket.histogram
- AutoDateHistogramAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.histogram
- AutoDateHistogramAggregatorFactory(String, ValuesSourceConfig, int, AutoDateHistogramAggregationBuilder.RoundingInfo[], AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>, AutoDateHistogramAggregatorSupplier) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregatorFactory
- AutoDateHistogramAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.bucket.histogram
- AutoExpandReplicas - Class in org.elasticsearch.cluster.metadata
-
This class acts as a functional wrapper around the
index.auto_expand_replicas
setting. - autoGenerateSynonymsPhraseQuery - Variable in class org.elasticsearch.index.search.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
- AutoIdHandler(Supplier<DiscoveryNodes>) - Constructor for class org.elasticsearch.rest.action.document.RestIndexAction.AutoIdHandler
- 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
- AutoPutMappingAction - Class in org.elasticsearch.action.admin.indices.mapping.put
- AutoQueueAdjustingExecutorBuilder - Class in org.elasticsearch.threadpool
-
A builder for executors that automatically adjust the queue length as needed, depending on Little's Law.
- available() - Method in class org.elasticsearch.common.io.stream.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 class org.elasticsearch.index.codec.CodecService
-
Returns all registered available codec names
- availableIndexFolders() - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all folder names in ${data.paths}/nodes/{node.id}/indices folder
- availableIndexFolders(Predicate<String>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns folder names in ${data.paths}/nodes/{node.id}/indices folder that don't match the given predicate.
- availableIndexFoldersForPath(NodeEnvironment.DataPath) - Method in class org.elasticsearch.env.NodeEnvironment
-
Return all directory names in the nodes/{node.id}/indices directory for the given node path.
- availableIndexFoldersForPath(NodeEnvironment.DataPath, Predicate<String>) - Method in class org.elasticsearch.env.NodeEnvironment
-
Return directory names in the nodes/{node.id}/indices directory for the given node path that don't match the given predicate.
- availableShardPaths(ShardId) - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all shard paths excluding custom shard path.
- availableShards() - Method in class org.elasticsearch.indices.IndexingMemoryController
- avg - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- avg - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- avg(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Avg
aggregation with the given name. - Avg - 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
- AvgBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregator
-
Read from a stream.
- avgShardsPerNode() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
-
Returns the global average of shards per node
- avgShardsPerNode(String) - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
-
Returns the average of shards per node for the given index
- awaitAllNodes(TimeValue) - Method in class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
Allows to wait for all non master nodes to reply to the publish event up to a timeout
- awaitClose(long, TimeUnit) - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Closes the processor.
- awaitClose(long, TimeUnit) - Method in class org.elasticsearch.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 interface org.elasticsearch.repositories.Repository
-
Block until all in-flight operations for this repository have completed.
- 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.
- awaitShardSearchActive(Consumer<Boolean>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Registers the given listener and invokes it once the shard is active again and all pending refresh translog location has been refreshed.
- awaitTermination() - Method in interface org.elasticsearch.index.IndexWarmer.TerminationHandle
-
Wait until execution of the warm-up action completes.
- awaitTermination(long, TimeUnit) - Method in class org.elasticsearch.threadpool.ThreadPool
- awaitTermination(ScheduledThreadPoolExecutor, long, TimeUnit) - Static method in interface org.elasticsearch.threadpool.Scheduler
- AwarenessAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This
AllocationDecider
controls shard allocation based onawareness
key-value pairs defined in the node configuration. - AwarenessAllocationDecider(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
B
- BACKGROUND_IS_SUPERSET - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
- backgroundFilter() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- backgroundFilter() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- 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
- 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
- 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 https://github.com/elastic/elasticsearch/issues/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_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
re-balances the nodes allocations within an cluster based on aBalancedShardsAllocator.WeightFunction
. - BalancedShardsAllocator(Settings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- BalancedShardsAllocator(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- BalancedShardsAllocator.Balancer - Class in org.elasticsearch.cluster.routing.allocation.allocator
- Balancer(Logger, RoutingAllocation, BalancedShardsAllocator.WeightFunction, float) - Constructor for class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
- BAN_PARENT_ACTION_NAME - Static variable in class org.elasticsearch.tasks.TaskCancellationService
- base64UUID() - Static method in class org.elasticsearch.common.UUIDs
-
Generates a time-based UUID (similar to Flake IDs), which is preferred when generating an ID to be indexed into a Lucene index as primary key.
- BaseAggregationBuilder - Interface in org.elasticsearch.search.aggregations
-
Interface shared by
AggregationBuilder
andPipelineAggregationBuilder
so they can conveniently share the same namespace forXContentParser.namedObject(Class, String, Object)
. - BaseAliasesRequestBuilder<Response extends ActionResponse,
Builder extends BaseAliasesRequestBuilder<Response, Builder>> - Class in org.elasticsearch.action.admin.indices.alias.get - BaseAliasesRequestBuilder(ElasticsearchClient, ActionType<Response>, String...) - Constructor for class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
- BaseFuture<V> - Class in org.elasticsearch.common.util.concurrent
- BaseFuture() - Constructor for class org.elasticsearch.common.util.concurrent.BaseFuture
- BaseGatewayShardAllocator - Class in org.elasticsearch.gateway
-
An abstract class that implements basic functionality for allocating shards to nodes based on shard copies that already exist in the cluster.
- BaseGatewayShardAllocator() - Constructor for class org.elasticsearch.gateway.BaseGatewayShardAllocator
- BaseKeyStoreCommand - Class in org.elasticsearch.common.settings
- BaseKeyStoreCommand(String, boolean) - Constructor for class org.elasticsearch.common.settings.BaseKeyStoreCommand
- BaseNodeRequest - Class in org.elasticsearch.action.support.nodes
- BaseNodeRequest() - Constructor for class org.elasticsearch.action.support.nodes.BaseNodeRequest
- BaseNodeRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodeRequest
- BaseNodeResponse - Class in org.elasticsearch.action.support.nodes
-
A base class for node level operations.
- BaseNodeResponse(DiscoveryNode) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodeResponse
- BaseNodeResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodeResponse
-
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
- BaseNodesRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodesRequest
- BaseNodesResponse<TNodeResponse extends BaseNodeResponse> - Class in org.elasticsearch.action.support.nodes
- BaseNodesResponse(ClusterName, List<TNodeResponse>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodesResponse
- BaseNodesResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.nodes.BaseNodesResponse
- basePath() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Returns base path of the repository
- basePath() - Method in class org.elasticsearch.repositories.fs.FsRepository
- BasePrimaryAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
Abstract base class for allocating an unassigned primary shard to a node
- BasePrimaryAllocationCommand(String, int, String, boolean) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
- BasePrimaryAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
-
Read from a stream.
- BasePrimaryAllocationCommand.Builder<T extends BasePrimaryAllocationCommand> - Class in org.elasticsearch.cluster.routing.allocation.command
- BaseRestHandler - Class in org.elasticsearch.rest
-
Base handler for REST requests.
- BaseRestHandler() - Constructor for class org.elasticsearch.rest.BaseRestHandler
- BaseRestHandler.RestChannelConsumer - Interface in org.elasticsearch.rest
-
REST requests are handled by preparing a channel consumer that represents the execution of the request against a channel.
- BaseRestHandler.Wrapper - Class in org.elasticsearch.rest
- BaseTasksRequest<Request extends BaseTasksRequest<Request>> - Class in org.elasticsearch.action.support.tasks
-
A base class for task requests
- BaseTasksRequest() - Constructor for class org.elasticsearch.action.support.tasks.BaseTasksRequest
- BaseTasksRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.tasks.BaseTasksRequest
- BaseTasksResponse - Class in org.elasticsearch.action.support.tasks
-
Base class for responses of task-related operations
- BaseTasksResponse(List<TaskOperationFailure>, List<? extends ElasticsearchException>) - Constructor for class org.elasticsearch.action.support.tasks.BaseTasksResponse
- BaseTasksResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.tasks.BaseTasksResponse
- BaseTermQueryBuilder<QB extends BaseTermQueryBuilder<QB>> - Class in org.elasticsearch.index.query
- BaseTermQueryBuilder(String, boolean) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(String, double) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(String, float) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(String, long) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Constructs a new base term query.
- BaseTermQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Read from a stream.
- BaseTranslogReader - Class in org.elasticsearch.index.translog
-
A base class for all classes that allows reading ops from translog files
- BaseTranslogReader(long, FileChannel, Path, TranslogHeader) - Constructor for class org.elasticsearch.index.translog.BaseTranslogReader
- basic() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Gets a new
SnapshotInfo
instance from the givenSnapshotInfo
with all information stripped out except the snapshot id, state, and indices. - Basic(Priority, TimeValue) - Constructor for class org.elasticsearch.cluster.ClusterStateTaskConfig.Basic
- BASIC_DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_ORDINAL_DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_ORDINAL_DATE_TIME - 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.FormatNames
- BASIC_T_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_T_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_WEEK_DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- BASIC_WEEK_DATE_TIME - 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.FormatNames
- basicDate() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a full date as four digit year, two digit month of year, and two digit day of month (yyyyMMdd).
- basicDateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter that combines a basic date and time, separated by a 'T' (yyyyMMdd'T'HHmmss.SSSZ).
- basicDateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter that combines a basic date and time without millis, separated by a 'T' (yyyyMMdd'T'HHmmssZ).
- BasicHit(String, String, String, long) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- basicOrdinalDate() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date, using a four digit year and three digit dayOfYear (yyyyDDD).
- basicOrdinalDateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date and time, using a four digit year and three digit dayOfYear (yyyyDDD'T'HHmmss.SSSZ).
- basicOrdinalDateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date and time without millis, using a four digit year and three digit dayOfYear (yyyyDDD'T'HHmmssZ).
- BasicReplicationRequest - Class in org.elasticsearch.action.support.replication
-
A replication request that has no more information than ReplicationRequest.
- BasicReplicationRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.replication.BasicReplicationRequest
- BasicReplicationRequest(ShardId) - Constructor for class org.elasticsearch.action.support.replication.BasicReplicationRequest
-
Creates a new request with resolved shard id
- basicTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, three digit millis, and time zone offset (HHmmss.SSSZ).
- basicTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and time zone offset (HHmmssZ).
- basicTTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, three digit millis, and time zone offset prefixed by 'T' ('T'HHmmss.SSSZ).
- basicTTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and time zone offset prefixed by 'T' ('T'HHmmssZ).
- basicWeekDate() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter for a full date as four digit weekyear, two digit week of weekyear, and one digit day of week (xxxx'W'wwe).
- basicWeekDateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter that combines a basic weekyear date and time, separated by a 'T' (xxxx'W'wwe'T'HHmmss.SSSZ).
- basicWeekDateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a basic formatter that combines a basic weekyear date and time without millis, separated by a 'T' (xxxx'W'wwe'T'HHmmssZ).
- BatchedRerouteService - Class in org.elasticsearch.cluster.routing
-
A
BatchedRerouteService
is aRerouteService
that batches together reroute requests to avoid unnecessary extra reroutes. - BatchedRerouteService(ClusterService, BiFunction<ClusterState, String, ClusterState>) - Constructor for class org.elasticsearch.cluster.routing.BatchedRerouteService
- BatchedTask(Priority, String, Object, Object) - Constructor for class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
- BATCHES_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- batchingKey - Variable in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
-
the object that is used as batching key
- bdd - Variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- becomeMasterAndTrimConflictingNodes(ClusterState, List<JoinTaskExecutor.Task>) - Method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor
- before(Version) - Method in class org.elasticsearch.Version
- 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
- beforeExecute(Thread, Runnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- 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) - 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.
- 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.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
- 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
- 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. - beta(double) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel.HoltLinearModelBuilder
-
Equivalent to
alpha
, but controls the smoothing of the trend instead of the data - beta(double) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
-
Equivalent to
alpha
, but controls the smoothing of the trend instead of the data - 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
- BG_COUNT - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- BigArray - Interface in org.elasticsearch.common.util
-
Base abstraction of an array.
- bigArrays - Variable in class org.elasticsearch.common.io.stream.BytesStreamOutput
- bigArrays - Variable in class org.elasticsearch.http.AbstractHttpServerTransport
- bigArrays - 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.AggregatorBase
-
Utilities for sharing large primitive arrays and tracking their usage.
- bigArrays() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
- 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 - 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
- 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
- BINARY - Enum constant in enum class org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- BINARY - Static variable in interface org.elasticsearch.search.DocValueFormat
- BinaryDocValuesRangeQuery - Class in org.apache.lucene.queries
- BinaryDocValuesRangeQuery(String, BinaryDocValuesRangeQuery.QueryType, RangeType.LengthType, BytesRef, BytesRef, Object, Object) - Constructor for class org.apache.lucene.queries.BinaryDocValuesRangeQuery
- BinaryDocValuesRangeQuery.QueryType - Enum Class in org.apache.lucene.queries
- 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
- binaryField(FieldInfo, BytesRef) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- BinaryFieldMapper - Class in org.elasticsearch.index.mapper
- BinaryFieldMapper(String, MappedFieldType, FieldMapper.MultiFields, FieldMapper.CopyTo, 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
- BinaryRange - Class in org.apache.lucene.document
-
A range field for binary encoded ranges
- BinaryRange(String, byte[]) - Constructor for class org.apache.lucene.document.BinaryRange
-
Create a new BinaryRange from a provided encoded binary range
- BinaryRangeAggregator - Class in org.elasticsearch.search.aggregations.bucket.range
-
A range aggregator for values that are stored in SORTED_SET doc values.
- BinaryRangeAggregator(String, AggregatorFactories, ValuesSource, 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
- binaryValue() - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.CustomBinaryDocValuesField
- bind(Class<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- bind(Class<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
See the EDSL examples at
Binder
. - bind(Class<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- bind(String, InetSocketAddress) - Method in class org.elasticsearch.transport.TcpTransport
-
Binds to the given
InetSocketAddress
- bind(InetSocketAddress) - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- bind(Key<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- bind(Key<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
See the EDSL examples at
Binder
. - bind(Key<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- bind(TypeLiteral<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- bind(TypeLiteral<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
See the EDSL examples at
Binder
. - bind(TypeLiteral<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- BIND_HOST - Static variable in class org.elasticsearch.transport.TransportSettings
- BIND_HOST_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- bindConstant() - Method in class org.elasticsearch.common.inject.AbstractModule
- bindConstant() - Method in interface org.elasticsearch.common.inject.Binder
-
See the EDSL examples at
Binder
. - binder - Variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- binder() - Method in class org.elasticsearch.common.inject.AbstractModule
-
Gets direct access to the underlying
Binder
. - binder() - Method in class org.elasticsearch.common.inject.PrivateModule
-
Returns the current binder.
- Binder - Interface in org.elasticsearch.common.inject
-
Collects configuration information (primarily bindings) which will be used to create an
Injector
. - bindHosts - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- BindHttpException - Exception in org.elasticsearch.http
- BindHttpException(String) - Constructor for exception org.elasticsearch.http.BindHttpException
- BindHttpException(String, Throwable) - Constructor for exception org.elasticsearch.http.BindHttpException
- BindHttpException(StreamInput) - Constructor for exception org.elasticsearch.http.BindHttpException
- Binding<T> - Interface in org.elasticsearch.common.inject
-
A mapping from a key (type and optional annotation) to the strategy for getting instances of the type.
- BINDING_TO_NULL - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- bindingAlreadySet(Key<?>, Object) - Method in class org.elasticsearch.common.inject.internal.Errors
- BindingAnnotation - Annotation Interface in org.elasticsearch.common.inject
-
Annotates annotations which are used for binding.
- BindingBuilder<T> - Class in org.elasticsearch.common.inject.internal
-
Bind a non-constant key.
- BindingBuilder(Binder, List<Element>, Object, Key<T>) - Constructor for class org.elasticsearch.common.inject.internal.BindingBuilder
- BindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- BindingImpl(Object, Key<T>, Scoping) - Constructor for class org.elasticsearch.common.inject.internal.BindingImpl
- BindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping) - Constructor for class org.elasticsearch.common.inject.internal.BindingImpl
- BindingScopingVisitor<V> - Interface in org.elasticsearch.common.inject.spi
-
Visits each of the strategies used to scope an injection.
- BindingTargetVisitor<T,
V> - Interface in org.elasticsearch.common.inject.spi -
Visits each of the strategies used to find an instance to satisfy an injection.
- bindingToProvider() - Method in class org.elasticsearch.common.inject.internal.Errors
- bindListener(Matcher<? super TypeLiteral<?>>, TypeListener) - Method in class org.elasticsearch.common.inject.AbstractModule
- bindListener(Matcher<? super TypeLiteral<?>>, TypeListener) - Method in interface org.elasticsearch.common.inject.Binder
-
Registers a listener for injectable types.
- bindProperties(Binder, Map<String, String>) - Static method in class org.elasticsearch.common.inject.name.Names
-
Creates a constant binding to
@Named(key)
for each entry inproperties
. - bindProperties(Binder, Properties) - Static method in class org.elasticsearch.common.inject.name.Names
-
Creates a constant binding to
@Named(key)
for each property. - bindScope(Class<? extends Annotation>, Scope) - Method in class org.elasticsearch.common.inject.AbstractModule
- bindScope(Class<? extends Annotation>, Scope) - Method in interface org.elasticsearch.common.inject.Binder
-
Binds a scope to an annotation.
- bindServer() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- bindServer(TcpTransport.ProfileSettings) - Method in class org.elasticsearch.transport.TcpTransport
- BindTransportException - Exception in org.elasticsearch.transport
- BindTransportException(String) - Constructor for exception org.elasticsearch.transport.BindTransportException
- BindTransportException(String, Throwable) - Constructor for exception org.elasticsearch.transport.BindTransportException
- BindTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.BindTransportException
- binFile() - Method in class org.elasticsearch.env.Environment
- BitArray - Class in org.elasticsearch.common.util
- BitArray(long, BigArrays) - Constructor for class org.elasticsearch.common.util.BitArray
-
Create the BitArray.
- 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 - Class in org.elasticsearch.index.cache.bitset
-
This is a cache for
BitDocIdSet
based filters and is unbounded by size or time. - BitsetFilterCache(IndexSettings, BitsetFilterCache.Listener) - Constructor for class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- BitsetFilterCache.Listener - Interface in org.elasticsearch.index.cache.bitset
-
A listener interface that is executed for each onCache / onRemoval event
- BitsetFilterCache.Value - Class in org.elasticsearch.index.cache.bitset
- bitsetFromQuery(Query, LeafReaderContext) - Static method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- blend(TermStates[], int, IndexReader) - Method in class org.apache.lucene.queries.BlendedTermQuery
- BlendedTermQuery - Class in org.apache.lucene.queries
-
BlendedTermQuery can be used to unify term statistics across one or more fields in the index.
- BlendedTermQuery(Term[], float[]) - Constructor for class org.apache.lucene.queries.BlendedTermQuery
- blobContainer() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
maintains single lazy instance of
BlobContainer
- blobContainer(BlobPath) - Method in interface org.elasticsearch.common.blobstore.BlobStore
-
Get a blob container instance for storing blobs at the given
BlobPath
. - blobContainer(BlobPath) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
- BlobContainer - Interface in org.elasticsearch.common.blobstore
-
An interface for managing a repository of blob entries, where each blob entry is just a named group of bytes.
- blobExists(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Tests whether a blob with the given blob name exists in the container.
- blobExists(String) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- blobExists(String) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- BlobMetadata - Interface in org.elasticsearch.common.blobstore
-
An interface for providing basic metadata about a blob.
- blobName(String) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- BlobPath - Class in org.elasticsearch.common.blobstore
-
The list of paths where a blob can reside.
- blobs() - Method in class org.elasticsearch.repositories.RepositoryCleanupResult
- blobsDeleted() - Method in class org.elasticsearch.common.blobstore.DeleteResult
- blobStore - Variable in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- blobStore() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Maintains single lazy instance of
BlobStore
. - BlobStore - Interface in org.elasticsearch.common.blobstore
-
An interface for storing blobs.
- BlobStoreException - Exception in org.elasticsearch.common.blobstore
- BlobStoreException(String) - Constructor for exception org.elasticsearch.common.blobstore.BlobStoreException
- BlobStoreException(String, Throwable) - Constructor for exception org.elasticsearch.common.blobstore.BlobStoreException
- BlobStoreException(StreamInput) - Constructor for exception org.elasticsearch.common.blobstore.BlobStoreException
- BlobStoreIndexShardSnapshot - Class in org.elasticsearch.index.snapshots.blobstore
-
Shard snapshot metadata
- BlobStoreIndexShardSnapshot(String, long, List<BlobStoreIndexShardSnapshot.FileInfo>, long, long, int, long) - Constructor for class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Constructs new shard snapshot metadata from snapshot metadata
- BlobStoreIndexShardSnapshot.FileInfo - Class in org.elasticsearch.index.snapshots.blobstore
-
Information about snapshotted file
- BlobStoreIndexShardSnapshots - Class in org.elasticsearch.index.snapshots.blobstore
-
Contains information about all snapshots for the given shard in repository
- BlobStoreIndexShardSnapshots(List<SnapshotFiles>) - Constructor for class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
- BlobStoreRepository - Class in org.elasticsearch.repositories.blobstore
-
BlobStore - based implementation of Snapshot Repository
- BlobStoreRepository(RepositoryMetadata, boolean, NamedXContentRegistry, ClusterService, BigArrays, RecoverySettings) - Constructor for class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Constructs new BlobStoreRepository
- BLOCK - Enum constant in enum class org.elasticsearch.monitor.jvm.HotThreads.ReportType
- blockingAllowed() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
- BlockingClusterStatePublishResponseHandler - Class in org.elasticsearch.discovery
-
Handles responses obtained when publishing a new cluster state from master to all non master nodes.
- BlockingClusterStatePublishResponseHandler(Set<DiscoveryNode>) - Constructor for class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
Creates a new BlockingClusterStatePublishResponseHandler
- blockOnFutures(List<ActionFuture<Void>>) - Static method in interface org.elasticsearch.common.network.CloseableChannel
- blocks() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- blocks() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- blocks() - Method in exception org.elasticsearch.cluster.block.ClusterBlockException
- blocks() - Method in class org.elasticsearch.cluster.ClusterState
- blocks(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- blocks(ClusterBlocks) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- blocks(ClusterBlocks) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- blocks(ClusterBlocks.Builder) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- BLOCKS - 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. - 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.search.aggregations.support.CoreValuesSourceType
- BOOLEAN - Enum constant in enum class org.elasticsearch.search.aggregations.support.ValueType
- 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.
- BooleanFieldMapper - Class in org.elasticsearch.index.mapper
-
A field mapper for boolean fields.
- BooleanFieldMapper(String, MappedFieldType, FieldMapper.MultiFields, FieldMapper.CopyTo, 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.Defaults - 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, 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, boolean, Boolean, FieldValues<Boolean>, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- Booleans(SortedNumericDocValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- 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
- 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
- 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
- boolSetting(String, Setting<Boolean>, Setting.Validator<Boolean>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- boost - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- boost - Variable in class org.elasticsearch.index.query.AbstractQueryBuilder
- boost - Variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- boost() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- boost() - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Returns the boost for this query.
- boost() - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Returns the boost for this query.
- boost() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- boost(float) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Sets the boost for this query.
- boost(float) - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Sets the boost for this query.
- boost(float) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- BOOST_FIELD - Static variable in class org.elasticsearch.index.query.AbstractQueryBuilder
- BOOST_MODE_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- boostingQuery(QueryBuilder, QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
The BoostingQuery class can be used to effectively demote results that match a given query.
- BoostingQueryBuilder - Class in org.elasticsearch.index.query
-
The BoostingQuery class can be used to effectively demote results that match a given query.
- BoostingQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.BoostingQueryBuilder
-
Read from a stream.
- BoostingQueryBuilder(QueryBuilder, QueryBuilder) - Constructor for class org.elasticsearch.index.query.BoostingQueryBuilder
-
Create a new
BoostingQueryBuilder
- boostMode() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Returns the boost mode, meaning how the combined result of score functions will influence the final score together with the sub query score.
- boostMode(CombineFunction) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Boost mode defines how the combined result of score functions will influence the final score together with the sub query score.
- boostParam() - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- 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 - Enum constant in enum class org.elasticsearch.plugins.PluginType
- BootstrapCheck - Interface in org.elasticsearch.bootstrap
-
Encapsulates a bootstrap check.
- BootstrapCheck.BootstrapCheckResult - Class in org.elasticsearch.bootstrap
-
Encapsulate the result of a bootstrap check.
- BootstrapContext - Class in org.elasticsearch.bootstrap
-
Context that is passed to every bootstrap check to make decisions on.
- BootstrapContext(Environment, Metadata) - Constructor for class org.elasticsearch.bootstrap.BootstrapContext
- BootstrapInfo - Class in org.elasticsearch.bootstrap
-
Exposes system startup information
- bootstrapNewHistory() - Method in class org.elasticsearch.index.store.Store
-
Marks an existing lucene index with a new history uuid.
- bootstrapNewHistory(long, long) - Method in class org.elasticsearch.index.store.Store
-
Marks an existing lucene index with a new history uuid and sets the given local checkpoint as well as the maximum sequence number.
- BootstrapSettings - Class in org.elasticsearch.bootstrap
- bottom - Variable in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- bottom() - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- 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.GeoBoundingBox
- 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 interface org.elasticsearch.search.aggregations.metrics.GeoBounds
-
Get the bottom-right location of the bounding box.
- bottomRight() - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- bottomRight() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedGeoBounds
- boundAddress() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- boundAddress() - Method in interface org.elasticsearch.http.HttpServerTransport
- boundAddress() - Method in class org.elasticsearch.transport.TcpTransport
- boundAddress() - Method in interface org.elasticsearch.transport.Transport
-
The address the transport is bound on.
- boundAddress() - Method in class org.elasticsearch.transport.TransportService
- boundAddresses() - Method in class org.elasticsearch.common.transport.BoundTransportAddress
- BOUNDARY_CHARS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- BOUNDARY_MAX_SCAN_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- BOUNDARY_SCANNER_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- BOUNDARY_SCANNER_LOCALE_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryChars - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryChars() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- boundaryChars() - Method in class org.elasticsearch.search.fetch.subphase.highlight.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.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.apache.lucene.search.uhighlight
-
A custom break iterator that is used to find break-delimited passages bounded by a provided maximum length in the
UnifiedHighlighter
context. - BOUNDS_FIELD - Static variable in class org.elasticsearch.common.geo.GeoBoundingBox
- 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 - 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
- breakdowns - Variable in class org.elasticsearch.search.profile.AbstractInternalProfileTree
- 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.NodesStatsRequest.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 BroadcastResponse, RequestBuilder extends BroadcastOperationRequestBuilder<Request, Response, RequestBuilder>> - Class in org.elasticsearch.action.support.broadcast - BroadcastOperationRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastOperationRequestBuilder
- BroadcastRequest<Request extends BroadcastRequest<Request>> - Class in org.elasticsearch.action.support.broadcast
- BroadcastRequest(String...) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastRequest
- BroadcastRequest(String[], IndicesOptions) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastRequest
- BroadcastRequest(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
-
Base class for all broadcast operation based responses.
- BroadcastResponse() - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastResponse
- BroadcastResponse(int, int, int, List<DefaultShardOperationFailedException>) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastResponse
- BroadcastResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastResponse
- BroadcastShardOperationFailedException - Exception in org.elasticsearch.action.support.broadcast
-
An exception indicating that a failure occurred performing an operation on the shard.
- BroadcastShardOperationFailedException(StreamInput) - Constructor for exception org.elasticsearch.action.support.broadcast.BroadcastShardOperationFailedException
- BroadcastShardOperationFailedException(ShardId, String) - Constructor for exception org.elasticsearch.action.support.broadcast.BroadcastShardOperationFailedException
- BroadcastShardOperationFailedException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.action.support.broadcast.BroadcastShardOperationFailedException
- BroadcastShardOperationFailedException(ShardId, Throwable) - Constructor for exception org.elasticsearch.action.support.broadcast.BroadcastShardOperationFailedException
- BroadcastShardRequest - Class in org.elasticsearch.action.support.broadcast
- BroadcastShardRequest() - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- BroadcastShardRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- BroadcastShardRequest(ShardId, OriginalIndices) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- BroadcastShardRequest(ShardId, BroadcastRequest<? extends BroadcastRequest<?>>) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- BroadcastShardResponse - Class in org.elasticsearch.action.support.broadcast
- BroadcastShardResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardResponse
- BroadcastShardResponse(ShardId) - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastShardResponse
- Bucket(double, long, boolean, DocValueFormat, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- Bucket(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, long, DocValueFormat, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- Bucket(long, InternalAggregations, boolean, long, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- Bucket(long, InternalAggregations, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- Bucket(String, double, double, long, List<InternalAggregation>, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Bucket
- Bucket(String, double, double, long, InternalAggregations, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Bucket
- Bucket(String, double, double, long, InternalAggregations, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- Bucket(BytesRef, long, long, long, long, InternalAggregations, 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, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
-
Read from a stream.
- Bucket(StreamInput, boolean, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
-
Read from a stream.
- Bucket(StreamInput, long, long, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.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.histogram.InternalAutoDateHistogram.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
-
Read from a stream.
- Bucket(StreamInput, DocValueFormat, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
-
Read from a stream.
- Bucket(DocValueFormat, boolean, String, BytesRef, BytesRef, long, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- 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.adjacency.AdjacencyMatrixAggregationBuilder
- bucketCardinality() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- 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.AutoDateHistogramAggregationBuilder
- 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.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.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.GeoBoundsAggregationBuilder
- 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 - Class in org.elasticsearch.search.aggregations
-
A Collector that can collect data in separate buckets.
- BucketCollector() - Constructor for class org.elasticsearch.search.aggregations.BucketCollector
- bucketComparator(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(TermsAggregator.BucketCountThresholds) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- bucketCountThresholds(TermsAggregator.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
- 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.InternalMappedRareTerms
- 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, Comparator<? super B>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.BucketPriorityQueue
- buckets - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- buckets - Variable in class org.elasticsearch.search.aggregations.bucket.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 - Variable in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation
- BUCKETS - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- BUCKETS_PATH - Static variable in interface org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.Parser
- BUCKETS_PATH_FIELD - Static variable in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
-
Field shared by many parsers.
- BucketsAggregator - Class in org.elasticsearch.search.aggregations.bucket
- BucketsAggregator(String, AggregatorFactories, 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
- BucketScriptPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregator
-
Read from a stream.
- bucketSelector(String, Map<String, String>, Script) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- bucketSelector(String, Script, String...) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- BucketSelectorPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- BucketSelectorPipelineAggregationBuilder(String, Map<String, String>, Script) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- BucketSelectorPipelineAggregationBuilder(String, Script, String...) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- BucketSelectorPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
-
Read from a stream.
- BucketSelectorPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- BucketSelectorPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregator
-
Read from a stream.
- BucketSignificancePriorityQueue<B extends SignificantTerms.Bucket> - Class in org.elasticsearch.search.aggregations.bucket.terms
- BucketSignificancePriorityQueue(int) - 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.
- bucketSort(String, List<FieldSortBuilder>) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- BucketSortPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
-
Builds a pipeline aggregation that allows sorting the buckets of its parent aggregation.
- BucketSortPipelineAggregationBuilder(String, List<FieldSortBuilder>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- BucketSortPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
-
Read from a stream.
- BucketSortPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- BucketSortPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregator
-
Read from a stream.
- bucketsPaths - Variable in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
- bucketsPaths() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- bucketToXContent(CompositeAggregation.Bucket, XContentBuilder, ToXContent.Params) - Static method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation
- BucketUtils - Class in org.elasticsearch.search.aggregations.bucket
-
Helper functions for common Bucketing functions
- buffer - Variable in class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
-
Current write buffer.
- 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.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.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.IndexGraveyard.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- build() - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Builder
- build() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- build() - Method in class org.elasticsearch.cluster.RestoreInProgress.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand.Builder
- build() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- build() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- build() - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
Builds the routing table.
- build() - Method in class org.elasticsearch.common.cache.CacheBuilder
- build() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
Builds a new instance of the
- build() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
Builds a new instance of the
- build() - Method in class org.elasticsearch.common.logging.ESJsonLayout.Builder
- build() - Method in interface org.elasticsearch.common.recycler.Recycler.Factory
- build() - Method in class org.elasticsearch.common.Rounding.Builder
- build() - Method in class org.elasticsearch.common.rounding.Rounding.Builder
-
Deprecated.
- build() - Method in class org.elasticsearch.common.settings.Settings.Builder
- build() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Builds an
Ordinals
instance from the builders current state. - build() - Method in class org.elasticsearch.index.mapper.AllFieldMapper.Builder
- build() - Method in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper.Builder
- build() - Method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo.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.indices.SystemIndexDescriptor.Builder
-
Builds a
SystemIndexDescriptor
using the fields supplied to this 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.pipeline.EwmaModel.EWMAModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel.HoltLinearModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel.LinearModelBuilder
- build() - Method in interface org.elasticsearch.search.aggregations.pipeline.MovAvgModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel.SimpleModelBuilder
- build() - Method in class org.elasticsearch.search.aggregations.support.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.snapshots.SnapshotInfo.SnapshotInfoBuilder
- 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(boolean, boolean, boolean, boolean) - Method in interface org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.ParserBuilder
- build(int, long, InternalAggregations) - Method in interface org.elasticsearch.search.aggregations.bucket.BucketsAggregator.BucketBuilderForFixedCount
- build(int, BucketOrder, Consumer<DelayedBucket<B>>) - 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(Object) - Static method in class org.elasticsearch.common.unit.Fuzziness
- 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, int, AutoDateHistogramAggregationBuilder.RoundingInfo[], ValuesSourceConfig, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregatorSupplier
- build(String, AggregatorFactories, List<QueryToFilterAdapter<?>>, boolean, String, 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, LongBounds, LongBounds, ValuesSourceConfig, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationSupplier
- 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, AggregationContext, Aggregator, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.CardinalityAggregatorSupplier
- 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, ValuesSource, AggregationContext, Aggregator, double[], PercentilesConfig, boolean, DocValueFormat, Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.metrics.PercentilesAggregatorSupplier
- build(String, ValuesSource, DocValueFormat, AggregationContext, Aggregator, Map<String, Object>, double) - 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(IndexReader, IndexOrdinalsFieldData, CircuitBreakerService, Logger, Function<SortedSetDocValues, ScriptDocValues<?>>) - 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(ClusterState) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult.Builder
- build(ClusterState) - Static method in class org.elasticsearch.cluster.MasterNodeChangePredicate
-
builds a predicate that will accept a cluster state only if it was generated after the current has (re-)joined the master
- build(Priority) - Static method in interface org.elasticsearch.cluster.ClusterStateTaskConfig
-
Build a cluster state update task configuration with the specified
Priority
and no timeout. - build(Priority, TimeValue) - Static method in interface org.elasticsearch.cluster.ClusterStateTaskConfig
-
Build a cluster state update task configuration with the specified
Priority
and timeout. - build(Settings) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
- build(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(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.AbstractLatLonPointIndexFieldData.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.PagedBytesIndexFieldData.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.SortedSetOrdinalsIndexFieldData.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(IndexSettings) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
-
Creates an index-level
IndexAnalyzers
from this registry using the given index settings - build(IndexSettings, Map<String, AnalyzerProvider<?>>, Map<String, AnalyzerProvider<?>>, Map<String, TokenizerFactory>, Map<String, CharFilterFactory>, Map<String, TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
- build(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.GeoShapeFieldMapper.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.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(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 - Class in org.elasticsearch
-
Information about a build of Elasticsearch.
- Build(Build.Flavor, Build.Type, String, String, boolean, String) - Constructor for class org.elasticsearch.Build
- 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.Flavor - Enum Class in org.elasticsearch
- 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.SumAggregator
- buildAggregation(long) - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregator
- 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(long[]) - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Build the results of this aggregation.
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTermsAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.terms.NumericTermsAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTermsAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.metrics.MetricsAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.aggregations.NonCollectingAggregator
- buildAggregations(long[]) - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- buildAggregationsForFixedBucketCount(long[], 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(long[], BucketsAggregator.SingleBucketResultBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Build aggregation results for an aggregator that always contain a single bucket.
- buildAggregationsForVariableBuckets(long[], 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.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, BroadcastResponse) - 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(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(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
- buildEmpty(IndexReader, IndexOrdinalsFieldData) - 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.adjacency.AdjacencyMatrixAggregator
- 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.FilterAggregator
- 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.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.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.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.cluster.block.ClusterBlocks
- builder() - Static method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult
- builder() - Static method in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- builder() - Static method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- 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.node.DiscoveryNodes
- 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.ImmutableOpenIntMap
- 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() - 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(int) - Static method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- 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(BiConsumer<BulkRequest, ActionListener<BulkResponse>>, BulkProcessor.Listener) - Static method in class org.elasticsearch.action.bulk.BulkProcessor
-
Deprecated.
- 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(Client, BulkProcessor.Listener) - Static method in class org.elasticsearch.action.bulk.BulkProcessor
-
Deprecated.Use
BulkProcessor.builder(BiConsumer, Listener, String)
with client::bulk as the first argument, orBulkProcessor.builder(org.elasticsearch.client.Client, org.elasticsearch.action.bulk.BulkProcessor.Listener, org.elasticsearch.threadpool.Scheduler, org.elasticsearch.threadpool.Scheduler, java.lang.Runnable)
and manage the flush and retry schedulers explicitly - builder(Client, BulkProcessor.Listener, Scheduler, Scheduler, Runnable) - Static method in class org.elasticsearch.action.bulk.BulkProcessor
- 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(Metadata) - Static method in class org.elasticsearch.cluster.metadata.Metadata
- builder(SingleNodeShutdownMetadata) - Static method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- builder(DiscoveryNodes) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes
- builder(RoutingTable) - Static method in class org.elasticsearch.cluster.routing.RoutingTable
- builder(ImmutableOpenIntMap<VType>) - Static method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- builder(ImmutableOpenMap<KType, VType>) - Static method in class org.elasticsearch.common.collect.ImmutableOpenMap
- builder(DateTimeUnit) - Static method in class org.elasticsearch.common.rounding.Rounding
-
Deprecated.
- builder(Rounding.DateTimeUnit) - Static method in class org.elasticsearch.common.Rounding
- builder(TimeValue) - Static method in class org.elasticsearch.common.Rounding
- builder(TimeValue) - Static method in class org.elasticsearch.common.rounding.Rounding
-
Deprecated.
- builder(Index) - Static method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- 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 class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup
- 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.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.ClusterStateTaskExecutor.ClusterTasksResult.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.coordination.CoordinationMetadata.Builder
- Builder() - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.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.RoutingTable.Builder
- Builder() - Constructor for class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- Builder() - Constructor for class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- Builder() - Constructor for class org.elasticsearch.common.logging.ESJsonLayout.Builder
- Builder() - Constructor for class org.elasticsearch.index.mapper.AllFieldMapper.Builder
- Builder() - Constructor for class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper.Builder
- Builder() - Constructor for class org.elasticsearch.index.mapper.FieldMapper.CopyTo.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.SourceFieldMapper.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.transport.ConnectionProfile.Builder
-
create an empty builder
- Builder(int) - Constructor for class org.elasticsearch.common.collect.ImmutableOpenIntMap.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.index.mapper.BinaryFieldMapper.Builder
- 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.KeywordFieldMapper.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.ObjectMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- Builder(String) - Constructor for class org.elasticsearch.index.mapper.RuntimeField.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, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.GeoShapeFieldMapper.Builder
- Builder(String, double, double, int, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.Builder
- Builder(String, String, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData.Builder
- Builder(String, Function<SortedSetDocValues, ScriptDocValues<?>>, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData.Builder
- Builder(String, IndexAnalyzers) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- Builder(String, IndexAnalyzers, ScriptCompiler) - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- Builder(String, NamedAnalyzer, Version) - Constructor for class org.elasticsearch.index.mapper.CompletionFieldMapper.Builder
- Builder(String, IndexNumericFieldData.NumericType) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData.Builder
- Builder(String, DateFieldMapper.Resolution, DateFormatter, ScriptCompiler, boolean, Version) - Constructor for class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- Builder(String, NumberFieldMapper.NumberType, ScriptCompiler, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- Builder(String, NumberFieldMapper.NumberType, ScriptCompiler, Settings) - Constructor for class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- Builder(String, RangeType, boolean, Version) - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- Builder(String, BooleanFieldScript.LeafFactory) - Constructor for class org.elasticsearch.index.fielddata.BooleanScriptFieldData.Builder
- Builder(String, DateFieldScript.LeafFactory) - Constructor for class org.elasticsearch.index.fielddata.DateScriptFieldData.Builder
- Builder(String, DoubleFieldScript.LeafFactory) - Constructor for class org.elasticsearch.index.fielddata.DoubleScriptFieldData.Builder
- Builder(String, GeoPointFieldScript.LeafFactory) - Constructor for class org.elasticsearch.index.fielddata.GeoPointScriptFieldData.Builder
- Builder(String, IpFieldScript.LeafFactory) - Constructor for class org.elasticsearch.index.fielddata.IpScriptFieldData.Builder
- Builder(String, LongFieldScript.LeafFactory) - Constructor for class org.elasticsearch.index.fielddata.LongScriptFieldData.Builder
- Builder(String, ScriptCompiler) - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.Builder
- Builder(String, ScriptCompiler, boolean) - Constructor for class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- Builder(String, ScriptCompiler, boolean, Version) - Constructor for class org.elasticsearch.index.mapper.IpFieldMapper.Builder
- Builder(String, StringFieldScript.LeafFactory) - Constructor for class org.elasticsearch.index.fielddata.StringScriptFieldData.Builder
- Builder(String, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointIndexFieldData.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) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData.Builder
- Builder(String, Version) - Constructor for class org.elasticsearch.index.mapper.NestedObjectMapper.Builder
- Builder(String, Version, IndexAnalyzers) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.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(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(ImmutableOpenIntMap<VType>) - Constructor for class org.elasticsearch.common.collect.ImmutableOpenIntMap.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(DateTimeUnit) - Constructor for class org.elasticsearch.common.rounding.Rounding.Builder
-
Deprecated.
- Builder(Rounding.DateTimeUnit) - Constructor for class org.elasticsearch.common.Rounding.Builder
- Builder(TimeValue) - Constructor for class org.elasticsearch.common.Rounding.Builder
- Builder(TimeValue) - Constructor for class org.elasticsearch.common.rounding.Rounding.Builder
-
Deprecated.
- Builder(Index) - Constructor for class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- Builder(ShardId) - Constructor for class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- Builder(ScriptMetadata) - Constructor for class org.elasticsearch.script.ScriptMetadata.Builder
- Builder(ConnectionProfile) - Constructor for class org.elasticsearch.transport.ConnectionProfile.Builder
-
copy constructor, using another profile as a base
- builders() - Method in class org.elasticsearch.threadpool.ThreadPool
- 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
- 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
- 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. - buildFromKeyValue(DiscoveryNodeFilters.OpType, Map<String, 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.
- buildFromSimplifiedDef(String, Object...) - Static method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- buildFullName(String) - Method in class org.elasticsearch.index.mapper.MapperBuilderContext
-
Builds the full name of the field, taking into account parent objects
- buildHelpWidths(Table, RestRequest) - Static method in class org.elasticsearch.rest.action.cat.RestTable
- 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. - buildMappers(boolean, MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- buildNodeShardsResult(ShardRouting, boolean, Set<String>, Set<String>, AsyncShardFetch.FetchResult<TransportNodesListGatewayStartedShards.NodeGatewayStartedShards>, Logger) - Static method in class org.elasticsearch.gateway.PrimaryShardAllocator
-
Builds a list of nodes.
- 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
- buildQueryPhaseResults() - Method in class org.elasticsearch.search.profile.Profilers
-
Build the results for the query phase.
- 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.
- 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 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.RestStatusToXContentListener
- buildResponse(Response, XContentBuilder) - Method in class org.elasticsearch.rest.action.RestToXContentListener
- 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) - Static method in class org.elasticsearch.transport.ConnectionProfile
-
Builds a connection profile that is dedicated to a single channel type.
- 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(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(long[]) - 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.
- buildSubAggsForBuckets(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.
- 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
- 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. - 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
- BUILT_IN_ROLES - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
The built-in node roles.
- BUILT_IN_SETTING_UPGRADERS - Static variable in class org.elasticsearch.common.settings.ClusterSettings
- bulk(BulkRequest) - Method in interface org.elasticsearch.client.Client
-
Executes a bulk of index / delete operations.
- bulk(BulkRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- bulk(BulkRequest, ActionListener<BulkResponse>) - Method in interface org.elasticsearch.client.Client
-
Executes a bulk of index / delete operations.
- bulk(BulkRequest, ActionListener<BulkResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- BULK - Enum constant in enum class org.elasticsearch.transport.TransportRequestOptions.Type
- BulkAction - Class in org.elasticsearch.action.bulk
- 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.
- 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.
- 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() - Static method in class org.elasticsearch.client.Requests
-
Creates a new bulk request.
- BulkRequest - Class in org.elasticsearch.action.bulk
-
A bulk request holds an ordered
IndexRequest
s,DeleteRequest
s andUpdateRequest
s and allows to executes 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(String, String) - Constructor for class org.elasticsearch.action.bulk.BulkRequest
-
Deprecated.Types are in the process of being removed. Use
BulkRequest(String)
instead - 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, BulkAction) - Constructor for class org.elasticsearch.action.bulk.BulkRequestBuilder
- BulkRequestBuilder(ElasticsearchClient, BulkAction, String) - Constructor for class org.elasticsearch.action.bulk.BulkRequestBuilder
- BulkRequestBuilder(ElasticsearchClient, BulkAction, String, String) - Constructor for class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Deprecated.
- 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) - Constructor for class org.elasticsearch.action.bulk.BulkRequestParser
-
Create a new parser.
- 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(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
- BulkShardResponse - Class in org.elasticsearch.action.bulk
- BulkShardResponse(ShardId, BulkItemResponse[]) - Constructor for class org.elasticsearch.action.bulk.BulkShardResponse
- Bundle(PluginDescriptor, Path) - Constructor for class org.elasticsearch.plugins.PluginsService.Bundle
- busiestThreads(int) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- BWC_PING_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.DiscoveryUpgradeService
- BWC_UUID - Static variable in class org.elasticsearch.cluster.RestoreInProgress
-
Fallback UUID used for restore operations that were started before v6.6 and don't have a uuid in the cluster state.
- 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_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
- ByteBufferStreamInput - Class in org.elasticsearch.common.io.stream
- ByteBufferStreamInput(ByteBuffer) - Constructor for class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- bytePage(boolean) - Method in class org.elasticsearch.common.util.PageCacheRecycler
- bytes - Variable in class org.elasticsearch.common.io.stream.BytesStreamOutput
- bytes() - Method in class org.elasticsearch.common.bytes.RecyclingBytesStreamOutput
- 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.text.Text
-
Returns a
BytesReference
view of the data. - 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 - Enum constant in enum class org.elasticsearch.common.unit.ByteSizeUnit
- BYTES - Static variable in class org.apache.lucene.document.BinaryRange
-
The number of bytes per dimension, use
InetAddressPoint.BYTES
as max, because that is maximum we need to support - 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
- byteSizeSetting(String, Function<Settings, String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- byteSizeSetting(String, Function<Settings, String>, ByteSizeValue, ByteSizeValue, 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) - Constructor for class org.elasticsearch.common.unit.ByteSizeValue
- ByteSizeValue(long, ByteSizeUnit) - Constructor for class org.elasticsearch.common.unit.ByteSizeValue
- ByteSizeValue(StreamInput) - 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
- BytesReference - Interface in org.elasticsearch.common.bytes
-
A reference to bytes.
- 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
- BytesRefs - Class in org.elasticsearch.common.lucene
- BytesRefs() - Constructor for class org.elasticsearch.common.lucene.BytesRefs
- BytesRefs(SortedBinaryDocValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.BytesRefs
- BytesRestResponse - Class in org.elasticsearch.rest
- BytesRestResponse(RestChannel, Exception) - Constructor for class org.elasticsearch.rest.BytesRestResponse
- BytesRestResponse(RestChannel, RestStatus, Exception) - Constructor for class org.elasticsearch.rest.BytesRestResponse
- BytesRestResponse(RestStatus, String) - Constructor for class org.elasticsearch.rest.BytesRestResponse
-
Creates a new plain text response.
- BytesRestResponse(RestStatus, String, byte[]) - Constructor for class org.elasticsearch.rest.BytesRestResponse
-
Creates a binary response.
- BytesRestResponse(RestStatus, String, String) - Constructor for class org.elasticsearch.rest.BytesRestResponse
-
Creates a new plain text response.
- BytesRestResponse(RestStatus, String, BytesReference) - Constructor for class org.elasticsearch.rest.BytesRestResponse
-
Creates a binary response.
- BytesRestResponse(RestStatus, XContentBuilder) - Constructor for class org.elasticsearch.rest.BytesRestResponse
-
Creates a new response based on
XContentBuilder
. - 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
- 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) - Method in class org.elasticsearch.index.fielddata.IpScriptFieldData.IpScriptDocValues
- bytesToString(BytesRef) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Strings
-
Convert the stored bytes to a String.
- 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, Version) - 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.GeoHashCellIdSource
- bytesValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileCellIdSource
- 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.
C
- c - Variable in class org.elasticsearch.common.recycler.NoneRecycler
- c() - Method in class org.elasticsearch.common.lucene.RegExp
-
Character expression.
- 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. - CachedSupplier(Supplier<T>) - Constructor for class org.elasticsearch.common.util.CachedSupplier
- 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
- calcHighFreqMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
-
Deprecated.
- calcLowFreqMinimumNumberShouldMatch(int) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
-
Deprecated.
- calcMinimumNumberShouldMatch(String, int) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
-
Deprecated.
- 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)
- calculateDelayBound(long) - Method in class org.elasticsearch.action.support.RetryableAction
- calculateMinShouldMatch(int, String) - Static method in class org.elasticsearch.common.lucene.search.Queries
- calculateNumRoutingShards(int, Version) - 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
- calendarDivider(TimeUnit) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.SizedBucketAggregatorBuilder
- 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).
- calTargetShardsNum(int, int) - Static method in class org.elasticsearch.action.admin.indices.shrink.TransportResizeAction
- CAN_MATCH_SEARCH_SOURCE - Static variable in class org.elasticsearch.index.engine.Engine
- canAcceptNull() - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- canAddShardsToCluster(int, int, ClusterState, boolean) - Static method in class org.elasticsearch.indices.ShardLimitValidator
-
This method decides 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 if the shards are going on frozen nodes or the "cluster.max_shards_per_node" setting if the shards are going on normal nodes.
- 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.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.
- canBeMinimized() - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- canBeMinimized() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
- canBeMinimized() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- canBeMinimized() - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel
- canBeMinimized() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
-
Returns if the model can be cost minimized.
- canBeMinimized() - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel
- canCache(ShardSearchRequest, SearchContext) - 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.common.util.concurrent.BaseFuture
- 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
- 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.
- CANCELED_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- 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(T[]) - 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
- 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 interface org.elasticsearch.client.ClusterAdminClient
-
Cancel tasks
- cancelTasks(CancelTasksRequest, ActionListener<CancelTasksResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Cancel active tasks
- CancelTasksAction - Class in org.elasticsearch.action.admin.cluster.node.tasks.cancel
-
ActionType for cancelling running tasks
- cancelTasksRequest() - Static method in class org.elasticsearch.client.Requests
-
Creates a nodes tasks request against one or more nodes.
- 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, CancelTasksAction) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequestBuilder
- CancelTasksResponse - Class in org.elasticsearch.action.admin.cluster.node.tasks.cancel
-
Returns the list of tasks that were cancelled
- CancelTasksResponse(List<TaskInfo>, List<TaskOperationFailure>, List<? extends ElasticsearchException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksResponse
- CancelTasksResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksResponse
- 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.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.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
- canHighlight(MappedFieldType) - Method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- 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.
- canMatch(ShardSearchRequest, ActionListener<CanMatchShardResponse>) - Method in class org.elasticsearch.search.SearchService
- 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
- cannotBindToGuiceType(String) - Method in class org.elasticsearch.common.inject.internal.Errors
- cannotInjectInnerClass(Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
- cannotInjectRawMembersInjector() - Method in class org.elasticsearch.common.inject.internal.Errors
- cannotInjectRawProvider() - Method in class org.elasticsearch.common.inject.internal.Errors
- cannotInjectRawTypeLiteral() - Method in class org.elasticsearch.common.inject.internal.Errors
- cannotInjectTypeLiteralOf(Type) - Method in class org.elasticsearch.common.inject.internal.Errors
- cannotRebalance(Decision, AllocationDecision, int, List<NodeAllocationResult>) - Static method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Creates a move decision for when rebalancing the shard is not allowed.
- cannotRemain(Decision, AllocationDecision, DiscoveryNode, List<NodeAllocationResult>) - Static method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Creates a move decision for the shard not being allowed to remain on its current node.
- cannotSatisfyCircularDependency(Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
- canonicalize(Type) - Static method in class org.elasticsearch.common.inject.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(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(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- canRemain(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
- canRemain(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
- canRemain(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
- canRemain(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.NodeReplacementAllocationDecider
- canRemain(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(ShardRouting, RoutingNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
- 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
- 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.
- 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.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.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.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.action.RestMainAction
- canTripCircuitBreaker() - Method in class org.elasticsearch.rest.BaseRestHandler.Wrapper
- 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. - capacity() - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
-
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.inject.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)
. - capitalize(String) - Static method in class org.elasticsearch.common.Strings
-
Capitalize a
String
, changing the first letter to upper case as perCharacter.toUpperCase(char)
. - captureAsWriteable() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Captures the current thread context as writeable, allowing it to be serialized out later
- cardinality() - Method in class org.apache.lucene.util.CombinedBitSet
-
This implementation is slow and requires to iterate over all bits to compute the intersection.
- cardinality() - Method in class org.elasticsearch.common.util.BitArray
- 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, AggregationContext, Aggregator, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- 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. - 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.
- caseInsensitiveTermQuery(Term) - Static method in class org.elasticsearch.common.lucene.search.AutomatonQueries
-
Build an automaton accepting all terms ASCII case insensitive.
- caseInsensitiveWildcardQuery(Term) - Static method in class org.elasticsearch.common.lucene.search.AutomatonQueries
-
Build an automaton matching a wildcard pattern, ASCII case insensitive.
- cast() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- 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 - Variable in class org.elasticsearch.index.shard.IndexShard.ShardFailure
- 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.PutComposableIndexTemplateAction.Request
- cause() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- cause() - Method in class org.elasticsearch.repositories.VerificationFailure
- 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.PutComposableIndexTemplateAction.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_FIELD - Static variable in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- CCW - Static variable in enum class org.elasticsearch.common.geo.Orientation
- 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
- centeredModulus(double, double) - Static method in class org.elasticsearch.common.geo.GeoUtils
- CENTIMETERS - Enum constant in enum class org.elasticsearch.common.unit.DistanceUnit
- centroid() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- centroid() - Method in interface org.elasticsearch.search.aggregations.metrics.GeoCentroid
- centroid() - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- centroid() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedGeoCentroid
- CFE - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- CFS - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- Cgroup(String, long, String, long, long, OsStats.Cgroup.CpuStat, String, String, String) - Constructor for class org.elasticsearch.monitor.os.OsStats.Cgroup
- 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,
Request extends TransportRequest> - Class in org.elasticsearch.action.support - ChannelActionListener(TransportChannel, String, Request) - 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, 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
- charTermAttr - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- 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.
- 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 - checkAutoIdWithOpTypeCreateSupportedByVersion(Version) - Method in class org.elasticsearch.action.index.IndexRequest
- checkBlock(ClusterAllocationExplainRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.allocation.TransportClusterAllocationExplainAction
- 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(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(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(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.exists.TransportAliasesExistAction
- 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(IndicesExistsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.exists.indices.TransportIndicesExistsAction
- checkBlock(TypesExistsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.exists.types.TransportTypesExistsAction
- 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(DeleteComponentTemplateAction.Request, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteComponentTemplateAction
- checkBlock(DeleteComposableIndexTemplateAction.Request, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteComposableIndexTemplateAction
- checkBlock(DeleteIndexTemplateRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
- 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(PutComposableIndexTemplateAction.Request, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutComposableIndexTemplateAction
- checkBlock(PutIndexTemplateRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
- checkBlock(UpgradeSettingsRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeSettingsAction
- checkBlock(ModifyDataStreamsAction.Request, ClusterState) - Method in class org.elasticsearch.action.datastreams.ModifyDataStreamsTransportAction
- 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(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
- checkBundleJarHell(Set<URL>, PluginsService.Bundle, Map<String, Set<URL>>) - Static method in class org.elasticsearch.plugins.PluginsService
- checkCancelled(SearchShardTask) - Method in class org.elasticsearch.search.SearchService
- 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
- 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
- checkForFailedPluginRemovals(Path) - Static method in class org.elasticsearch.plugins.PluginsService
- checkForMisplacedScopeAnnotations(Class<?>, Object, Errors) - Static method in class org.elasticsearch.common.inject.internal.Annotations
-
Adds an error if there is a misplaced annotations on
type
. - checkForNull(T, Object, Dependency<?>) - Method in class org.elasticsearch.common.inject.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) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.SignificanceHeuristic
- checkGlobalBlock(ClusterState) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- checkGlobalBlock(ClusterState) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- 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, UpgradeStatusRequest) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
- checkGlobalBlock(ClusterState, UpgradeRequest) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
- 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
- checkIdle(long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Called by
IndexingMemoryController
to check whether more thaninactiveTimeNS
has passed since the last indexing operation, and notify listeners that we are now inactive so e.g. - 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.
- checkIndexTime() - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- checkIndexTime(long) - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- 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.
- checkNegativeBoost(float) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- 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
- checkNotAnnotated() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- checkNotAnnotated() - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- checkNoTimeZone(ZoneId) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Validate the provided
timeZone
is null. - checkNotScoped() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- checkNotTargetted() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- checkNull(String, Object) - Static method in class org.elasticsearch.index.mapper.TypeParsers
- 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, 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, UpgradeStatusRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
- checkRequestBlock(ClusterState, UpgradeRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
- 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
- checkRestTotalHits(RestRequest, SearchRequest) - Static method in class org.elasticsearch.rest.action.search.RestSearchAction
-
Modify the search request to accurately count the total hits that match the query if
RestSearchAction.TOTAL_HITS_AS_INT_PARAM
is set. - checkSegmentInfoIntegrity(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
- 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 extends ToXContent> - Class in org.elasticsearch.repositories.blobstore
-
Snapshot metadata file format used in v2.0 and above
- ChecksumBlobStoreFormat(String, String, CheckedBiFunction<String, XContentParser, T, IOException>) - 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.
- checkUnrecognizedParams(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel.AbstractModelParser
- checkWriteable(Object) - Static method in class org.elasticsearch.common.io.stream.StreamOutput
- childBindingAlreadySet(Key<?>) - Method in class org.elasticsearch.common.inject.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(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() - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Lists all child containers under this container.
- children() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- children() - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- 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_SIZE_SETTING - Static variable in class org.elasticsearch.repositories.fs.FsRepository
- 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
- 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
- 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
- CircuitBreakerPlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
implementations to add custom circuit breakers - 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.
- clampToValidRange(Instant) - Method in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
-
Return the instant that this range can represent that is closest to the provided instant.
- 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
- 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
- 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, Version, ActionListener<RepositoryCleanupResult>) - 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<? extends IndexPatternMatcher>, 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.
- cleanupIndex(Index, long) - Method in class org.elasticsearch.gateway.MetaStateService
-
Removes old state files in index directory.
- cleanupOldFiles(long, Path[]) - Method in class org.elasticsearch.gateway.MetadataStateFormat
-
Clean ups all state files not matching passed generation.
- cleanupRepository(CleanupRepositoryRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Cleans up repository.
- cleanupRepository(CleanupRepositoryRequest, ActionListener<CleanupRepositoryResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Cleans up repository.
- CleanupRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.cleanup
- cleanupRepositoryRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Cleanup repository
- CleanupRepositoryRequest - Class in org.elasticsearch.action.admin.cluster.repositories.cleanup
- CleanupRepositoryRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryRequest
- CleanupRepositoryRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryRequest
- CleanupRepositoryRequestBuilder - Class in org.elasticsearch.action.admin.cluster.repositories.cleanup
- CleanupRepositoryRequestBuilder(ElasticsearchClient, ActionType<CleanupRepositoryResponse>, 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
- clear() - Method in class org.apache.lucene.analysis.miscellaneous.DisableGraphAttributeImpl
- clear() - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- 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.common.collect.EvictingQueue
- clear() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- clear() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- clear() - Method in class org.elasticsearch.common.collect.MapBuilder
- clear() - Method in class org.elasticsearch.common.util.LazyMap
- 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.indices.recovery.RecoveryState.RecoveryFilesDetails
- 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() - Method in class org.elasticsearch.search.lookup.SourceLookup
- clear(int) - Method in class org.apache.lucene.util.CombinedBitSet
- clear(int, int) - Method in class org.apache.lucene.util.CombinedBitSet
- 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 interface org.elasticsearch.client.IndicesAdminClient
-
Clear indices cache.
- clearCache(ClearIndicesCacheRequest, ActionListener<ClearIndicesCacheResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Clear indices cache.
- 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
- ClearIndicesCacheAction - Class in org.elasticsearch.action.admin.indices.cache.clear
- clearIndicesCacheRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a clean indices cache request.
- 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, ClearIndicesCacheAction) - Constructor for class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
- ClearIndicesCacheResponse - Class in org.elasticsearch.action.admin.indices.cache.clear
-
The response of a clear cache action.
- 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.Client
-
Clears the search contexts associated with specified scroll ids.
- clearScroll(ClearScrollRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- clearScroll(ClearScrollRequest, ActionListener<ClearScrollResponse>) - Method in interface org.elasticsearch.client.Client
-
Clears the search contexts associated with specified scroll ids.
- clearScroll(ClearScrollRequest, ActionListener<ClearScrollResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- ClearScrollAction - Class in org.elasticsearch.action.search
- 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, ClearScrollAction) - 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
- ClearScrollResponse(StreamInput) - 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
- clearTemporalResponses() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
-
Clears the list of cached ping responses.
- clearTrackedNodes() - Method in class org.elasticsearch.cluster.coordination.LagDetector
- clearVotingConfigExclusions() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.Builder
- ClearVotingConfigExclusionsAction - Class in org.elasticsearch.action.admin.cluster.configuration
- 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() - Constructor for class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsRequest
-
Construct a request to remove all the voting config exclusions from the cluster state.
- ClearVotingConfigExclusionsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsRequest
- client - Variable in class org.elasticsearch.action.ActionRequestBuilder
- 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 class org.elasticsearch.node.Node
-
A client that can be used to execute actions (operations) against the cluster.
- Client - Interface in org.elasticsearch.client
-
A client provides a one stop interface for performing actions/operations against the cluster.
- CLIENT_TRANSPORT_IGNORE_CLUSTER_NAME - Static variable in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- CLIENT_TRANSPORT_NODES_SAMPLER_INTERVAL - Static variable in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- CLIENT_TRANSPORT_PING_TIMEOUT - Static variable in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- CLIENT_TRANSPORT_SNIFF - Static variable in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- CLIENT_TYPE - Static variable in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- CLIENT_TYPE_SETTING_S - Static variable in interface org.elasticsearch.client.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(int, String, String, String, String, String, String, long, long, long, long, long) - Constructor for class org.elasticsearch.http.HttpStats.ClientStats
- 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.settings.SecureString
-
Returns a new copy of this object that is backed by its own char array.
- clone() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- clone() - Method in class org.elasticsearch.index.mapper.RootObjectMapper
- clone() - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- clone() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
- clone() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- clone() - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel
- clone() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
-
Clone the model, returning an exact copy
- clone() - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel
- clone(long, BigArrays) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
-
Clone the data structure at the given bucket
- CLONE - Enum constant in enum class org.elasticsearch.action.admin.indices.shrink.ResizeType
- CLONE_SNAPSHOT_VERSION - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- cloneLocalPeerRecoveryRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
- cloneLocalPeerRecoveryRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.shard.IndexShard
- 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 interface org.elasticsearch.repositories.Repository
-
Clones a shard snapshot.
- cloneSnapshot(CloneSnapshotRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Clones a snapshot.
- cloneSnapshot(CloneSnapshotRequest, ActionListener<Void>) - Method in class org.elasticsearch.snapshots.SnapshotsService
- cloneSnapshot(CloneSnapshotRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Clones a snapshot.
- CloneSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.clone
- CloneSnapshotRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.clone
- CloneSnapshotRequest(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.
- CloneSnapshotRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
- CloneSnapshotRequestBuilder - Class in org.elasticsearch.action.admin.cluster.snapshots.clone
- CloneSnapshotRequestBuilder(ElasticsearchClient, ActionType<AcknowledgedResponse>, String, String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequestBuilder
- CloneSnapshotRequestBuilder(ElasticsearchClient, ActionType<AcknowledgedResponse>, CloneSnapshotRequest) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequestBuilder
- close() - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Closes the processor.
- close() - Method in class org.elasticsearch.action.search.QueryPhaseResultConsumer
- close() - Method in class org.elasticsearch.action.support.replication.PendingReplicationActions
- close() - Method in class org.elasticsearch.client.FilterClient
- close() - Method in class org.elasticsearch.client.node.NodeClient
- close() - Method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.Closes the client.
- 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.breaker.PreallocatedCircuitBreakerService
- close() - Method in class org.elasticsearch.common.bytes.RecyclingBytesStreamOutput
- 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.BytesStreamOutput
- 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.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.UTF8StreamWriter
-
Closes and
resets
this writer for reuse. - 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.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 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.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 interface org.elasticsearch.common.util.concurrent.ThreadContext.StoredContext
- 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.discovery.ProbeConnectionResult
- close() - Method in class org.elasticsearch.discovery.zen.FaultDetection
- close() - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- close() - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
- close() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
- close() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.PingingRound
- 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.PersistedClusterStateService.Writer
- close() - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
- close() - Method in class 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.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.fielddata.BinaryScriptFieldData.BinaryScriptLeafFieldData
- close() - Method in class org.elasticsearch.index.fielddata.BooleanScriptFieldData.BooleanScriptLeafFieldData
- close() - Method in class org.elasticsearch.index.fielddata.DoubleScriptFieldData.DoubleScriptLeafFieldData
- close() - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
- close() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Closes this builder and release all resources.
- close() - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVLeafFieldData
- close() - Method in class org.elasticsearch.index.fielddata.plain.LeafDoubleFieldData
- close() - Method in class org.elasticsearch.index.fielddata.plain.LeafLongFieldData
- close() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesLeafFieldData
- close() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetBytesLeafFieldData
- 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.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.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.repositories.blobstore.ChunkedBlobOutputStream
- close() - Method in class org.elasticsearch.repositories.FilterRepository
- 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 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.sampler.BestDocsDeferringCollector
- 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.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.InboundMessage
- close() - Method in class org.elasticsearch.transport.InboundPipeline
- close() - Method in class org.elasticsearch.transport.Lz4TransportDecompressor
- 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 interface 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) - Method in class org.elasticsearch.index.IndexService
- close(String, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
- close(CloseIndexRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Closes an index based on the index name.
- close(CloseIndexRequest, ActionListener<CloseIndexResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Closes an index based on the index name.
- 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.action.support.IndicesOptions.WildcardStates
- 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.
- CloseIndexAction - Class in org.elasticsearch.action.admin.indices.close
- CloseIndexClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.close
-
Cluster state update request that allows to close one or more indices
- CloseIndexClusterStateUpdateRequest(long) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexClusterStateUpdateRequest
- closeIndexRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Creates a close index request.
- 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, CloseIndexAction) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
- CloseIndexRequestBuilder(ElasticsearchClient, CloseIndexAction, 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.transport.CloseableConnection
- 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
-
Method to close the engine while the write lock is held.
- closeNoLock(String, CountDownLatch) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Closes the engine without acquiring the write lock.
- 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.
- closePassword() - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequest
- ClosePointInTimeAction - Class in org.elasticsearch.action.search
- ClosePointInTimeRequest - Class in org.elasticsearch.action.search
- ClosePointInTimeRequest(String) - 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
- ClosePointInTimeResponse(StreamInput) - Constructor for class org.elasticsearch.action.search.ClosePointInTimeResponse
- cluster() - Method in interface org.elasticsearch.client.AdminClient
-
A client allowing to perform actions/operations against the cluster.
- CLUSTER - Enum constant in enum class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest.Level
- 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_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_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_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_WATERMARK_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- CLUSTER_ROUTING_ALLOCATION_INCLUDE_RELOCATIONS_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_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_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
- ClusterAdminClient - Interface in org.elasticsearch.client
-
Administrative actions/operations against indices.
- clusterAlias - Variable in class org.elasticsearch.transport.RemoteConnectionStrategy
- ClusterAllocationExplainAction - Class in org.elasticsearch.action.admin.cluster.allocation
-
ActionType for explaining shard allocation for a shard in the cluster
- ClusterAllocationExplainRequest - Class in org.elasticsearch.action.admin.cluster.allocation
-
A request to explain the allocation of a shard in the cluster
- ClusterAllocationExplainRequest() - Constructor for class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Create a new allocation explain request to explain any unassigned shard in the cluster.
- ClusterAllocationExplainRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
- ClusterAllocationExplainRequestBuilder - Class in org.elasticsearch.action.admin.cluster.allocation
-
Builder for requests to explain the allocation of a shard in the cluster
- ClusterAllocationExplainRequestBuilder(ElasticsearchClient, ClusterAllocationExplainAction) - Constructor for class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
- 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
- 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 class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreClusterStateListener
- clusterChanged(ClusterChangedEvent) - Method in interface org.elasticsearch.cluster.ClusterStateListener
-
Called when cluster state changes.
- 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.gateway.DanglingIndicesState
- clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.gateway.GatewayService
- 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.SystemIndexManager
- 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.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
- ClusterFormationFailureHelper - Class in org.elasticsearch.cluster.coordination
- ClusterFormationFailureHelper(Settings, Supplier<ClusterFormationFailureHelper.ClusterFormationState>, ThreadPool, Runnable) - Constructor for class org.elasticsearch.cluster.coordination.ClusterFormationFailureHelper
- ClusterGetSettingsRequest - Class in org.elasticsearch.action.admin.cluster.settings
-
This request is specific to the REST client.
- ClusterGetSettingsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsRequest
- ClusterGetSettingsResponse - Class in org.elasticsearch.action.admin.cluster.settings
-
This response is specific to the REST client.
- ClusterGetSettingsResponse(Settings, Settings, Settings) - Constructor for class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
- ClusterHealthAction - Class in org.elasticsearch.action.admin.cluster.health
- clusterHealthRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a cluster health request.
- ClusterHealthRequest - Class in org.elasticsearch.action.admin.cluster.health
- ClusterHealthRequest() - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- ClusterHealthRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- ClusterHealthRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- ClusterHealthRequest.Level - Enum Class in org.elasticsearch.action.admin.cluster.health
- ClusterHealthRequestBuilder - Class in org.elasticsearch.action.admin.cluster.health
- ClusterHealthRequestBuilder(ElasticsearchClient, ClusterHealthAction) - 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(ImmutableOpenMap<String, DiskUsage>, ImmutableOpenMap<String, DiskUsage>, ImmutableOpenMap<String, Long>, ImmutableOpenMap<ShardId, Long>, ImmutableOpenMap<ShardRouting, String>, ImmutableOpenMap<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 - Class in org.elasticsearch.cluster
-
Represents a data path on a node
- ClusterInfo.ReservedSpace - 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(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.
- 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, ThreadContext, SystemIndices) - Constructor for class org.elasticsearch.cluster.ClusterModule
- clusterName - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- clusterName - Variable in class org.elasticsearch.transport.TransportService
- clusterName() - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection.PingRequest
- clusterName() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingResponse
-
the name of the cluster this node belongs to
- 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(Settings, 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.
- ClusterRerouteAction - Class in org.elasticsearch.action.admin.cluster.reroute
- clusterRerouteRequest() - Static method in class org.elasticsearch.client.Requests
- ClusterRerouteRequest - Class in org.elasticsearch.action.admin.cluster.reroute
-
Request to submit cluster reroute allocation commands
- ClusterRerouteRequest() - Constructor for class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
- ClusterRerouteRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
- ClusterRerouteRequestBuilder - Class in org.elasticsearch.action.admin.cluster.reroute
-
Builder for a cluster reroute request
- ClusterRerouteRequestBuilder(ElasticsearchClient, ClusterRerouteAction) - Constructor for class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
- 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
- ClusterSearchShardsAction - Class in org.elasticsearch.action.admin.cluster.shards
- ClusterSearchShardsGroup - Class in org.elasticsearch.action.admin.cluster.shards
- ClusterSearchShardsGroup(ShardId, ShardRouting[]) - Constructor for class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
- clusterSearchShardsRequest() - Static method in class org.elasticsearch.client.Requests
-
List all shards for the give search
- clusterSearchShardsRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
List all shards for the give search
- ClusterSearchShardsRequest - Class in org.elasticsearch.action.admin.cluster.shards
- ClusterSearchShardsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- ClusterSearchShardsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- ClusterSearchShardsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- ClusterSearchShardsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.shards
- ClusterSearchShardsRequestBuilder(ElasticsearchClient, ClusterSearchShardsAction) - Constructor for class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequestBuilder
- 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.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
- clusterService - Variable in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- 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.cluster.metadata.TemplateUpgradeService
- clusterService() - Method in class org.elasticsearch.indices.IndicesService
- ClusterService - Class in org.elasticsearch.cluster.service
- ClusterService(Settings, ClusterSettings, MasterService, ClusterApplierService) - Constructor for class org.elasticsearch.cluster.service.ClusterService
- ClusterService(Settings, ClusterSettings, ThreadPool) - 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
- ClusterSettings(Settings, Set<Setting<?>>, Set<SettingUpgrader<?>>) - 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
- clusterState - Variable in class org.elasticsearch.action.admin.indices.rollover.MetadataRolloverService.RolloverResult
- clusterState() - Method in interface org.elasticsearch.discovery.zen.PingContextProvider
-
return the current cluster state of the node
- clusterState() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- clusterState(Environment, PersistedClusterStateService.OnDiskState) - Static method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- ClusterState - Class in org.elasticsearch.cluster
-
Represents the current state of the cluster.
- ClusterState(long, String, ClusterState) - Constructor for class org.elasticsearch.cluster.ClusterState
- ClusterState(ClusterName, long, String, Metadata, RoutingTable, DiscoveryNodes, ClusterBlocks, ImmutableOpenMap<String, ClusterState.Custom>, int, boolean, RoutingNodes) - Constructor for class org.elasticsearch.cluster.ClusterState
- ClusterState.Builder - Class in org.elasticsearch.cluster
- ClusterState.Custom - Interface in org.elasticsearch.cluster
- ClusterState.FeatureAware - Interface in org.elasticsearch.cluster
-
An interface that implementors use when a class requires a client to maybe have a feature.
- ClusterState.Metric - Enum Class in org.elasticsearch.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, 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(ClusterState, 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, 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(String, ClusterState, ClusterState) - Method in interface org.elasticsearch.cluster.ClusterStateTaskListener
-
Called when the result of the
ClusterStateTaskExecutor.execute(ClusterState, List)
have been processed properly by all listeners. - clusterStateProcessed(String, ClusterState, ClusterState) - Method in class org.elasticsearch.cluster.metadata.SystemIndexMetadataUpgradeService.SystemIndexMetadataUpdateTask
- clusterStateProcessed(String, 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(String, ClusterState, ClusterState, long, long) - Constructor for class org.elasticsearch.cluster.ClusterStatePublicationEvent
- clusterStatePublished(ClusterStatePublicationEvent) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardFailedClusterStateTaskExecutor
- clusterStatePublished(ClusterStatePublicationEvent) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardStartedClusterStateTaskExecutor
- clusterStatePublished(ClusterStatePublicationEvent) - Method in interface org.elasticsearch.cluster.ClusterStateTaskExecutor
-
Callback invoked after new cluster state is published.
- clusterStatePublished(ClusterStatePublicationEvent) - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
- ClusterStatePublisher - Interface in org.elasticsearch.cluster.coordination
- ClusterStatePublisher.AckListener - Interface in org.elasticsearch.cluster.coordination
- clusterStateRequest() - Static method in class org.elasticsearch.client.Requests
-
Creates a cluster state request.
- ClusterStateRequest - Class in org.elasticsearch.action.admin.cluster.state
- ClusterStateRequest() - Constructor for class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- ClusterStateRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- ClusterStateRequestBuilder - Class in org.elasticsearch.action.admin.cluster.state
- ClusterStateRequestBuilder(ElasticsearchClient, ClusterStateAction) - 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
- ClusterStateTaskConfig - Interface in org.elasticsearch.cluster
-
Cluster state update task configuration for timeout and priority
- ClusterStateTaskConfig.Basic - Class in org.elasticsearch.cluster
- ClusterStateTaskExecutor<T> - Interface in org.elasticsearch.cluster
- ClusterStateTaskExecutor.ClusterTasksResult<T> - Class in org.elasticsearch.cluster
-
Represents the result of a batched execution of cluster state update tasks
- ClusterStateTaskExecutor.ClusterTasksResult.Builder<T> - Class in org.elasticsearch.cluster
- ClusterStateTaskExecutor.TaskResult - Class in org.elasticsearch.cluster
- ClusterStateTaskListener - Interface in org.elasticsearch.cluster
- ClusterStateUpdateRequest<T extends ClusterStateUpdateRequest<T>> - Class in org.elasticsearch.cluster.ack
-
Base class to be used when needing to update the cluster state Contains the basic fields that are always needed
- ClusterStateUpdateRequest() - Constructor for class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
- 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 class org.elasticsearch.discovery.zen.NodesFaultDetection.PingRequest
- clusterStateVersion() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- clusterStats(ClusterStatsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Cluster wide aggregated stats.
- clusterStats(ClusterStatsRequest, ActionListener<ClusterStatsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Cluster wide aggregated stats
- ClusterStatsAction - Class in org.elasticsearch.action.admin.cluster.stats
- 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
- 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[]) - 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() - Static method in class org.elasticsearch.client.Requests
-
Creates a cluster stats request.
- ClusterStatsRequest - Class in org.elasticsearch.action.admin.cluster.stats
-
A request to get cluster level stats.
- ClusterStatsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequest
-
Get stats from nodes based on the nodes ids specified.
- ClusterStatsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequest
- ClusterStatsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.stats
- ClusterStatsRequestBuilder(ElasticsearchClient, ClusterStatsAction) - 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) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- ClusterStatsResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- clusterStatus() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
-
Cluster Health Status, only populated on master nodes.
- ClusterUpdateSettingsAction - Class in org.elasticsearch.action.admin.cluster.settings
- clusterUpdateSettingsRequest() - Static method in class org.elasticsearch.client.Requests
- ClusterUpdateSettingsRequest - Class in org.elasticsearch.action.admin.cluster.settings
-
Request for an update cluster settings action
- ClusterUpdateSettingsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- ClusterUpdateSettingsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- ClusterUpdateSettingsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.settings
-
Builder for a cluster update settings request
- ClusterUpdateSettingsRequestBuilder(ElasticsearchClient, ClusterUpdateSettingsAction) - 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() - Method in class org.elasticsearch.cluster.metadata.Metadata
- clusterUUID(String) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- 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(boolean) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- CMP - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- coalesceToEmpty(String) - Static method in class org.elasticsearch.common.Strings
- codec(String) - Method in class org.elasticsearch.index.codec.CodecService
- 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) - Constructor for class org.elasticsearch.index.codec.CodecService
- 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 - Static variable in class org.elasticsearch.index.mapper.RangeFieldMapper.Defaults
- 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(CollapseBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- collapse(CollapseContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- collapse(CollapseContext) - Method in class org.elasticsearch.search.internal.SearchContext
- COLLAPSE - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- COLLAPSE_FIELD - Static variable in class org.elasticsearch.index.query.InnerHitBuilder
- 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, List<InnerHitBuilder>) - Constructor for class org.elasticsearch.search.collapse.CollapseContext
- collapseField - Variable in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
- CollapseTopFieldDocs - Class in org.apache.lucene.search.grouping
-
Represents hits returned by
CollapsingTopDocsCollector.getTopDocs()
. - CollapseTopFieldDocs(String, TotalHits, ScoreDoc[], SortField[], Object[]) - Constructor for class org.apache.lucene.search.grouping.CollapseTopFieldDocs
- 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 - Variable in class org.apache.lucene.search.grouping.CollapseTopFieldDocs
-
The collapse value for each top doc
- CollapsingTopDocsCollector<T> - Class in org.apache.lucene.search.grouping
-
A collector that groups documents based on field values and returns
CollapseTopFieldDocs
output. - 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.apache.lucene.search.grouping.CollapsingTopDocsCollector
- collect(int) - Method in class org.elasticsearch.action.search.MaxScoreCollector
- collect(int) - Method in class org.elasticsearch.common.lucene.MinimumScoreCollector
- 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
- 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.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
- 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. - 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 - 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
. - collectV2Mappings(Map<String, String>, List<CompressedXContent>, NamedXContentRegistry) - Static method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
- collectV2Mappings(Map<String, String>, ClusterState, String, NamedXContentRegistry, String) - Static method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
- 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(Iterable<? extends Module>) - Static method in class org.elasticsearch.common.inject.util.Modules
-
Returns a new module that installs all of
modules
. - 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(Module...) - Static method in class org.elasticsearch.common.inject.util.Modules
-
Returns a new module that installs all of
modules
. - 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.apache.lucene.util
-
A
BitSet
implementation that combines two instances ofBitSet
andBits
to provide a single merged view. - CombinedBitSet(BitSet, Bits) - Constructor for class org.apache.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
- combineScript() - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
-
Get the
combine
script. - 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
- 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
- CommandLoggingConfigurator - Class in org.elasticsearch.cli
-
Holder class for method to configure logging without Elasticsearch configuration files for use in CLI tools that will not read such files.
- CommandLoggingConfigurator() - Constructor for class org.elasticsearch.cli.CommandLoggingConfigurator
- 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.
- COMMIT_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- COMMIT_MISMATCH - Enum constant in enum class org.elasticsearch.index.engine.Engine.SyncedFlushResult
- COMMIT_STATE_ACTION_NAME - Static variable in class org.elasticsearch.cluster.coordination.PublicationTransportHandler
- COMMIT_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.DiscoverySettings
-
sets the timeout for receiving enough acks for a specific cluster state and committing it.
- CommitClusterStateRequest(String) - Constructor for class org.elasticsearch.discovery.zen.PublishClusterStateAction.CommitClusterStateRequest
- CommitClusterStateRequest(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.PublishClusterStateAction.CommitClusterStateRequest
- commitDescription(IndexCommit) - Static method in class org.elasticsearch.index.engine.CombinedDeletionPolicy
-
Returns a description for a given
IndexCommit
. - CommitId(byte[]) - Constructor for class org.elasticsearch.index.engine.Engine.CommitId
- CommitId(StreamInput) - Constructor for class org.elasticsearch.index.engine.Engine.CommitId
-
Read from a stream.
- commitIndexWriter(IndexWriter, Translog, String) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Commits the specified index writer.
- CommitInfo(long, long) - Constructor for class org.elasticsearch.index.seqno.SequenceNumbers.CommitInfo
- 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
- COMMON_TERMS_QUERY_DEPRECATION_MSG - Static variable in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- 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
- CommonStats(IndicesQueryCache, IndexShard, CommonStatsFlags) - Constructor for class org.elasticsearch.action.admin.indices.stats.CommonStats
- CommonStatsFlags - Class in org.elasticsearch.action.admin.indices.stats
- 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
- commonTermsBlendedQuery(Term[], float[], float) - Static method in class org.apache.lucene.queries.BlendedTermQuery
-
Deprecated.Since max_score optimization landed in 7.0, normal MultiMatchQuery will achieve the same result without any configuration.
- commonTermsCutoff - Variable in class org.elasticsearch.index.search.MatchQueryParser
- commonTermsQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Deprecated.
- CommonTermsQueryBuilder - Class in org.elasticsearch.index.query
-
Deprecated.Since max_optimization optimization landed in 7.0, normal MatchQuery will achieve the same result without any configuration.
- CommonTermsQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.See
CommonTermsQueryBuilder
for more details. - CommonTermsQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.See
CommonTermsQueryBuilder
for more details. - COMPACT_SHARD_ID_VERSION - Static variable in class org.elasticsearch.action.bulk.BulkShardRequest
- 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(ElectMasterService.MasterCandidate, ElectMasterService.MasterCandidate) - Static method in class org.elasticsearch.discovery.zen.ElectMasterService.MasterCandidate
-
compares two candidates to indicate which the a better master.
- 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
- 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(InternalAutoDateHistogram.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- 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(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(ChronoZonedDateTime<?>) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- compareTo(IndicesShardStoresResponse.StoreStatus) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
- compareTo(SearchShard) - Method in class org.elasticsearch.action.search.SearchShard
- compareTo(SearchShardIterator) - Method in class org.elasticsearch.action.search.SearchShardIterator
- 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(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(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(HttpPipelinedMessage) - Method in interface org.elasticsearch.http.HttpPipelinedMessage
- 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 class org.elasticsearch.index.translog.Translog.Location
- compareTo(SystemIndexDescriptor) - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- compareTo(ProcessorInfo) - Method in class org.elasticsearch.ingest.ProcessorInfo
- compareTo(ScriptContextStats) - Method in class org.elasticsearch.script.ScriptContextStats
- compareTo(InternalGeoGridBucket) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- 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 class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- compareTo(Version) - Method in class org.elasticsearch.Version
- compareToSameType(SortValue) - Method in class org.elasticsearch.search.sort.SortValue
-
Compare this sort value to another sort value of the same type.
- COMPATIBILITY_VERSION - Static variable in class org.elasticsearch.action.admin.indices.shrink.ResizeAction
- CompensatedSum - Class in org.elasticsearch.search.aggregations.metrics
-
Used to calculate sums using the Kahan summation algorithm.
- CompensatedSum(double, double) - Constructor for class org.elasticsearch.search.aggregations.metrics.CompensatedSum
-
Used to calculate sums using the Kahan summation algorithm.
- compilationContexts - Variable in class org.elasticsearch.script.ScriptService.ContextSettings
- 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?
- 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.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 - Enum constant in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Status
- 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(Collection<SnapshotsInProgress.ShardSnapshotStatus>) - Static method in class org.elasticsearch.cluster.SnapshotsInProgress
-
Checks if all shards in the list have completed
- completed(ImmutableOpenMap<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.
- 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.
- 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
- 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.MultiFields, FieldMapper.CopyTo, 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.RequestBuilder - 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
- 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
- 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(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
- ComposableIndexTemplate - Class in org.elasticsearch.cluster.metadata
-
An index template is comprised 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(List<String>, Template, List<String>, Long, Long, Map<String, Object>) - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- ComposableIndexTemplate(List<String>, Template, List<String>, Long, Long, Map<String, Object>, ComposableIndexTemplate.DataStreamTemplate) - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- ComposableIndexTemplate(List<String>, Template, List<String>, Long, Long, Map<String, Object>, ComposableIndexTemplate.DataStreamTemplate, Boolean) - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- 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
- 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, 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.
- 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
- 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.fs.FsRepository
- 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(BytesReference) - Constructor for class org.elasticsearch.common.compress.CompressedXContent
-
Create a
CompressedXContent
out of a serializedToXContent
that may already be compressed. - CompressedXContent(ToXContent, XContentType, ToXContent.Params) - Constructor for class org.elasticsearch.common.compress.CompressedXContent
-
Create a
CompressedXContent
out of aToXContent
instance. - compression() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
-
Deprecated.
- compression() - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
-
Returns the compression factor of the t-digest sketches used
- 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
- 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
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.elasticsearch.common.util.LazyMap
- 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
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.elasticsearch.common.util.LazyMap
- 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.
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.elasticsearch.common.util.LazyMap
- computeNorm(FieldInvertState) - Method in class org.elasticsearch.index.similarity.NonNegativeScoresSimilarity
- computeNorm(FieldInvertState) - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity
- computeNxys(long, long, long, long, String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
- computeRecoveryPlan(ShardId, String, Store.MetadataSnapshot, Store.MetadataSnapshot, long, int, Version, boolean, ActionListener<ShardRecoveryPlan>) - Method in class org.elasticsearch.indices.recovery.plan.PeerOnlyRecoveryPlannerService
- computeRecoveryPlan(ShardId, String, Store.MetadataSnapshot, Store.MetadataSnapshot, long, int, Version, boolean, ActionListener<ShardRecoveryPlan>) - Method in interface org.elasticsearch.indices.recovery.plan.RecoveryPlannerService
- computeRecoveryPlan(ShardId, String, Store.MetadataSnapshot, Store.MetadataSnapshot, long, int, Version, boolean, ActionListener<ShardRecoveryPlan>) - Method in class org.elasticsearch.indices.recovery.plan.SnapshotsRecoveryPlannerService
- computeWaitForCheckpoint(Map<String, long[]>, ShardId, int) - Static method in class org.elasticsearch.search.internal.ShardSearchRequest
- concat(Iterable<T>...) - Static method in class org.elasticsearch.common.util.iterable.Iterables
- concat(String[], String[]) - Static method in class org.elasticsearch.common.util.ArrayUtils
-
Concatenates 2 arrays
- concat(Iterator<? extends T>...) - Static method in class org.elasticsearch.common.collect.Iterators
- concat(T[], T[], Class<T>) - Static method in class org.elasticsearch.common.util.ArrayUtils
-
Concatenates 2 arrays
- concatLists(List<E>, List<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, IndexAbstraction.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.
- concreteNodes() - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- 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.
- 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>) - Static method in enum class org.elasticsearch.common.recycler.Recyclers
- 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
- 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
- ConcurrentMapLong<T> - Interface in org.elasticsearch.common.util.concurrent
- 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(Settings, 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 - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition.Result
- Condition<T> - Class in org.elasticsearch.action.admin.indices.rollover
-
Base class for rollover request conditions
- Condition(String) - 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 - Class in org.elasticsearch.action.admin.indices.rollover
-
Holder for evaluated condition result
- Condition.Stats - Class in org.elasticsearch.action.admin.indices.rollover
-
Holder for index stats used to evaluate conditions
- ConditionalProcessor - Class in org.elasticsearch.ingest
- 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
- config - Variable in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- config - Variable in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
- config() - Method in class org.elasticsearch.index.engine.Engine
- Config(CorsHandler.Config.Builder) - Constructor for class org.elasticsearch.http.CorsHandler.Config
- configExists(Environment) - Static method in class org.elasticsearch.bootstrap.plugins.PluginsManager
- 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.common.inject
-
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.common.inject.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.common.inject.AbstractModule
-
Configures a
Binder
via the exposed methods. - configure() - Method in class org.elasticsearch.common.inject.PrivateModule
-
Creates bindings and other configurations private to this module.
- configure() - Method in class org.elasticsearch.gateway.GatewayModule
- configure() - Method in class org.elasticsearch.indices.IndicesModule
- configure(Binder) - Method in class org.elasticsearch.common.inject.AbstractModule
- configure(Binder) - Method in class org.elasticsearch.common.inject.internal.ProviderMethod
- configure(Binder) - Method in class org.elasticsearch.common.inject.internal.ProviderMethodsModule
- configure(Binder) - Method in interface org.elasticsearch.common.inject.Module
-
Contributes bindings and other configurations for this module to
binder
. - configure(Binder) - Method in class org.elasticsearch.common.inject.multibindings.MapBinder.RealMapBinder
- configure(Binder) - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
- configure(Binder) - Method in class org.elasticsearch.common.inject.PrivateModule
- configure(Binder) - Method in class org.elasticsearch.common.settings.SettingsModule
- configure(Environment) - 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.
- ConfiguredHostsResolver - Interface in org.elasticsearch.discovery
- configureLoggingWithoutConfig() - Static method in class org.elasticsearch.cli.CommandLoggingConfigurator
-
Configures logging without Elasticsearch configuration files based on the system property "es.logger.level" only.
- 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) - 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.
- CONNECT - Enum constant in enum class org.elasticsearch.rest.RestRequest.Method
- CONNECT_ON_NETWORK_DISCONNECT_SETTING - Static variable in class org.elasticsearch.discovery.zen.FaultDetection
- CONNECT_TIMEOUT - Static variable in class org.elasticsearch.transport.TransportSettings
- connectedNodes() - Method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.Returns the current connected transport nodes that this client will use.
- 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 class org.elasticsearch.transport.Transport.ResponseContext
- connectionListener - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- 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
- connectOnNetworkDisconnect - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- connectToNode(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService
-
Connect to the specified node with the default connection profile
- connectToNode(DiscoveryNode, ActionListener<Releasable>) - Method in class org.elasticsearch.transport.TransportService
-
Connect to the specified node with the given connection profile.
- connectToNode(DiscoveryNode, ConnectionProfile) - 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
- ConsoleCtrlHandler - Interface in org.elasticsearch.bootstrap
- CONSTANT_SCORE - Static variable in class org.elasticsearch.index.query.support.QueryParsers
- CONSTANT_SCORE_BOOLEAN - Static variable in class org.elasticsearch.index.query.support.QueryParsers
- CONSTANT_VALUE_ALREADY_SET - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- constantBackoff(TimeValue, int) - Static method in class org.elasticsearch.action.bulk.BackoffPolicy
-
Creates an new constant backoff policy with the provided configuration.
- ConstantBindingBuilder - Interface in org.elasticsearch.common.inject.binder
-
Binds to a constant value.
- ConstantBindingBuilderImpl<T> - Class in org.elasticsearch.common.inject.internal
-
Bind a constant.
- ConstantBindingBuilderImpl(Binder, List<Element>, Object) - Constructor for class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- 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
- 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.
- ConstructionContext<T> - Class in org.elasticsearch.common.inject.internal
-
Context of a dependency construction.
- ConstructionContext() - Constructor for class org.elasticsearch.common.inject.internal.ConstructionContext
- ConstructorBinding<T> - Interface in org.elasticsearch.common.inject.spi
-
A binding to the constructor of a concrete clss.
- consumeAggs() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns and nulls out the aggregation for this search results.
- consumeAll() - Method in class org.elasticsearch.search.query.QuerySearchResult
- consumeBucketsAndMaybeBreak(int) - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
-
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.
- 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.
- 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.
- 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.index.seqno.RetentionLeases
-
Checks if this retention lease collection contains a retention lease with the specified
RetentionLease.id()
. - contains(String) - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns true iff this metadata contains the given file.
- contains(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlock
- contains(ShardSearchContextId) - Method in class org.elasticsearch.action.search.SearchContextId
- CONTAINS - Enum constant in enum class org.apache.lucene.queries.BinaryDocValuesRangeQuery.QueryType
- CONTAINS - Enum constant in enum class org.elasticsearch.common.geo.ShapeRelation
- 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.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
- containsField(String) - Method in class org.elasticsearch.common.FieldMemoryStats
-
Returns
true
iff the given field is in the stats - containsHeader(String) - Method in class org.elasticsearch.http.HttpPipelinedResponse
- containsHeader(String) - Method in interface org.elasticsearch.http.HttpResponse
- 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(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- containsKey(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
-
Returns
true
if this container has an association to a value for the given key. - containsKey(Object) - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap
- containsKey(Object) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
- containsKey(Object) - Method in class org.elasticsearch.common.util.LazyMap
- 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(Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
- containsKey(K) - Method in class org.elasticsearch.common.collect.MapBuilder
- containsKey(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- containsKey(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
Returns
true
if this container has an association to a value for the given key. - containsPoint(double, double) - Method in class org.apache.lucene.geo.XTessellator.Triangle
-
utility method to compute whether the point is in the triangle
- 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 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.util.LazyMap
- containsValue(Object) - Method in class org.elasticsearch.script.DynamicMap
- containsValue(Object) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- containsValue(Object) - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- containsValue(Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
- 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.http.HttpPipelinedRequest
- content() - Method in interface org.elasticsearch.http.HttpRequest
- content() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- content() - Method in class org.elasticsearch.rest.BytesRestResponse
- content() - Method in class org.elasticsearch.rest.RestRequest
- content() - Method in class org.elasticsearch.rest.RestResponse
-
The response content.
- 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.client.Requests
-
The content type used to generate request builders (query / search).
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.AllFieldMapper
- 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.GeoShapeFieldMapper
- 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.IpFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.KeywordFieldMapper
- 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.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.TypeFieldMapper
- CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.TypeFieldType
- 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
. - ContentPath - Class in org.elasticsearch.index.mapper
- ContentPath() - Constructor for class org.elasticsearch.index.mapper.ContentPath
- ContentPath(int) - Constructor for class org.elasticsearch.index.mapper.ContentPath
-
Constructs a json path with an offset.
- ContentPath(String) - Constructor for class org.elasticsearch.index.mapper.ContentPath
- contentType() - Method in class org.elasticsearch.index.mapper.AllFieldMapper
- 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.GeoShapeFieldMapper
- 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.IndexFieldMapper
- 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.NumberFieldMapper
- 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.TypeFieldMapper
- contentType() - Method in class org.elasticsearch.index.mapper.VersionFieldMapper
- contentType() - Method in class org.elasticsearch.rest.BytesRestResponse
- contentType() - Method in class org.elasticsearch.rest.RestResponse
-
The response content type.
- 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.AggregatorFactory
- context - Variable in class org.elasticsearch.search.fetch.subphase.highlight.FieldHighlightContext
- context - Variable in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- context - Variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- context() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- context() - Method in 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.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 class org.elasticsearch.script.ScriptMetadata
- context() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
- 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.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.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.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.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.UpdateScript
-
The context used to compile
UpdateScript
factories. - CONTEXT - Static variable in class org.elasticsearch.search.aggregations.pipeline.MovingFunctionScript
- CONTEXT_MODE_API - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- CONTEXT_MODE_GATEWAY - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- 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 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
- 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 - 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.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
- CONTINUE - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The client SHOULD continue with its request.
- conversionError(String, Object, TypeLiteral<?>, MatcherAndConverter, RuntimeException) - Method in class org.elasticsearch.common.inject.internal.Errors
- conversionTypeError(String, Object, TypeLiteral<?>, MatcherAndConverter, Object) - Method in class org.elasticsearch.common.inject.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(Object) - Static method in class org.elasticsearch.common.inject.internal.Errors
- convert(String, TypeLiteral<?>) - Method in interface org.elasticsearch.common.inject.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(L) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- 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(T) - Method in class org.elasticsearch.action.support.ListenableActionFuture
- convert(T) - Method in class org.elasticsearch.action.support.PlainActionFuture
- ConvertedConstantBinding<T> - Interface in org.elasticsearch.common.inject.spi
-
A binding created from converting a bound instance to a new type.
- converterReturnedNull(String, Object, TypeLiteral<?>, MatcherAndConverter) - Method in class org.elasticsearch.common.inject.internal.Errors
- convertFieldValue(MappedFieldType, Object) - Static method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- convertFromStringArray(String[]) - Static method in class org.elasticsearch.common.text.Text
- 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.QueryRewriteContext
- convertToDoubleFilter() - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- convertToElastic(Exception) - Static method in class org.elasticsearch.ExceptionsHelper
- 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
-
Converts the given bytes into a map that is optionally ordered.
- convertToMap(XContent, byte[], int, int, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
- convertToMap(XContent, InputStream, boolean) - 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 of null otherwise - convertToSearchExecutionContext() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- convertToStringFilter(DocValueFormat) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- convertToTypes(Matcher<? super TypeLiteral<?>>, TypeConverter) - Method in class org.elasticsearch.common.inject.AbstractModule
- convertToTypes(Matcher<? super TypeLiteral<?>>, TypeConverter) - Method in interface org.elasticsearch.common.inject.Binder
-
Binds a type converter.
- 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, BigArrays, TransportService, Client, NamedWriteableRegistry, AllocationService, MasterService, Supplier<CoordinationState.PersistedState>, SeedHostsProvider, ClusterApplier, Collection<BiConsumer<DiscoveryNode, ClusterState>>, Random, RerouteService, ElectionStrategy, NodeHealthService) - Constructor for class org.elasticsearch.cluster.coordination.Coordinator
- Coordinator.Mode - Enum Class 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(NamedXContentRegistry, NamedWriteableRegistry, Client, LongSupplier, Index, IndexLongFieldRange, DateFieldMapper.DateFieldType) - Constructor for class org.elasticsearch.index.query.CoordinatorRewriteContext
- CoordinatorRewriteContextProvider - Class in org.elasticsearch.index.query
- CoordinatorRewriteContextProvider(NamedXContentRegistry, NamedWriteableRegistry, Client, LongSupplier, Supplier<ClusterState>, Function<Index, DateFieldMapper.DateFieldType>) - Constructor for class org.elasticsearch.index.query.CoordinatorRewriteContextProvider
- copy() - Method in class org.elasticsearch.common.FieldMemoryStats
-
Creates a deep copy of this stats instance
- 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(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, long, String) - Constructor for class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- copyAndPut(K, V) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
Associate
key
withvalue
and return a new copy of the hash table. - copyAndPutAll(Iterable<Map.Entry<K1, V1>>) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
- copyAndPutAll(Map<? extends K, ? extends V>) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
Same as
CopyOnWriteHashMap.copyAndPut(Object, Object)
but for an arbitrary number of entries. - copyAndPutAll(Stream<Map.Entry<K1, V1>>) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
- copyAndRemove(Object) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
Remove the given key from this map.
- copyAndRemoveAll(Collection<?>) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
Same as
CopyOnWriteHashMap.copyAndRemove(Object)
but for an arbitrary number of entries. - 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
- copyBytes() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
-
Like
BytesStreamOutput.bytes()
but copies the bytes to a freshly allocated buffer. - 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
- copyMap(Map<R, T>) - Static method in class org.elasticsearch.common.util.CollectionUtils
-
Returns an unmodifiable copy of the given map.
- 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.SearchExecutionContext
- copyOf(ObjectObjectMap<KType, VType>) - Static method in class org.elasticsearch.common.collect.ImmutableOpenMap
- copyOf(Map<? extends K, ? extends V>) - Static method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
Return a copy of the provided map.
- CopyOnWriteHashMap<K,
V> - Class in org.elasticsearch.common.collect -
An immutable map whose writes result in a new copy of the map to be created.
- CopyOnWriteHashMap() - Constructor for class org.elasticsearch.common.collect.CopyOnWriteHashMap
-
Create a new empty map.
- 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 - Variable in class org.elasticsearch.index.mapper.FieldMapper
- 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.apache.lucene.analysis.miscellaneous.DisableGraphAttributeImpl
- copyTo(AttributeImpl) - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- 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.
- 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
- CORRUPTED - Enum constant in enum class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
- 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.
- 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.
- 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
- count - Variable in class org.elasticsearch.common.io.stream.BytesStreamOutput
- count - Variable in class org.elasticsearch.index.fielddata.ScriptDocValues.BytesRefs
- count - Variable in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
- count - Variable in class org.elasticsearch.script.ScriptCache.CompilationRate
- count - Variable in class org.elasticsearch.search.aggregations.metrics.InternalStats
- count - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- 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.index.fielddata.HistogramValue
-
The current count of the histogram
- count() - Method in class org.elasticsearch.script.AbstractLongFieldScript
-
The number of results produced the last time
AbstractLongFieldScript.runForDoc(int)
was called. - count() - Method in class org.elasticsearch.script.DoubleFieldScript
-
The number of results produced the last time
DoubleFieldScript.runForDoc(int)
was called. - count() - Method in class org.elasticsearch.script.IpFieldScript
-
The number of results produced the last time
IpFieldScript.runForDoc(int)
was called. - count() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- count() - Method in interface org.elasticsearch.search.aggregations.metrics.GeoCentroid
- count() - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- count() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedGeoCentroid
- 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. - 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
- countCanUseMetadata(FiltersAggregator.Counter, Bits) - Method in class org.elasticsearch.search.aggregations.bucket.filter.QueryToFilterAdapter
-
Would using index metadata like
IndexReader.docFreq(org.apache.lucene.index.Term)
orIndexReader.maxDoc()
to count the number of matching documents produce the same answer as collecting the results with a sequence likesearcher.collect(counter); return counter.readAndReset();
? - 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-down and returns
true
iff this call reached zero otherwisefalse
- CountDown - Class in org.elasticsearch.common.util.concurrent
-
A simple thread safe count-down class that in contrast to a
CountDownLatch
never blocks. - CountDown(int) - Constructor for class org.elasticsearch.common.util.concurrent.CountDown
- 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
- counter - Enum constant in enum class org.elasticsearch.index.mapper.TimeSeriesParams.MetricType
- 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
- 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
- countMasterNodes(Iterable<DiscoveryNode>) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
- 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
- CpuStat(long, long, long) - Constructor for class org.elasticsearch.monitor.os.OsStats.Cgroup.CpuStat
- create() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction.Request
- create() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
- create() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- create() - Static method in class org.elasticsearch.common.inject.internal.UniqueAnnotations
-
Returns an annotation instance that is not equal to any other annotation instances, for use in creating distinct
Key
s. - 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.search.aggregations.MultiBucketConsumerService
- 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.PutComposableIndexTemplateAction.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.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(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(Reader) - Method in interface org.elasticsearch.index.analysis.CharFilterFactory
- 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(Path, boolean) - Static method in class org.elasticsearch.common.PidFile
-
Creates a new PidFile and writes the current process ID into the provided path
- 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<InternalAdjacencyMatrix.InternalBucket>) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- 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<InternalAutoDateHistogram.Bucket>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- 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<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.common.inject.internal.FailableCache
- 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(CreateIndexRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Creates an index using an explicit request allowing to specify the settings of the index.
- create(CreateIndexRequest, ActionListener<CreateIndexResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Creates an index using an explicit request allowing to specify the settings of the index.
- 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(SearchExecutionContext, Collection<FieldAndFormat>) - Static method in class org.elasticsearch.search.fetch.subphase.FieldFetcher
- create(ShardId, String, long, Path, ChannelFactory, ByteSizeValue, long, long, LongSupplier, LongSupplier, long, TragicExceptionHolder, LongConsumer, BigArrays) - Static method in class org.elasticsearch.index.translog.TranslogWriter
- 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(Version) - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProviderFactory
- create(Version) - Method in class org.elasticsearch.index.analysis.PreConfiguredAnalysisComponent
- create(Version) - Method in class org.elasticsearch.index.analysis.PreConfiguredCharFilter
- create(Version) - Method in class org.elasticsearch.index.analysis.PreConfiguredTokenFilter
- create(Version) - Method in class org.elasticsearch.index.analysis.PreConfiguredTokenizer
- create(Version) - Method in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- 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.query.QueryTimingType
- 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.InternalAutoDateHistogram
- 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, 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(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.InternalAutoDateHistogram
- 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, InternalAdjacencyMatrix.InternalBucket) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- 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, InternalAutoDateHistogram.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- 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, 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.InternalRareTerms
-
Create an array to hold some buckets.
- 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.LongRareTerms
- 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.StringRareTerms
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- createBucketsArray(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- 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) - Method in class org.elasticsearch.index.mapper.MapperBuilderContext
-
Creates a new MapperBuilderContext that is a child of this context
- createChildRuntimeField(MappingParserContext, String, Function<SearchLookup, CompositeFieldScript.LeafFactory>) - Method in class org.elasticsearch.index.mapper.RuntimeField.Builder
- createCircuitBreakerService(Settings, List<BreakerSettings>, ClusterSettings) - Static method in class org.elasticsearch.node.Node
-
Creates a new
CircuitBreakerService
based on the settings provided. - 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(Client, ClusterService, ThreadPool, ResourceWatcherService, ScriptService, NamedXContentRegistry, Environment, NodeEnvironment, NamedWriteableRegistry, IndexNameExpressionResolver, Supplier<RepositoriesService>) - Method in class org.elasticsearch.plugins.Plugin
-
Returns components added by this plugin.
- createContext(ReaderContext, ShardSearchRequest, SearchShardTask, boolean) - Method in class org.elasticsearch.search.SearchService
- createCopyToContext() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Return a new context that will be within a copy-to operation.
- 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_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) - Method in class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService
- CreateDataStreamClusterStateUpdateRequest(String) - Constructor for class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService.CreateDataStreamClusterStateUpdateRequest
- CreateDataStreamClusterStateUpdateRequest(String, long, SystemDataStreamDescriptor, TimeValue, TimeValue) - Constructor for class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService.CreateDataStreamClusterStateUpdateRequest
- CreateDataStreamClusterStateUpdateRequest(String, SystemDataStreamDescriptor, TimeValue, TimeValue) - Constructor for class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService.CreateDataStreamClusterStateUpdateRequest
- createDirectSpellChecker() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- createDiscoveryNodeWithImpossiblyHighId(DiscoveryNode) - Static method in class org.elasticsearch.cluster.coordination.DiscoveryUpgradeService
-
Pre-7.0 nodes select the best master by comparing their IDs (as strings) and selecting the lowest one amongst those nodes with the best cluster state version.
- createEmpty() - Method in class org.elasticsearch.index.store.Store
-
creates an empty lucene index and a corresponding empty translog.
- createEmpty(String, MapperService) - Static method in class org.elasticsearch.index.mapper.DocumentMapper
-
Create a new
DocumentMapper
that holds empty mappings. - 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(Map<String, String>) - Method in class org.elasticsearch.cli.EnvironmentAwareCommand
-
Create an
Environment
for the command to use. - createEnv(Settings, Map<String, String>) - Method in class org.elasticsearch.cli.EnvironmentAwareCommand
-
Create an
Environment
for the command to use. - 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
- createFields(String, Number, boolean, boolean, boolean) - Method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- createFields(DocumentParserContext, String, RangeFieldMapper.Range, boolean, boolean, boolean) - Method in enum class org.elasticsearch.index.mapper.RangeType
- createFilter(Filter.Result, Filter.Result) - Static method in class org.elasticsearch.common.logging.RateLimitingFilter
- createFromMap(Map<String, Object>) - Static method in class org.elasticsearch.search.SearchHit
- createGuiceModules() - Method in class org.elasticsearch.plugins.Plugin
-
Node level guice modules.
- createGuiceModules() - Method in class org.elasticsearch.plugins.PluginsService
- CreateHandler() - Constructor for class org.elasticsearch.rest.action.document.RestIndexAction.CreateHandler
- createIllegalState(BytesReference) - Static method in interface org.elasticsearch.transport.TransportDecompressor
- createIndex(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. - 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. - createIndexableFields(String, Polygon) - Static method in class org.apache.lucene.document.XLatLonShape
-
create indexable fields for polygon geometry
- CreateIndexAction - Class in org.elasticsearch.action.admin.indices.create
- 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
- createIndexMapperService(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(String) - Static method in class org.elasticsearch.client.Requests
-
Creates a create index request.
- 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, CreateIndexAction) - Constructor for class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
- CreateIndexRequestBuilder(ElasticsearchClient, CreateIndexAction, 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
- createInjector() - Method in class org.elasticsearch.common.inject.ModulesBuilder
- createInjector(Iterable<? extends Module>) - Static method in class org.elasticsearch.common.inject.Guice
-
Creates an injector for the given set of modules.
- createInjector(Module...) - Static method in class org.elasticsearch.common.inject.Guice
-
Creates an injector for the given set of modules.
- createInjector(Stage, Iterable<? extends Module>) - Static method in class org.elasticsearch.common.inject.Guice
-
Creates an injector for the given set of modules, in a given development stage.
- createInjector(Stage, Module...) - Static method in class org.elasticsearch.common.inject.Guice
-
Creates an injector for the given set of modules, in a given development stage.
- 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.BucketSelectorPipelineAggregationBuilder
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- 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.DerivativePipelineAggregationBuilder
- 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
- createInternal(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- 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.adjacency.AdjacencyMatrixAggregatorFactory
- createInternal(Aggregator, CardinalityUpperBound, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.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.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
- createKeyword(String, MappedFieldType, Sort, int, FieldDoc) - Static method in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
-
Create a collapsing top docs collector on a
SortedDocValues
field. - createLayout(String, Charset, String[]) - Static method in class org.elasticsearch.common.logging.ESJsonLayout
- createListener(ThreadPool) - Method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- createLocal(Settings, TransportAddress, String) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Creates a DiscoveryNode representing the local node.
- 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.DocumentParserContext
-
Return a new context that will be within multi-fields.
- createNestedContext(String) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Return a new context that will be used within a nested document.
- createNumeric(String, MappedFieldType, Sort, int, FieldDoc) - Static method in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
-
Create a collapsing top docs collector on a
NumericDocValues
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(Supplier<ParsedGeoGrid>, CheckedFunction<XContentParser, ParsedGeoGridBucket, IOException>, CheckedFunction<XContentParser, ParsedGeoGridBucket, IOException>) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoGrid
- createParser(NamedXContentRegistry, DeprecationHandler, BytesReference) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Deprecated.use
XContentHelper.createParser(NamedXContentRegistry, DeprecationHandler, BytesReference, XContentType)
to avoid content type auto-detection - createParser(NamedXContentRegistry, DeprecationHandler, BytesReference, XContentType) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Creates a parser for the bytes using the supplied content-type
- createPercentilesAggregator(String, ValuesSource, AggregationContext, Aggregator, double[], boolean, DocValueFormat, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig
- createPercentilesAggregator(String, ValuesSource, AggregationContext, Aggregator, double[], boolean, DocValueFormat, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.Hdr
- createPercentilesAggregator(String, ValuesSource, 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
- 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
- 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.common.inject.internal.ConstructionContext
- createRangeQuery(String, boolean, Object, Object, boolean, boolean, ShapeRelation) - Method in enum class org.elasticsearch.index.mapper.RangeType
- createRecoveryState(ShardRouting, DiscoveryNode, DiscoveryNode) - Method in class org.elasticsearch.index.IndexService
- 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
- createRequest(RestRequest) - Static method in class org.elasticsearch.rest.action.admin.cluster.RestClusterRerouteAction
- createResponse(RestStatus, BytesReference) - Method in class org.elasticsearch.http.HttpPipelinedRequest
- createResponse(RestStatus, BytesReference) - Method in interface org.elasticsearch.http.HttpRequest
-
Create an http response from this request and the supplied status and content.
- createRounding(ZoneId, long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- createRuntimeField(MappingParserContext) - Method in class org.elasticsearch.index.mapper.RuntimeField.Builder
- createSearchContext(ShardSearchRequest, TimeValue) - Method in class org.elasticsearch.search.SearchService
- 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, Consumer<ShardId>, RetentionLeaseSyncer) - Method in class org.elasticsearch.index.IndexService
- createShard(ShardRouting, PeerRecoveryTargetService, PeerRecoveryTargetService.RecoveryListener, RepositoriesService, Consumer<IndexShard.ShardFailure>, Consumer<ShardId>, RetentionLeaseSyncer, DiscoveryNode, DiscoveryNode) - 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>, Consumer<ShardId>, RetentionLeaseSyncer, DiscoveryNode, DiscoveryNode) - Method in class org.elasticsearch.indices.IndicesService
- createShardSearchRequest(CanMatchNodeRequest.Shard) - Method in class org.elasticsearch.action.search.CanMatchNodeRequest
- createShardSearchRequests() - Method in class org.elasticsearch.action.search.CanMatchNodeRequest
- createSnapshot(CreateSnapshotRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Creates a new snapshot.
- createSnapshot(CreateSnapshotRequest, ActionListener<CreateSnapshotResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Creates a new snapshot.
- createSnapshot(CreateSnapshotRequest, ActionListener<Snapshot>) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Initializes the snapshotting process.
- CreateSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.create
-
Create snapshot action
- createSnapshotLegacy(CreateSnapshotRequest, ActionListener<Snapshot>) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Initializes the snapshotting process.
- createSnapshotRequest(String, String) - Static method in class org.elasticsearch.client.Requests
-
Creates new snapshot
- CreateSnapshotRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.create
-
Create snapshot request
- CreateSnapshotRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- CreateSnapshotRequest(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
- CreateSnapshotRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- CreateSnapshotRequestBuilder - Class in org.elasticsearch.action.admin.cluster.snapshots.create
-
Create snapshot request builder
- CreateSnapshotRequestBuilder(ElasticsearchClient, CreateSnapshotAction) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Constructs a new create snapshot request builder
- CreateSnapshotRequestBuilder(ElasticsearchClient, CreateSnapshotAction, 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
- 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.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.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.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.segments.IndicesSegmentsRequest
- createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageShardRequest
- 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.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.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- 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.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 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<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
- createTaskManager(Settings, ThreadPool, Set<String>) - Method in class org.elasticsearch.transport.TransportService
- 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
- 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.AutoDateHistogramAggregatorFactory
- 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.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.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. - 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.apache.lucene.queries.BinaryDocValuesRangeQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.queries.MinDocQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.queries.SearchAfterSortedDocQuery
- createWeight(IndexSearcher, ScoreMode, float) - Method in class org.apache.lucene.queries.SpanMatchNoDocsQuery
- 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.search.aggregations.bucket.filter.MergedPointRangeQuery
- 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(Query, ScoreMode, float) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- 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
- createWriter() - Method in class org.elasticsearch.gateway.PersistedClusterStateService
-
Creates a new disk-based writer for cluster states
- creationDate(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- CreationException - Exception in org.elasticsearch.common.inject
-
Thrown when errors occur while creating a
Injector
. - CreationException(Collection<Message>) - Constructor for exception org.elasticsearch.common.inject.CreationException
-
Creates a CreationException containing
messages
. - 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 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.apache.lucene.queries.BinaryDocValuesRangeQuery.QueryType
- 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
- 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.
- cumulativeSum(String, String) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- 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
- CumulativeSumPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregator
-
Read from a stream.
- current - Variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- current() - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- current() - Method in class org.elasticsearch.index.get.GetStats
- current() - Method in class org.elasticsearch.index.warmer.WarmerStats
- current() - Method in class org.elasticsearch.search.aggregations.bucket.IteratorAndCurrent
- CURRENT - Static variable in class org.elasticsearch.Build
-
The current build of Elasticsearch.
- CURRENT - Static variable in class org.elasticsearch.Version
- CURRENT_SNAPSHOT - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- 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
- 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
- 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.
- 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
- currentStage() - Method in class org.elasticsearch.common.inject.AbstractModule
- currentStage() - Method in interface org.elasticsearch.common.inject.Binder
-
Gets the current stage.
- currentState() - Method in exception org.elasticsearch.index.shard.IllegalIndexShardStateException
- currentTerm - Variable in class org.elasticsearch.gateway.PersistedClusterStateService.OnDiskState
- currentTime() - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
- currentTotalTermFreq - Variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- Cursor() - Constructor for class org.elasticsearch.common.util.LongObjectPagedHashMap.Cursor
- custom(String) - Method in class org.elasticsearch.cluster.ClusterState
- custom(String) - Method in class org.elasticsearch.cluster.metadata.Metadata
- custom(String) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- 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.apache.lucene.search.vectorhighlight
- CustomFieldQuery(Query, IndexReader, boolean, boolean) - Constructor for class org.apache.lucene.search.vectorhighlight.CustomFieldQuery
- CustomFieldQuery(Query, IndexReader, FastVectorHighlighter) - Constructor for class org.apache.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 or by pattern.
- CustomFieldsVisitor(Set<String>, boolean) - Constructor for class org.elasticsearch.index.fieldvisitor.CustomFieldsVisitor
- 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.apache.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) - Constructor for class org.apache.lucene.search.uhighlight.CustomPassageFormatter
- CustomQueryScorer - Class in org.elasticsearch.search.fetch.subphase.highlight
- CustomQueryScorer(WeightedSpanTerm[]) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.CustomQueryScorer
- 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
- CustomQueryScorer(Query, String, String) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.CustomQueryScorer
- CustomQueryScorer(Query, IndexReader, String) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.CustomQueryScorer
- CustomQueryScorer(Query, IndexReader, String, 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(ImmutableOpenMap<String, ClusterState.Custom>) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- customs(ImmutableOpenMap<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.apache.lucene.search.uhighlight
-
Subclass of the
UnifiedHighlighter
that works for a single field in a single document. - CustomUnifiedHighlighter(IndexSearcher, Analyzer, UnifiedHighlighter.OffsetSource, PassageFormatter, Locale, BreakIterator, String, String, Query, int, int, Predicate<String>, int, Integer) - Constructor for class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
-
Creates a new instance of
CustomUnifiedHighlighter
- CUTOFF_FREQUENCY_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
-
Deprecated.Since max_optimization optimization landed in 7.0, normal MatchQuery will achieve the same result without any configuration.
- cutoffFrequency() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- cutoffFrequency() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Gets the optional cutoff value, can be
null
if not set previously - cutoffFrequency() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- cutoffFrequency(float) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.Sets the cutoff document frequency for high / low frequent terms.
- cutoffFrequency(float) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Deprecated.see
MatchQueryBuilder.CUTOFF_FREQUENCY_FIELD
for more details - cutoffFrequency(float) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Deprecated.Since max_score optimization landed in 7.0, normal MultiMatchQuery will achieve the same result without any configuration.
- cutoffFrequency(Float) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Deprecated.Since max_score optimization landed in 7.0, normal MultiMatchQuery will achieve the same result without any configuration.
- cutoffScore - Variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- CW - Static variable in enum class org.elasticsearch.common.geo.Orientation
D
- 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(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), and importing them into the cluster.
- DanglingIndicesState(NodeEnvironment, MetaStateService, LocalAllocateDangledIndices, ClusterService) - Constructor for class org.elasticsearch.gateway.DanglingIndicesState
- 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
- 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
- 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
- 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
- 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_ALIAS_VERSION - Static variable in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- DATA_STREAMS_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStreamAlias
- DATA_STREAMS_IN_SNAPSHOT - Static variable in class org.elasticsearch.snapshots.SnapshotInfo
- DATA_TIER_SETTING_VALIDATOR - Static variable in class org.elasticsearch.cluster.routing.allocation.DataTier
- 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
- dataFiles() - Method in class org.elasticsearch.env.Environment
-
The data location.
- dataNodesWithoutAllDataRoles(ClusterState) - Static method in class org.elasticsearch.cluster.routing.allocation.DataTier
-
Checks each data node in the cluster state to see whether it has the explicit data role or if it has all data tiers (e.g.
- 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
- dataStream(String) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- DataStream - Class in org.elasticsearch.cluster.metadata
- DataStream(String, DataStream.TimestampField, List<Index>, long, Map<String, Object>, boolean, boolean, boolean) - Constructor for class org.elasticsearch.cluster.metadata.DataStream
- DataStream(DataStream, List<String>) - Constructor for class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- DataStream(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.DataStream
- DataStream.TimestampField - Class in org.elasticsearch.cluster.metadata
- dataStreamAccessException(ThreadContext, Collection<String>) - 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, 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
- 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(Map<String, DataStream>, Map<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(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- dataStreamNames(ClusterState, IndicesOptions, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- 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
- dataStreamTemplate(ComposableIndexTemplate.DataStreamTemplate) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.Builder
- DataStreamTemplate() - Constructor for class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- DataStreamTemplate(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: "data_hot"
unless the user overrides the setting while the index is being created (in a create index request for instance) - date() - Method in class org.elasticsearch.Build
- date() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full date as four digit year, two digit month of year, and two digit day of month (yyyy-MM-dd).
- DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- 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
- 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_MINUTE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- DATE_HOUR_MINUTE_SECOND - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- DATE_HOUR_MINUTE_SECOND_FRACTION - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- DATE_HOUR_MINUTE_SECOND_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- 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_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- DATE_TIME_FORMATTER - Static variable in class org.elasticsearch.cluster.routing.UnassignedInfo
- DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- 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
- dateElementParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO date parser for parsing dates.
- 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
- DateFieldScript - Class in org.elasticsearch.script
- DateFieldScript(String, Map<String, Object>, SearchLookup, DateFormatter, 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, 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, Rounding, LongBounds, LongBounds, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>, DateHistogramAggregationSupplier) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregatorFactory
- dateHistogramInterval() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Deprecated.
- dateHistogramInterval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Deprecated.
- dateHistogramInterval() - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalConsumer
-
Deprecated.
- dateHistogramInterval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
-
Deprecated.
- dateHistogramInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- dateHistogramInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- dateHistogramInterval(DateHistogramInterval) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalConsumer
-
Deprecated.
- dateHistogramInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- 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
- dateHour() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter that combines a full date and two digit hour of day.
- dateHourMinute() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter that combines a full date, two digit hour of day, and two digit minute of hour.
- dateHourMinuteSecond() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter that combines a full date, two digit hour of day, two digit minute of hour, and two digit second of minute.
- dateHourMinuteSecondFraction() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter that combines a full date, two digit hour of day, two digit minute of hour, two digit second of minute, and three digit fraction of second (yyyy-MM-dd'T'HH:mm:ss.SSS).
- dateHourMinuteSecondMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter that combines a full date, two digit hour of day, two digit minute of hour, two digit second of minute, and three digit fraction of second (yyyy-MM-dd'T'HH:mm:ss.SSS).
- 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
- DateMathExpressionResolver() - Constructor for class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.DateMathExpressionResolver
- dateMathExpressionResolverAt() - Method in class org.elasticsearch.index.IndexService
- dateMathExpressionResolverAt(long) - Method in class org.elasticsearch.index.IndexService
- dateMathParser - Variable in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- 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 to allow different implementation for joda and java time.
- 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
- dateOptionalTimeParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO datetime parser where the date is mandatory and the time is optional.
- dateParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO date parser for parsing dates with a possible zone.
- 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(SortedNumericDocValues, boolean) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Dates
- 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
- dateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter that combines a full date and time, separated by a 'T' (yyyy-MM-dd'T'HH:mm:ss.SSSZZ).
- DateTime(StreamInput) - Constructor for class org.elasticsearch.search.DocValueFormat.DateTime
- DateTime(DateFormatter, ZoneId, DateFieldMapper.Resolution) - Constructor for class org.elasticsearch.search.DocValueFormat.DateTime
- dateTimeFormatter - Variable in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- 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
- dateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter that combines a full date and time without millis, separated by a 'T' (yyyy-MM-dd'T'HH:mm:ssZZ).
- dateTimeParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO datetime parser which parses either a date or a time or both.
- DateTimeUnit - Enum Class in org.elasticsearch.common.rounding
- dateTimeZoneToZoneId(DateTimeZone) - Static method in class org.elasticsearch.common.time.DateUtils
- 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
- 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.cluster.coordination.DiscoveryUpgradeService
- 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
- Deadlock(ThreadInfo[]) - Constructor for class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
- deadlockAnalyzer() - Static method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer
- DeadlockAnalyzer - Class in org.elasticsearch.monitor.jvm
- DeadlockAnalyzer.Deadlock - Class in org.elasticsearch.monitor.jvm
- DEB - Enum constant in enum class org.elasticsearch.Build.Type
- DEBUG - Enum constant in enum class org.elasticsearch.index.SlowLogLevel
- debugDecision() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- debugDecision(boolean) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- debugFormat() - Method in class org.elasticsearch.search.sort.BucketedSort
-
Return a fairly human readable representation of the array backing the sort.
- 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(JodaCompatibleZonedDateTime) - Method in class org.elasticsearch.script.ScoreScriptUtils.DecayDateExp
- DecayDateExp(String, String, String, double) - Constructor for class org.elasticsearch.script.ScoreScriptUtils.DecayDateExp
- decayDateGauss(JodaCompatibleZonedDateTime) - Method in class org.elasticsearch.script.ScoreScriptUtils.DecayDateGauss
- DecayDateGauss(String, String, String, double) - Constructor for class org.elasticsearch.script.ScoreScriptUtils.DecayDateGauss
- decayDateLinear(JodaCompatibleZonedDateTime) - 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 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
- Decimal(StreamInput) - Constructor for class org.elasticsearch.search.DocValueFormat.Decimal
- 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
- declareAggregationFields(AbstractObjectParser<? extends ParsedAggregation, ?>) - Static method in class org.elasticsearch.search.aggregations.ParsedAggregation
- declareBroadcastFields(ConstructingObjectParser<T, Void>) - Static method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
- declareCommon(AbstractObjectParser<? extends MultiValuesSourceAggregationBuilder<?>, T>, boolean, ValueType) - Static method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceParseHelper
- declareCommonFields(ObjectParser<? extends Suggest.Suggestion.Entry<? extends Suggest.Suggestion.Entry.Option>, Void>) - Static method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- declareExtendedStatsFields(ObjectParser<? extends ParsedExtendedStats, Void>) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- declareField(String, AbstractObjectParser<? extends MultiValuesSourceAggregationBuilder<?>, T>, 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
- declareFields(ObjectParser<? extends BulkByScrollTask.StatusBuilder, Void>) - Static method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- declareInnerHitsParseFields(ObjectParser<Map<String, Object>, Void>) - Static method in class org.elasticsearch.search.SearchHit
- declareIntervalFields(ObjectParser<T, String>) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- declareMultiBucketAggregationFields(ObjectParser<A, Void>, CheckedFunction<XContentParser, T, IOException>, CheckedFunction<XContentParser, T, IOException>) - Static method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation
- declareParsedRangeFields(ObjectParser<? extends ParsedRange, Void>, CheckedFunction<XContentParser, ParsedRange.ParsedBucket, IOException>, CheckedFunction<XContentParser, ParsedRange.ParsedBucket, IOException>) - Static method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange
- 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.
- declarePercentilesFields(ObjectParser<? extends ParsedPercentiles, Void>) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedPercentiles
- declareRawObject(AbstractObjectParser<Value, Context>, BiConsumer<Value, BytesReference>, ParseField) - 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) - 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
. - declareSingleValueFields(ObjectParser<? extends ParsedSingleValueNumericMetricsAggregation, Void>, double) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- declareStandardFields(AbstractObjectParser<? extends QueryBuilder, ?>) - Static method in class org.elasticsearch.index.query.AbstractQueryBuilder
- declareStatsFields(ObjectParser<? extends ParsedStats, Void>) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- decode(String) - Method in interface org.elasticsearch.common.path.PathTrie.Decoder
- decode(BytesRef) - Static method in class org.elasticsearch.search.runtime.IpScriptFieldTermsQuery
- decode(ReleasableBytesReference, Consumer<Object>) - Method in class org.elasticsearch.transport.InboundDecoder
- decode(NamedWriteableRegistry, String) - Static method in class org.elasticsearch.action.search.SearchContextId
- decodeComponent(String) - Static method in class org.elasticsearch.rest.RestUtils
-
Decodes a bit of an URL encoded by a browser.
- 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.
- decodeLatitude(long) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- decodeLongitude(long) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- 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
- decomposeLine(Line, List<Line>) - Static method in class org.elasticsearch.common.geo.GeoLineDecomposer
-
Splits the specified line by datelines and adds them to the supplied lines array
- decomposeMultiLine(MultiLine, List<Line>) - Static method in class org.elasticsearch.common.geo.GeoLineDecomposer
- decomposeMultiPolygon(MultiPolygon, boolean, List<Polygon>) - Static method in class org.elasticsearch.common.geo.GeoPolygonDecomposer
- decomposePolygon(Polygon, boolean, List<Polygon>) - Static method in class org.elasticsearch.common.geo.GeoPolygonDecomposer
-
Splits the specified polygon by datelines and adds them to the supplied polygon array
- decompress(BytesReference) - Method in class org.elasticsearch.transport.DeflateTransportDecompressor
- decompress(BytesReference) - Method in class org.elasticsearch.transport.Lz4TransportDecompressor
- decompress(BytesReference) - Method in interface org.elasticsearch.transport.TransportDecompressor
-
Decompress the provided bytes
- decorate(CompoundProcessor, ConditionalProcessor, List<SimulateProcessorResult>) - Static method in class org.elasticsearch.ingest.TrackingResultProcessor
- 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.transport.BytesTransportRequest
- decRef() - Method in class org.elasticsearch.transport.TransportMessage
- 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.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(String) - Method in class org.elasticsearch.common.util.StringLiteralDeduplicator
- DeDuplicatingTokenFilter - Class in org.apache.lucene.analysis.miscellaneous
-
Inspects token streams for duplicate sequences of tokens.
- DeDuplicatingTokenFilter(TokenStream, DuplicateByteSequenceSpotter) - Constructor for class org.apache.lucene.analysis.miscellaneous.DeDuplicatingTokenFilter
- DeDuplicatingTokenFilter(TokenStream, DuplicateByteSequenceSpotter, boolean) - Constructor for class org.apache.lucene.analysis.miscellaneous.DeDuplicatingTokenFilter
- deepCopy(Object) - Static method in class org.elasticsearch.ingest.IngestDocument
- 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.Build.Flavor
- 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 - Static variable in enum class org.elasticsearch.action.search.SearchType
-
The default search type (
SearchType.QUERY_THEN_FETCH
. - DEFAULT - Static variable in class org.elasticsearch.action.support.ActiveShardCount
- DEFAULT - Static variable in class org.elasticsearch.cluster.ClusterName
- DEFAULT - Static variable in enum class org.elasticsearch.common.unit.DistanceUnit
- DEFAULT - Static variable in enum class org.elasticsearch.index.query.GeoValidationMethod
- 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_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_CUTOFF_FREQ - Static variable in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- DEFAULT_DATE_PRINTER - Static variable in class org.elasticsearch.common.xcontent.XContentElasticsearchExtension
- 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_DISABLE_COORD - Static variable in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- 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_EXPUNGE_DELETES_ALLOWED - Static variable in class org.elasticsearch.index.MergePolicyConfig
- 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_FIELDS_EMULATION_ENABLED - Static variable in class org.elasticsearch.action.search.SearchRequest
- 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_FORCE_SOURCE - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
default for whether to highlight fields based on the source even if stored separately
- 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.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_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_HIGH_FREQ_OCCUR - Static variable in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- 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_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.mapping.get.GetFieldMappingsRequest
- 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.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_INDICES_OPTIONS - Static variable in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- 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_INSTANCE - Static variable in class org.elasticsearch.common.inject.internal.SourceProvider
- 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_LOW_FREQ_OCCUR - Static variable in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- DEFAULT_MAPPING - Static variable in class org.elasticsearch.index.mapper.MapperService
- DEFAULT_MASTER_NODE_TIMEOUT - Static variable in class org.elasticsearch.action.support.master.MasterNodeRequest
- 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_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_MERGE_AT_ONCE_EXPLICIT - Static variable in class org.elasticsearch.index.MergePolicyConfig
- DEFAULT_MAX_MERGED_SEGMENT - 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_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_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_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_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.LongScriptFieldType
- DEFAULT_SCRIPT_FUNCTION - Static variable in class org.elasticsearch.index.fielddata.plain.AbstractLeafOrdinalsFieldData
- 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_SEGMENTS_PER_TIER - Static variable in class org.elasticsearch.index.MergePolicyConfig
- 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.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 class org.elasticsearch.indices.ExecutorNames
-
The thread pools for a typical system data stream.
- DEFAULT_SYSTEM_INDEX_THREAD_POOLS - Static variable in 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 - Static variable in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
- 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.GeoBoundingBoxQueryBuilder
-
Default type for executing this query (memory as of this writing).
- DEFAULT_TYPE - Static variable in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- DEFAULT_TYPE - Static variable in class org.elasticsearch.index.query.QueryStringQueryBuilder
- 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_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
- DefaultBindingScopingVisitor<V> - Class in org.elasticsearch.common.inject.spi
-
No-op visitor for subclassing.
- DefaultBindingScopingVisitor() - Constructor for class org.elasticsearch.common.inject.spi.DefaultBindingScopingVisitor
- DefaultBindingTargetVisitor<T,
V> - Class in org.elasticsearch.common.inject.spi -
No-op visitor for subclassing.
- DefaultBindingTargetVisitor() - Constructor for class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- defaultCcsMinimizeRoundtrips(SearchRequest) - Static method in class org.elasticsearch.action.search.SearchRequest
-
Returns the default value of
SearchRequest.ccsMinimizeRoundtrips
of a search request - DefaultElementVisitor<V> - Class in org.elasticsearch.common.inject.spi
-
No-op visitor for subclassing.
- DefaultElementVisitor() - Constructor for class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- 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.SearchExecutionContext
- defaultFormat() - Method in enum class org.elasticsearch.search.aggregations.support.ValueType
- DefaultHotAllocationSettingProvider() - Constructor for class org.elasticsearch.cluster.routing.allocation.DataTier.DefaultHotAllocationSettingProvider
- defaultMapping() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Get the default mapping.
- 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.
- DefaultRestChannel - Class in org.elasticsearch.http
-
The default rest channel for incoming requests.
- 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.action.admin.indices.upgrade.post.UpgradeRequest.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.AllFieldMapper.Defaults
- Defaults() - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.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.IdFieldMapper.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
- Defaults() - Constructor for class org.elasticsearch.index.mapper.TypeFieldMapper.Defaults
- 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
- defaultStoreType(boolean) - Static method in class org.elasticsearch.index.IndexModule
- defaultTypeIfNull(String) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Deprecated.Types are in the process of being removed.
- defaultTypeIfNull(String) - Method in interface org.elasticsearch.action.DocWriteRequest
-
Set the default type supplied to a bulk request if this individual request's type is null or empty
- defaultTypeIfNull(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Deprecated.Types are in the process of being removed.
- defaultTypeIfNull(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Types are in the process of being removed.
- defaultValue - Variable in class org.elasticsearch.common.settings.Setting
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- defaultValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- 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.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. - 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
- 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(PageCacheRecycler) - Constructor for class org.elasticsearch.transport.DeflateTransportDecompressor
- 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.Serialized<T extends Writeable> - Class in org.elasticsearch.common.io.stream
-
A
Writeable
stored in serialized form backed by aReleasableBytesReference
. - 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
- 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(BiFunction<List<B>, InternalAggregation.ReduceContext, B>, InternalAggregation.ReduceContext, List<B>) - Constructor for class org.elasticsearch.search.aggregations.DelayedBucket
-
Build a delayed bucket.
- 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.ActionListener.Delegating
- delegate - Variable in class org.elasticsearch.common.io.stream.FilterStreamInput
- delegate - Variable in class org.elasticsearch.rest.BaseRestHandler.Wrapper
- delegate() - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- delegateFailure(BiConsumer<ActionListener<Response>, T>) - Method in interface org.elasticsearch.action.ActionListener
-
Creates a listener that delegates all exceptions it receives to another listener.
- 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(ActionListener<DelegateResponse>) - Constructor for class org.elasticsearch.action.ActionListener.Delegating
- DelegatingNodeConnectionListener() - Constructor for class org.elasticsearch.transport.ConnectionManager.DelegatingNodeConnectionListener
- DelegatingRoutingChangesObserver(RoutingChangesObserver...) - Constructor for class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- delete() - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Deletes this container and all its contents from the repository.
- delete() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- delete() - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- delete() - Method in class org.elasticsearch.common.lucene.FilterIndexCommit
- delete(String, String) - Static method in class org.elasticsearch.common.Strings
-
Delete all occurrences of the given substring.
- delete(DeleteIndexRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deletes an index based on the index name.
- delete(DeleteIndexRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deletes an index based on the index name.
- delete(DeleteRequest) - Method in interface org.elasticsearch.client.Client
-
Deletes a document from the index based on the index, type and id.
- delete(DeleteRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- delete(DeleteRequest, ActionListener<DeleteResponse>) - Method in interface org.elasticsearch.client.Client
-
Deletes a document from the index based on the index, type and id.
- delete(DeleteRequest, ActionListener<DeleteResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- delete(DeletePipelineRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.ingest.IngestService
-
Deletes the pipeline specified by id in the request.
- 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, String, long, long, Term) - Constructor for class org.elasticsearch.index.translog.Translog.Delete
-
utility for testing
- Delete(String, String, Term, long) - Constructor for class org.elasticsearch.index.engine.Engine.Delete
- Delete(String, String, Term, long, long, long) - Constructor for class org.elasticsearch.index.translog.Translog.Delete
- Delete(String, String, Term, 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(Engine.Delete, VersionType) - Constructor for class org.elasticsearch.index.engine.Engine.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
- DeleteAction - Class in org.elasticsearch.action.delete
- 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(String, String) - Static method in class org.elasticsearch.common.Strings
-
Delete any character in a given String.
- deleteBlobsIgnoringIfNotExists(Iterator<String>) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Deletes the blobs with given names.
- deleteBlobsIgnoringIfNotExists(Iterator<String>) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- deleteBlobsIgnoringIfNotExists(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, ActionType<BulkByScrollResponse>) - Constructor for class org.elasticsearch.index.reindex.DeleteByQueryRequestBuilder
- DeleteComponentTemplateAction - Class in org.elasticsearch.action.admin.indices.template.delete
- DeleteComponentTemplateAction.Request - Class in org.elasticsearch.action.admin.indices.template.delete
- DeleteComposableIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.delete
- DeleteComposableIndexTemplateAction.Request - Class in org.elasticsearch.action.admin.indices.template.delete
- 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_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.
- deleteDanglingIndex(DeleteDanglingIndexRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete specified dangling indices.
- deleteDanglingIndex(DeleteDanglingIndexRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete specified dangling indices.
- DeleteDanglingIndexAction - Class in org.elasticsearch.action.admin.indices.dangling.delete
-
This action causes a dangling index to be considered as deleted by the cluster.
- 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
- DeleteIndexAction - Class in org.elasticsearch.action.admin.indices.delete
- DeleteIndexClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.delete
-
Cluster state update request that allows to close one or more indices
- 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(String) - Static method in class org.elasticsearch.client.Requests
-
Creates a delete index request.
- 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, DeleteIndexAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequestBuilder
- DeleteIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.delete
- 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, DeleteIndexTemplateAction) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequestBuilder
- DeleteIndexTemplateRequestBuilder(ElasticsearchClient, DeleteIndexTemplateAction, String) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequestBuilder
- deleteIndices(DeleteIndexClusterStateUpdateRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataDeleteIndexService
- deleteIndices(ClusterState, Set<Index>) - Method in class org.elasticsearch.cluster.metadata.MetadataDeleteIndexService
-
Delete some indices from the cluster state.
- 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 interface org.elasticsearch.client.ClusterAdminClient
-
Deletes a stored ingest pipeline
- deletePipeline(DeletePipelineRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Deletes a stored ingest pipeline
- DeletePipelineAction - Class in org.elasticsearch.action.ingest
- DeletePipelineAction() - Constructor for class org.elasticsearch.action.ingest.DeletePipelineAction
- 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, DeletePipelineAction) - Constructor for class org.elasticsearch.action.ingest.DeletePipelineRequestBuilder
- DeletePipelineRequestBuilder(ElasticsearchClient, DeletePipelineAction, 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) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Unregisters a repository.
- deleteRepository(DeleteRepositoryRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Unregisters a repository.
- DeleteRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.delete
-
Unregister repository action
- deleteRepositoryRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Deletes registration for snapshot repository
- DeleteRepositoryRequest - Class in org.elasticsearch.action.admin.cluster.repositories.delete
-
Unregister repository request.
- DeleteRepositoryRequest() - Constructor for class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
- DeleteRepositoryRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
-
Constructs a new unregister repository request with the provided name.
- DeleteRepositoryRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
- DeleteRepositoryRequestBuilder - Class in org.elasticsearch.action.admin.cluster.repositories.delete
-
Builder for unregister repository request
- DeleteRepositoryRequestBuilder(ElasticsearchClient, DeleteRepositoryAction) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequestBuilder
-
Constructs unregister repository request builder
- DeleteRepositoryRequestBuilder(ElasticsearchClient, DeleteRepositoryAction, String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequestBuilder
-
Constructs unregister repository request builder with specified repository name
- deleteRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Creates a delete request against a specific index.
- 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(String, String, String) - Constructor for class org.elasticsearch.action.delete.DeleteRequest
-
Deprecated.Types are in the process of being removed. Use
DeleteRequest(String, String)
instead. - 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, DeleteAction) - Constructor for class org.elasticsearch.action.delete.DeleteRequestBuilder
- DeleteRequestBuilder(ElasticsearchClient, DeleteAction, 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, 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) - Constructor for class org.elasticsearch.index.engine.Engine.DeleteResult
- DeleteResult(Exception, long, long) - Constructor for class org.elasticsearch.index.engine.Engine.DeleteResult
-
use in case of the delete operation failed before getting to internal engine
- DeleteResult(Exception, long, long, long, boolean) - Constructor for class org.elasticsearch.index.engine.Engine.DeleteResult
- DeleteResult(Mapping) - Constructor for class org.elasticsearch.index.engine.Engine.DeleteResult
- 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.
- 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) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete snapshot.
- deleteSnapshot(DeleteSnapshotRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete snapshot.
- DeleteSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.delete
-
Delete snapshot action
- deleteSnapshotRequest(String, String...) - Static method in class org.elasticsearch.client.Requests
-
Deletes snapshots
- DeleteSnapshotRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.delete
-
Delete snapshot request
- DeleteSnapshotRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
-
Constructs a new delete snapshots request
- DeleteSnapshotRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
-
Constructs a new delete snapshots request with repository name
- DeleteSnapshotRequest(String, String...) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
-
Constructs a new delete snapshots request with repository and snapshot names
- DeleteSnapshotRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
- DeleteSnapshotRequestBuilder - Class in org.elasticsearch.action.admin.cluster.snapshots.delete
-
Delete snapshot request builder
- DeleteSnapshotRequestBuilder(ElasticsearchClient, DeleteSnapshotAction) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequestBuilder
-
Constructs delete snapshot request builder
- DeleteSnapshotRequestBuilder(ElasticsearchClient, DeleteSnapshotAction, 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, Version, ActionListener<RepositoryData>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- deleteSnapshots(Collection<SnapshotId>, long, Version, ActionListener<RepositoryData>) - Method in class org.elasticsearch.repositories.FilterRepository
- deleteSnapshots(Collection<SnapshotId>, long, Version, ActionListener<RepositoryData>) - Method in interface org.elasticsearch.repositories.Repository
-
Deletes snapshots
- deleteSnapshots(DeleteSnapshotRequest, ActionListener<Void>) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Deletes snapshots from the repository.
- deleteStoredScript(DeleteStoredScriptRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete a script from the cluster state
- deleteStoredScript(DeleteStoredScriptRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete a script from the cluster state
- deleteStoredScript(ClusterService, DeleteStoredScriptRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.script.ScriptService
- DeleteStoredScriptAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- DeleteStoredScriptRequest - Class in org.elasticsearch.action.admin.cluster.storedscripts
- DeleteStoredScriptRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- DeleteStoredScriptRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- DeleteStoredScriptRequestBuilder - Class in org.elasticsearch.action.admin.cluster.storedscripts
- DeleteStoredScriptRequestBuilder(ElasticsearchClient, DeleteStoredScriptAction) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequestBuilder
- deleteSubDirectories(Path...) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Deletes all subdirectories in the given path recursively
- deleteTempFiles() - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
- deleteTemplate(DeleteIndexTemplateRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deletes index template.
- deleteTemplate(DeleteIndexTemplateRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deletes an index template.
- deleteTombstone(String, 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.
- 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 - Static variable in class org.elasticsearch.index.mapper.Uid
- 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.
- Dependency<T> - Class in org.elasticsearch.common.inject.spi
-
A variable that can be resolved by an injector.
- deprecated() - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Deprecates the entire parameter.
- 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_LONG_TIMEZONES - Static variable in class org.elasticsearch.common.time.DateUtils
- DEPRECATED_PARAMETERS - Static variable in class org.elasticsearch.index.mapper.GeoShapeFieldMapper
- DEPRECATED_ROUTE_KEY - Static variable in class org.elasticsearch.rest.DeprecationRestHandler
- DEPRECATED_SHORT_TZ_IDS - Static variable in class org.elasticsearch.common.time.DateUtils
- DeprecatedMessage - Class in org.elasticsearch.common.logging
-
A logger message used by
DeprecationLogger
. - DeprecatedMessage(DeprecationCategory, String, String, String, String, Object...) - 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_MESSAGE - Static variable in class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
- 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 - Variable in class org.elasticsearch.index.AbstractIndexComponent
- 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) - Constructor for class org.elasticsearch.rest.DeprecationRestHandler
-
Create a
DeprecationRestHandler
that encapsulates thehandler
using thedeprecationLogger
to log deprecationwarning
. - 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
- derivative(String, String) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- Derivative - Interface in org.elasticsearch.search.aggregations.pipeline
- DerivativePipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- DerivativePipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- DerivativePipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
-
Read from a stream.
- DerivativePipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- DerivativePipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregator
-
Read from a stream.
- 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
- describeParams() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Describe the parameters that control how the "more like this" query is formed.
- describeTasks(List<? extends TaskBatcher.BatchedTask>) - Method in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
- describeTasks(List<ClusterStateUpdateTask>) - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
- describeTasks(List<LocalClusterUpdateTask>) - Method in class org.elasticsearch.cluster.LocalClusterUpdateTask
- 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_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
- deserialize(String, NamedXContentRegistry, InputStream) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- destination() - Method in class org.elasticsearch.index.reindex.ReindexRequestBuilder
- destination(String) - Method in class org.elasticsearch.index.reindex.ReindexRequestBuilder
-
Set the destination index.
- destination(String, String) - Method in class org.elasticsearch.index.reindex.ReindexRequestBuilder
-
Set the destination index and type.
- 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 class org.elasticsearch.rest.AbstractRestChannel
- detailedErrorsEnabled() - Method in interface org.elasticsearch.rest.RestChannel
- detailedMessage(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
-
Deprecated.Don't swallow exceptions, allow them to propagate.
- detect() - 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.
- DEVELOPMENT - Enum constant in enum class org.elasticsearch.common.inject.Stage
-
We want fast startup times at the expense of runtime performance and some up front error checking.
- 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_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- 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. - 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.
- DfsPhase() - Constructor for class org.elasticsearch.search.dfs.DfsPhase
- DfsPhaseExecutionException - Exception in org.elasticsearch.search.dfs
- DfsPhaseExecutionException(StreamInput) - Constructor for exception org.elasticsearch.search.dfs.DfsPhaseExecutionException
- DfsPhaseExecutionException(SearchShardTarget, String) - Constructor for exception org.elasticsearch.search.dfs.DfsPhaseExecutionException
- DfsPhaseExecutionException(SearchShardTarget, String, Throwable) - Constructor for exception org.elasticsearch.search.dfs.DfsPhaseExecutionException
- dfsResult() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- dfsResult() - Method in class org.elasticsearch.search.internal.SearchContext
- 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
- diff(String, String) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- diff(Map<K, T>, Map<K, T>, DiffableUtils.KeySerializer<K>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Calculates diff between two Maps of Diffable objects.
- diff(Map<K, T>, Map<K, T>, 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(ClusterState) - Method in class org.elasticsearch.cluster.ClusterState
- 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 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.upgrades.FeatureMigrationResults
- diff(RoutingTable) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- diff(ImmutableOpenIntMap<T>, ImmutableOpenIntMap<T>, DiffableUtils.KeySerializer<Integer>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Calculates diff between two ImmutableOpenIntMaps of Diffable objects
- diff(ImmutableOpenIntMap<T>, ImmutableOpenIntMap<T>, DiffableUtils.KeySerializer<Integer>, DiffableUtils.ValueSerializer<Integer, T>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Calculates diff between two ImmutableOpenIntMaps of non-diffable objects
- diff(ImmutableOpenMap<K, T>, ImmutableOpenMap<K, T>, DiffableUtils.KeySerializer<K>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Calculates diff between two ImmutableOpenMaps of Diffable objects
- diff(ImmutableOpenMap<K, T>, ImmutableOpenMap<K, T>, DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Calculates diff between two ImmutableOpenMaps of non-diffable objects
- 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.AbstractDiffable
- 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(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.ImmutableOpenMapDiff<K,
T> - Class in org.elasticsearch.cluster -
Represents differences between two ImmutableOpenMap of (possibly diffable) objects
- DiffableUtils.KeySerializer<K> - Interface in org.elasticsearch.cluster
-
Provides read and write operations to serialize keys of map
- DiffableUtils.MapDiff<K,
T, M> - 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.
- 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(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
- dimensionParam(Function<FieldMapper, Boolean>) - Static method in class org.elasticsearch.index.mapper.TimeSeriesParams
- DIRECT - Enum constant in enum class org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
- 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
- DirectSpellcheckerSettings - Class in org.elasticsearch.search.suggest
- DirectSpellcheckerSettings() - Constructor for class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- disableCache() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Marks this context as not cacheable.
- disabled() - Static method in class org.elasticsearch.http.CorsHandler
- DisabledQueryCache - Class in org.elasticsearch.index.cache.query
- DisabledQueryCache(IndexSettings) - Constructor for class org.elasticsearch.index.cache.query.DisabledQueryCache
- DisableGraphAttribute - Interface in org.apache.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.apache.lucene.analysis.miscellaneous
-
Default implementation of
DisableGraphAttribute
. - DisableGraphAttributeImpl() - Constructor for class org.apache.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.
- DiscardedResponsesException(Exception) - Constructor for exception org.elasticsearch.action.support.NodeResponseTracker.DiscardedResponsesException
- discardIntermediateResponses(Exception) - Method in class org.elasticsearch.action.support.NodeResponseTracker
-
This method discards the results collected so far to free up the resources.
- 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 - Interface in org.elasticsearch.discovery
-
A pluggable module allowing to implement discovery of other nodes, publishing of the cluster state to all nodes, electing a master of the cluster that raises cluster state change events.
- DISCOVERY - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- DISCOVERY_CLUSTER_FORMATION_WARNING_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.ClusterFormationFailureHelper
- DISCOVERY_FIND_PEERS_INTERVAL_SETTING - Static variable in class org.elasticsearch.discovery.PeerFinder
- DISCOVERY_JOIN_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.MembershipAction
- DISCOVERY_JOIN_VALIDATE_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.MembershipAction
- DISCOVERY_LEAVE_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.MembershipAction
- DISCOVERY_REJOIN_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- 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_TYPE_SETTING - Static variable in class org.elasticsearch.discovery.DiscoveryModule
- DISCOVERY_ZEN_MINIMUM_MASTER_NODES_SETTING - Static variable in class org.elasticsearch.discovery.zen.ElectMasterService
- 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, ThreadPool, BigArrays, TransportService, Client, NamedWriteableRegistry, NetworkService, MasterService, ClusterApplier, ClusterSettings, List<DiscoveryPlugin>, AllocationService, Path, GatewayMetaState, RerouteService, NodeHealthService) - 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>, Version) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
-
Creates a new
DiscoveryNode
. - DiscoveryNode(String, String, TransportAddress, Map<String, String>, Set<DiscoveryNodeRole>, Version) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
-
Creates a new
DiscoveryNode
- DiscoveryNode(String, TransportAddress, Map<String, String>, Set<DiscoveryNodeRole>, Version) - Constructor for class org.elasticsearch.cluster.node.DiscoveryNode
-
Creates a new
DiscoveryNode
- DiscoveryNode(String, TransportAddress, Version) - 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. - DiscoverySettings - Class in org.elasticsearch.discovery
-
Exposes common discovery settings that may be supported by all the different discovery implementations
- DiscoverySettings(Settings, ClusterSettings) - Constructor for class org.elasticsearch.discovery.DiscoverySettings
- DiscoveryStats - Class in org.elasticsearch.discovery
- DiscoveryStats(StreamInput) - Constructor for class org.elasticsearch.discovery.DiscoveryStats
- DiscoveryStats(PendingClusterStateStats, PublishClusterStateStats, ClusterStateUpdateStats, ClusterApplierRecordingService.Stats) - Constructor for class org.elasticsearch.discovery.DiscoveryStats
- DiscoveryUpgradeService - Class in org.elasticsearch.cluster.coordination
-
Deals with rolling upgrades of the cluster coordination layer.
- DiscoveryUpgradeService(Settings, TransportService, BooleanSupplier, JoinHelper, Supplier<Iterable<DiscoveryNode>>, Consumer<CoordinationMetadata.VotingConfiguration>) - Constructor for class org.elasticsearch.cluster.coordination.DiscoveryUpgradeService
- 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
- 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
- DiskUsage - 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 class org.elasticsearch.cluster.DiskUsage
-
Create a new DiskUsage, if
totalBytes
is 0,DiskUsage.getFreeDiskAsPercentage()
will always return 100.0% free - DiskUsage(StreamInput) - Constructor for class org.elasticsearch.cluster.DiskUsage
- dismaxBlendedQuery(Term[], float) - Static method in class org.apache.lucene.queries.BlendedTermQuery
- dismaxBlendedQuery(Term[], float[], float) - Static method in class org.apache.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
- DispatchingRestToXContentListener<Response extends StatusToXContentObject> - Class in org.elasticsearch.rest.action
-
Response listener for REST requests which dispatches the serialization of the response off of the thread on which the response was received, since that thread is often a transport thread and XContent serialization might be expensive.
- DispatchingRestToXContentListener(ExecutorService, RestChannel, RestRequest) - Constructor for class org.elasticsearch.rest.action.DispatchingRestToXContentListener
- 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.Flavor
- displayName() - Method in enum class org.elasticsearch.Build.Type
- 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(String, float, long, TimeValue) - Method in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
- 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() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- 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. - 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. - DO_NOT_FETCH_SOURCE - Static variable in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- 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.adjacency.AdjacencyMatrixAggregationBuilder
- 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.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 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 interface org.elasticsearch.search.LeafNestedDocuments
-
The current doc
- doc() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
- 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(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_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.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.mapper.TypeParsers
- DOC_VALUES - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- 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.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.SafeCommitInfo
- 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.terms.InternalRareTerms.Bucket
- docCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- docCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- docCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- docCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms.ParsedBucket
- docCountErrorUpperBound - Variable in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- 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
- doCheckAndNotify() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Will be called periodically
- doCheckAndNotify() - Method in class org.elasticsearch.watcher.FileWatcher
- 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.search.fetch.FetchSubPhase.HitContext
- docId() - Method in class org.elasticsearch.search.lookup.SourceLookup
- docId() - Method in class org.elasticsearch.search.SearchHit
- 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
- 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
- docIdsSize() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- docIdsToLoad() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- docIdsToLoad() - Method in class org.elasticsearch.search.internal.SearchContext
- docIdsToLoad() - Method in class org.elasticsearch.search.internal.SubSearchContext
- docIdsToLoad(int[], int) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- docIdsToLoad(int[], int) - Method in class org.elasticsearch.search.internal.SearchContext
- docIdsToLoad(int[], int) - Method in class org.elasticsearch.search.internal.SubSearchContext
- docIdsToLoadSize() - Method in class org.elasticsearch.search.internal.SearchContext
- docIdsToLoadSize() - Method in class org.elasticsearch.search.internal.SubSearchContext
- DOCKER - Enum constant in enum class org.elasticsearch.Build.Type
- 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.component.AbstractLifecycleComponent
- doClose() - Method in class org.elasticsearch.discovery.SeedHostsResolver
- doClose() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- doClose() - Method in class org.elasticsearch.gateway.GatewayService
- 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.MonitorService
- doClose() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- doClose() - Method in class org.elasticsearch.repositories.RepositoriesService
- 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.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
- 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.AutoDateHistogramAggregatorFactory
- 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.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.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.DocumentParserContext
- docs() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- 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
- 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(MultiGeoPointValues) - 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. - 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.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
- 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(StreamInput) - Constructor for class org.elasticsearch.common.document.DocumentField
- 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(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
Return the
DocumentMapper
for the given type. - 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, 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, IndexSettings, IndexAnalyzers, Function<DateFormatter, MappingParserContext>, SourceToParse) - Constructor for class org.elasticsearch.index.mapper.DocumentParserContext
- DocumentSourceMissingException - Exception in org.elasticsearch.index.engine
- DocumentSourceMissingException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.DocumentSourceMissingException
- DocumentSourceMissingException(ShardId, String, 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.MultiGeoPointValues
-
Return the number of geo points the current document has.
- 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
- 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
- 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.aggregations.metrics.TopHitsAggregationBuilder
-
Gets the field-data fields.
- 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 - 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.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.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.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
- 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(FetchDocValuesContext) - Method in class org.elasticsearch.search.internal.SearchContext
- docValuesContext(FetchDocValuesContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
- 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
- DocValuesField - Interface in org.elasticsearch.script.field
- docValuesOnly(String, NumberFieldMapper.NumberType) - Static method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- docValuesParam(Function<FieldMapper, Boolean>, boolean) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- 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
- 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
IndexAction
and BwC deserialization path - DocWriteResponse(ShardId, String, 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(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
-
Deprecated.
- 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(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(TypeQueryBuilder) - Method in class org.elasticsearch.index.query.TypeQueryBuilder
- 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(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(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.FilterClient
- doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.node.NodeClient
- doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.OriginSettingClient
- doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.ParentTaskAssigningClient
- doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.support.AbstractClient
- doExecute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- 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, NodesReloadSecureSettingsRequest, ActionListener<NodesReloadSecureSettingsResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction
- doExecute(Task, GetTaskRequest, ActionListener<GetTaskResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.TransportGetTaskAction
- doExecute(Task, RemoteInfoRequest, ActionListener<RemoteInfoResponse>) - Method in class org.elasticsearch.action.admin.cluster.remote.TransportRemoteInfoAction
- 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, SyncedFlushRequest, ActionListener<SyncedFlushResponse>) - Method in class org.elasticsearch.action.admin.indices.flush.TransportSyncedFlushAction
- 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, ResolveIndexAction.Request, ActionListener<ResolveIndexAction.Response>) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.TransportAction
- doExecute(Task, UpgradeRequest, ActionListener<UpgradeResponse>) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
- 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.TransportBulkAction
- 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, SimulatePipelineRequest, ActionListener<SimulatePipelineResponse>) - Method in class org.elasticsearch.action.ingest.SimulatePipelineTransportAction
- doExecute(Task, MainRequest, ActionListener<MainResponse>) - Method in class org.elasticsearch.action.main.TransportMainAction
- 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, 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, 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, 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.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.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, TasksRequest, ActionListener<TasksResponse>) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- 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
-
Deprecated.
- 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.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.TypeQueryBuilder
- 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.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
- doInit() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Will be called once on initialization
- doInit() - Method in class org.elasticsearch.watcher.FileWatcher
- doInternalExecute(Task, BulkRequest, String, ActionListener<BulkResponse>) - Method in class org.elasticsearch.action.bulk.TransportBulkAction
- 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(ObjectMapper, MapperService.MergeReason) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- doMerge(ObjectMapper, MapperService.MergeReason) - Method in class org.elasticsearch.index.mapper.RootObjectMapper
- done() - Method in class org.elasticsearch.repositories.GetSnapshotInfoContext
- done(boolean) - Method in class org.elasticsearch.action.support.ListenableActionFuture
- done(boolean) - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
-
Called when the
BaseFuture
is completed. - done(boolean) - Method in class org.elasticsearch.common.util.concurrent.ListenableFuture
- 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
- 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.bucket.composite.CompositeAggregator
- doPostCollection() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
- doPostCollection() - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- doPostCollection() - Method in class org.elasticsearch.search.aggregations.metrics.GlobalOrdCardinalityAggregator
- 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
- doPredict(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- doPredict(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
-
Predicts the next `n` values in the series, using the smoothing model to generate new values.
- doPredict(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
-
Predicts the next `n` values in the series, using the smoothing model to generate new values.
- doPredict(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel
- doPredict(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
-
Calls to the model-specific implementation which actually generates the predictions
- doPredict(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel
- doReduce(Aggregations, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregator
- doReduce(Aggregations, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.SiblingPipelineAggregator
- 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.ExistsQueryBuilder
- 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.MatchPhraseQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
- 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.PrefixQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.TermQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- doRewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- 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.adjacency.AdjacencyMatrixAggregationBuilder
- 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
- doRun() - Method in class org.elasticsearch.common.util.concurrent.AbstractLifecycleRunnable
-
This method has the same semantics as
Runnable.run()
- 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
- doRunInLifecycle() - Method in class org.elasticsearch.common.util.concurrent.AbstractLifecycleRunnable
-
Perform runnable logic, but only if the
AbstractLifecycleRunnable.lifecycle
is not stopped or closed. - doSetNextReader(LeafReaderContext) - Method in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
- doSetNextReader(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.MinimumScoreCollector
- 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
- doStart() - Method in class org.elasticsearch.discovery.SeedHostsResolver
- doStart() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- doStart() - Method in class org.elasticsearch.gateway.GatewayService
- 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.MonitorService
- doStart() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- doStart() - Method in class org.elasticsearch.repositories.RepositoriesService
- 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
- doStop() - Method in class org.elasticsearch.discovery.SeedHostsResolver
- doStop() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- doStop() - Method in class org.elasticsearch.gateway.GatewayService
- doStop() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- 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.MonitorService
- doStop() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- doStop() - Method in class org.elasticsearch.repositories.RepositoriesService
- 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
- 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
-
Deprecated.
- 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.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.TypeQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- doToQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- 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
- DoubleArray - Interface in org.elasticsearch.common.util
-
Abstraction of an array of double values.
- 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.
- 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, 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
- doubleParam(String, boolean, Function<FieldMapper, Double>, double) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Defines a parameter that takes a double value
- doubleRangeQuery(Object, Object, boolean, boolean, BiFunction<Double, Double, Query>) - Static method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- Doubles(SortedNumericDoubleValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- 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, LongSet) - 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
- 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.
- doubleToBytes(double) - Static method in class org.elasticsearch.common.Numbers
-
Converts a double to a byte array.
- 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.GeoHashCellIdSource
- doubleValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileCellIdSource
- 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
- doValidate() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
- 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
- doWrapDirectoryReader(DirectoryReader) - Method in class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper
- doWrapDirectoryReader(DirectoryReader) - Method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
- 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
-
Deprecated.
- 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.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.TypeQueryBuilder
- 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.adjacency.AdjacencyMatrixAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- 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.InternalAutoDateHistogram
- 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.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.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.InternalCardinality
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalMax
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalMedianAbsoluteDeviation
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalMin
- 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.InternalSum
- 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.ScriptedMetricAggregationBuilder
- 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.BucketMetricsPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalBucketMetricValue
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalDerivative
- 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
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregator
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
-
Deprecated.pipeline aggregations added after 7.8.0 don't need to implement this
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
- doWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregator
- 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.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
- 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.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
-
Deprecated.
- 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.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.TypeQueryBuilder
- 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.rescore.QueryRescorerBuilder
- doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- 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.adjacency.InternalAdjacencyMatrix
- 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.ParsedComposite
- 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.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.AutoDateHistogramAggregationBuilder
- 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.InternalAutoDateHistogram
- 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.ParsedAutoDateHistogram
- 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.ParsedSingleBucketAggregation
- 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.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.ParsedRareTerms
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- 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.InternalCardinality
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalMax
- 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.InternalMin
- 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.InternalSum
- 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.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.MinAggregationBuilder
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedAvg
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedCardinality
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedGeoBounds
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedGeoCentroid
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedMax
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedMedianAbsoluteDeviation
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedMin
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedPercentiles
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedScriptedMetric
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedSum
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTopHits
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedValueCount
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedWeightedAvg
- 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.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.ParsedAggregation
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation
- 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.InternalDerivative
- 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.ParsedBucketMetricValue
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedDerivative
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedPercentilesBucket
- doXContentBody(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedSimpleValue
- 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(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
- 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) - Method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- 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.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
- duplicateBindingAnnotations(Member, Class<? extends Annotation>, Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.Errors
- DuplicateByteSequenceSpotter - Class in org.apache.lucene.analysis.miscellaneous
-
A Trie structure for analysing byte streams for duplicate sequences.
- DuplicateByteSequenceSpotter() - Constructor for class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
- duplicateScopeAnnotations(Class<? extends Annotation>, Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.Errors
- duplicateScopes(Scope, Class<? extends Annotation>, Scope) - Method in class org.elasticsearch.common.inject.internal.Errors
- DuplicateSequenceAttribute - Interface in org.apache.lucene.analysis.miscellaneous
-
Provides statistics useful for detecting duplicate sections of text
- DuplicateSequenceAttributeImpl - Class in org.apache.lucene.analysis.miscellaneous
- DuplicateSequenceAttributeImpl() - Constructor for class org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- DURATION - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.SortBy
- 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
- 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.ObjectMapper
- 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_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
- 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.common.inject.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
- EarlyTerminatingCollector - Class in org.elasticsearch.search.query
-
A
Collector
that early terminates collection aftermaxCountHits
docs have been collected. - EARTH_AXIS_RATIO - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Earth axis ratio defined by WGS 84 (0.996647189335)
- 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
- ELASTIC_ORIGIN_FIELD_NAME - Static variable in class org.elasticsearch.common.logging.DeprecatedMessage
- ELASTICSEARCH - Enum constant in enum class org.elasticsearch.indices.analysis.PreBuiltCacheFactory.CachingStrategy
- ElasticsearchClient - Interface in org.elasticsearch.client
- 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.
- ElasticsearchMergePolicy - Class in org.elasticsearch.index.shard
-
A
MergePolicy
that upgrades segments and can upgrade merges. - ElasticsearchMergePolicy(MergePolicy) - Constructor for class org.elasticsearch.index.shard.ElasticsearchMergePolicy
- 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 - 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
- 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
- elasticsearchVersion(String, boolean, boolean, BiFunction<TokenStream, Version, TokenStream>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredTokenFilter
-
Create a pre-configured token filter that may vary based on the Elasticsearch version.
- elasticsearchVersion(String, boolean, BiFunction<Reader, Version, Reader>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredCharFilter
-
Create a pre-configured token filter that may vary based on the Elasticsearch version.
- elasticsearchVersion(String, boolean, BiFunction<TokenStream, Version, TokenStream>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredTokenFilter
-
Create a pre-configured token filter that may vary based on the Elasticsearch version.
- elasticsearchVersion(String, Function<Version, Tokenizer>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredTokenizer
-
Create a pre-configured tokenizer that may vary based on the Elasticsearch version.
- 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
- electionWon() - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- electMaster(Collection<ElectMasterService.MasterCandidate>) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
-
Elects a new master out of the possible nodes, returning it.
- ElectMasterService - Class in org.elasticsearch.discovery.zen
- ElectMasterService(Settings) - Constructor for class org.elasticsearch.discovery.zen.ElectMasterService
- ElectMasterService.MasterCandidate - Class in org.elasticsearch.discovery.zen
-
a class to encapsulate all the information about a candidate in a master election that is needed to decided which of the candidates should win
- element() - Method in class org.elasticsearch.common.collect.EvictingQueue
- Element - Interface in org.elasticsearch.common.inject.spi
-
A core component of a module or injector.
- elements - Variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- elements - Variable in class org.elasticsearch.search.profile.AbstractInternalProfileTree
-
A list of the original queries, keyed by index position
- Elements - Class in org.elasticsearch.common.inject.spi
-
Exposes elements of a module so they can be inspected, validated or
rewritten
. - Elements() - Constructor for class org.elasticsearch.common.inject.spi.Elements
- ElementVisitor<V> - Interface in org.elasticsearch.common.inject.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(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(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.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.StringFieldScript
- emitFromSource() - Method in class org.elasticsearch.script.AbstractFieldScript
- EmitMap(CompositeFieldScript) - Constructor for class org.elasticsearch.script.CompositeFieldScript.EmitMap
- emitTypesDeprecationWarning() - Static method in class org.elasticsearch.index.mapper.TypeFieldMapper
- empty() - Static method in class org.elasticsearch.cluster.metadata.Manifest
- empty() - Static method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- empty() - Method in class org.elasticsearch.gateway.PersistedClusterStateService.OnDiskState
- empty() - Static method in class org.elasticsearch.index.fielddata.plain.AbstractLeafOrdinalsFieldData
- 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.search.internal.InternalSearchResponse
- empty() - Static method in class org.elasticsearch.search.SearchHits
- empty(boolean) - Static method in class org.elasticsearch.search.internal.InternalSearchResponse
- empty(boolean) - Static method in class org.elasticsearch.search.SearchHits
- empty(int) - Static method in class org.elasticsearch.index.fielddata.plain.AbstractLeafGeoPointFieldData
- empty(int) - Static method in class org.elasticsearch.index.fielddata.plain.LeafDoubleFieldData
- Empty() - Constructor for class org.elasticsearch.action.ActionResponse.Empty
- Empty() - Constructor for class org.elasticsearch.transport.TransportRequest.Empty
- Empty() - Constructor for class org.elasticsearch.transport.TransportResponse.Empty
- Empty() - Constructor for class org.elasticsearch.transport.TransportResponseHandler.Empty
- Empty(StreamInput) - Constructor for class org.elasticsearch.transport.TransportRequest.Empty
- EMPTY - Enum constant in enum class org.elasticsearch.index.query.RegexpFlag
-
Enables empty language expression:
#
- EMPTY - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotResponse
- EMPTY - Static variable in class org.elasticsearch.action.search.SearchResponse.Clusters
- EMPTY - Static variable in class org.elasticsearch.action.support.broadcast.BroadcastResponse
- EMPTY - Static variable in class org.elasticsearch.action.support.replication.ReplicationResponse
- EMPTY - Static variable in class org.elasticsearch.cluster.ClusterInfo
- EMPTY - Static variable in class org.elasticsearch.cluster.ClusterInfo.ReservedSpace
- EMPTY - Static variable in class org.elasticsearch.cluster.coordination.ClusterStateSerializationStats
- EMPTY - Static variable in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- 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.MappingMetadata.Routing
- 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 class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- EMPTY - Static variable in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- EMPTY - Static variable in class org.elasticsearch.cluster.SnapshotsInProgress
- EMPTY - Static variable in class org.elasticsearch.common.blobstore.BlobPath
- EMPTY - Static variable in class org.elasticsearch.common.bytes.BytesArray
- EMPTY - Static variable in class org.elasticsearch.common.settings.Settings
- EMPTY - Static variable in 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 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 class org.elasticsearch.index.store.Store.MetadataSnapshot
- EMPTY - Static variable in interface org.elasticsearch.index.store.Store.OnClose
- EMPTY - Static variable in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan.SnapshotFilesToRecover
- 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 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.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.SnapshotShardSizeInfo
- 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_METADATA - Static variable in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- EMPTY_METADATA - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- EMPTY_MODULE - Static variable in class org.elasticsearch.common.inject.util.Modules
- 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_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.cluster.ClusterState
- 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.common.inject.internal.MoreTypes
- 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
- EmptyField - Class in org.elasticsearch.script.field
-
Script field with no mapping, always returns
defaultValue
. - EmptyField(String) - Constructor for class org.elasticsearch.script.field.EmptyField
- emptyGeoPoint() - Static method in enum class org.elasticsearch.index.fielddata.FieldData
- emptyMultiGeoPoints() - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Return a
SortedNumericDoubleValues
that doesn't contain any value. - emptyNumericDouble() - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Return a
NumericDoubleValues
that doesn't contain any value. - emptyPredictions(int) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
-
Returns an empty set of predictions, filled with NaNs
- emptyReader(int) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Returns an empty leaf reader with the given max docs.
- emptySeqID() - Static method in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SequenceIDFields
- 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
- EmptyTransportResponseHandler - Class in org.elasticsearch.transport
- EmptyTransportResponseHandler(String) - Constructor for class org.elasticsearch.transport.EmptyTransportResponseHandler
- ENABLE_FOR_SINGLE_DATA_NODE - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
- 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_REMOTE_CLUSTERS - Static variable in class org.elasticsearch.transport.RemoteClusterService
-
If
true
connecting to remote clusters is supported on this node. - ENABLE_REWRITE_AGGS_TO_FILTER_BY_FILTER - Static variable in class org.elasticsearch.search.SearchService
- ENABLE_UNSAFE_BOOTSTRAPPING_ON_UPGRADE_SETTING - Static variable in class org.elasticsearch.cluster.coordination.DiscoveryUpgradeService
- 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(Settings, 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 class org.elasticsearch.index.mapper.SourceFieldMapper
- enabled(boolean) - Method in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- ENABLED - Static variable in class org.elasticsearch.Assertions
- 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.index.mapper.SourceFieldMapper.Defaults
- ENABLED - Static variable in class org.elasticsearch.watcher.ResourceWatcherService
- ENABLED_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- 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. - 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(List<SearchPhaseResult>, Map<String, AliasFilter>, Version) - Static method in class org.elasticsearch.action.search.SearchContextId
- encode(LogEvent, ByteBufferDestination) - Method in class org.elasticsearch.common.logging.ESJsonLayout
- encodeId(String) - Static method in class org.elasticsearch.index.mapper.Uid
-
Encode an id for storage in the index.
- encodeLatLon(double, double) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- encoder() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Getter for
HighlightBuilder.encoder(String)
- encoder() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- encoder(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Set encoder for the highlighting are
html
anddefault
. - 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
- 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
- endHeaders() - Method in class org.elasticsearch.common.Table
- endRow() - Method in class org.elasticsearch.common.Table
- endRow(boolean) - Method in class org.elasticsearch.common.Table
- 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 interface org.elasticsearch.repositories.Repository
-
Called at the end of repository verification process.
- 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.CommitId - Class in org.elasticsearch.index.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.Get - Class in org.elasticsearch.index.engine
- Engine.GetResult - Class in org.elasticsearch.index.engine
- Engine.HistorySource - Enum Class in org.elasticsearch.index.engine
-
Whether we should read history operations from translog or Lucene index
- Engine.Index - Class 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
- Engine.NoOpResult - Class in org.elasticsearch.index.engine
- Engine.Operation - Class in org.elasticsearch.index.engine
- Engine.Operation.Origin - Enum Class in org.elasticsearch.index.engine
- Engine.Operation.TYPE - Enum Class in org.elasticsearch.index.engine
-
type of operation (index, delete), subclasses use static types
- Engine.Result - Class in org.elasticsearch.index.engine
-
Base class for index and delete operation results Holds result meta data (e.g.
- Engine.Result.Type - Enum Class in org.elasticsearch.index.engine
- Engine.Searcher - Class in org.elasticsearch.index.engine
- Engine.SearcherScope - Enum Class in org.elasticsearch.index.engine
- Engine.SearcherSupplier - Class in org.elasticsearch.index.engine
- Engine.SyncedFlushResult - Enum Class in org.elasticsearch.index.engine
- Engine.TranslogRecoveryRunner - Interface in org.elasticsearch.index.engine
- Engine.Warmer - Interface in org.elasticsearch.index.engine
-
Called for each new opened engine reader to warm new segments
- engineConfig - Variable in class org.elasticsearch.index.engine.Engine
- EngineConfig - Class in org.elasticsearch.index.engine
- EngineConfig(ShardId, ThreadPool, IndexSettings, Engine.Warmer, Store, MergePolicy, Analyzer, Similarity, CodecService, Engine.EventListener, QueryCache, QueryCachingPolicy, TranslogConfig, TimeValue, List<ReferenceManager.RefreshListener>, List<ReferenceManager.RefreshListener>, Sort, CircuitBreakerService, LongSupplier, Supplier<RetentionLeases>, LongSupplier, IndexStorePlugin.SnapshotCommitSupplier, Comparator<LeafReader>) - Constructor for class org.elasticsearch.index.engine.EngineConfig
-
Creates a new
EngineConfig
- EngineCreationFailureException - Exception in org.elasticsearch.index.engine
-
An exception indicating that an
Engine
creation failed. - EngineCreationFailureException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.EngineCreationFailureException
- EngineCreationFailureException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.engine.EngineCreationFailureException
- EngineException - Exception in org.elasticsearch.index.engine
- EngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.EngineException
- EngineException(ShardId, String, Object...) - Constructor for exception org.elasticsearch.index.engine.EngineException
- EngineException(ShardId, String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.engine.EngineException
- EngineFactory - Interface in org.elasticsearch.index.engine
-
Simple Engine Factory
- EnginePlugin - Interface in org.elasticsearch.plugins
-
A plugin that provides alternative engine implementations.
- engines - Variable in class org.elasticsearch.script.ScriptModule
- enoughShardsActive(int) - Method in class org.elasticsearch.action.support.ActiveShardCount
-
Returns true iff the given number of active shards is enough to meet the required shard count represented by this instance.
- enoughShardsActive(ClusterState, String...) - Method in class org.elasticsearch.action.support.ActiveShardCount
-
Returns true iff the given cluster state's routing table contains enough active shards for the given indices to meet the required shard count represented by this instance.
- enoughShardsActive(IndexShardRoutingTable) - Method in class org.elasticsearch.action.support.ActiveShardCount
-
Returns true iff the active shard count in the shard routing table is enough to meet the required shard count represented by this instance.
- ensureCanReadBytes(int) - Method in class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- ensureCanReadBytes(int) - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- ensureCanReadBytes(int) - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- ensureCanReadBytes(int) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- ensureCanReadBytes(int) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
This method throws an
EOFException
if the given number of bytes can not be read from the this stream. - ensureCapacity(long) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- ensureExpectedToken(XContentParser.Token, XContentParser.Token, XContentParser) - Static method in class org.elasticsearch.common.xcontent.XContentParserUtils
-
Makes sure that provided token is of the expected type
- ensureFieldName(XContentParser, XContentParser.Token, String) - Static method in class org.elasticsearch.common.xcontent.XContentParserUtils
-
Makes sure that current token is of type
XContentParser.Token.FIELD_NAME
and the field name is equal to the provided one - ensureIndexCompatibility(Version, Metadata) - Static method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor
-
Ensures that all indices are compatible with the given node version.
- ensureIndexHasHistoryUUID() - Method in class org.elasticsearch.index.store.Store
-
Checks that the Lucene index contains a history uuid marker.
- ensureMaxSeqNoEqualsToGlobalCheckpoint(SeqNoStats) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- ensureNodesCompatibility(Version, DiscoveryNodes) - Static method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor
-
ensures that the joining node has a version that's compatible with all current nodes
- ensureNodesCompatibility(Version, Version, Version) - Static method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor
-
ensures that the joining node has a version that's compatible with a given version range
- ensureNoNullKeys(int, float) - Static method in class org.elasticsearch.common.collect.HppcMaps.Object.Integer
- ensureNoSelfReferences(Object, String) - Static method in class org.elasticsearch.common.util.CollectionUtils
-
Deeply inspects a Map, Iterable, or Object array looking for references back to itself.
- ensureNotCancelled() - Method in class org.elasticsearch.tasks.CancellableTask
-
Throws a
TaskCancelledException
if this task has been cancelled, otherwise does nothing. - ensureOpen() - Method in class org.elasticsearch.action.bulk.BulkProcessor
- ensureOpen() - Method in class org.elasticsearch.action.bulk.BulkProcessor2
- ensureOpen() - Method in class org.elasticsearch.index.engine.Engine
- ensureOpen() - Method in class org.elasticsearch.index.translog.TranslogReader
- ensureOpen() - Method in class org.elasticsearch.index.translog.TranslogWriter
- ensureOpen() - Method in class org.elasticsearch.rest.action.RestActionListener
- ensureOpen(Exception) - Method in class org.elasticsearch.index.engine.Engine
- ensureRepositoryExists(String, ClusterState) - Static method in class org.elasticsearch.snapshots.SnapshotsService
-
Throws
RepositoryMissingException
if no repository by the given name is found in the given cluster state. - ensureSynced(Stream<Translog.Location>) - Method in class org.elasticsearch.index.translog.Translog
-
Ensures that all locations in the given stream have been synced / written to the underlying storage.
- ensureSynced(Translog.Location) - Method in class org.elasticsearch.index.translog.Translog
-
Ensures that the given location has be synced / written to the underlying storage.
- ensureTranslogSynced(Stream<Translog.Location>) - Method in class org.elasticsearch.index.engine.Engine
-
Ensures that all locations in the given stream have been written to the underlying storage.
- ensureTranslogSynced(Stream<Translog.Location>) - Method in class org.elasticsearch.index.engine.InternalEngine
- ensureTranslogSynced(Stream<Translog.Location>) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- ensureValidity() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- ensureVersionBarrier(Version, Version) - Static method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor
-
ensures that the joining node's version is equal or higher to the minClusterNodeVersion.
- entries - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion
- entries() - Method in class org.elasticsearch.cluster.RepositoryCleanupInProgress
- entriesByRepo() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- Entry() - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- Entry(Class<T>, String, Writeable.Reader<? extends T>) - Constructor for class org.elasticsearch.common.io.stream.NamedWriteableRegistry.Entry
-
Creates a new entry which can be stored by the registry.
- Entry(String, long) - Constructor for class org.elasticsearch.cluster.RepositoryCleanupInProgress.Entry
- Entry(String, Snapshot, RestoreInProgress.State, List<String>, ImmutableOpenMap<ShardId, RestoreInProgress.ShardRestoreStatus>) - Constructor for class org.elasticsearch.cluster.RestoreInProgress.Entry
-
Creates new restore metadata
- Entry(List<SnapshotId>, String, long, long, SnapshotDeletionsInProgress.State) - Constructor for class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- Entry(SnapshotsInProgress.Entry, SnapshotsInProgress.State, Map<String, IndexId>, long, ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>, Version, String) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- Entry(StreamInput) - Constructor for class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- Entry(StreamInput) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry
- Entry(StreamInput) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- Entry(StreamInput) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- Entry(StreamInput) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion.Entry
- Entry(Text, int, int) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry
- Entry(Text, int, int) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- Entry(Text, int, int) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- Entry(Text, int, int) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion.Entry
- Entry(Text, int, int, double) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- Entry(Snapshot, boolean, boolean, SnapshotsInProgress.State, Map<String, IndexId>, List<String>, long, long, ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>, Map<String, Object>, Version) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- Entry(Snapshot, boolean, boolean, SnapshotsInProgress.State, Map<String, IndexId>, List<String>, List<SnapshotFeatureInfo>, long, long, ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>, String, Map<String, Object>, Version) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- entrySet() - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap
- entrySet() - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
- entrySet() - Method in class org.elasticsearch.common.util.LazyMap
- entrySet() - Method in class org.elasticsearch.script.DynamicMap
- entrySet() - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- entrySet() - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- entrySet() - Method in class org.elasticsearch.search.lookup.SourceLookup
- enumParam(String, boolean, Function<FieldMapper, T>, T, Class<T>) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Defines a parameter that takes any of the values of an enumeration.
- enumSetting(Class<T>, String, Setting<T>, Setting.Validator<T>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
-
Creates a setting where the allowed values are defined as enum constants.
- enumSetting(Class<T>, String, T, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
-
Creates a setting where the allowed values are defined as enum constants.
- env - Variable in class org.elasticsearch.ingest.Processor.Parameters
-
Useful to provide access to the node's environment like config directory to processor factories.
- environment() - Method in class org.elasticsearch.bootstrap.BootstrapContext
- Environment - Class in org.elasticsearch.env
-
The environment of where things exists.
- Environment(Settings, Path) - Constructor for class org.elasticsearch.env.Environment
- Environment(Settings, Path, boolean) - Constructor for class org.elasticsearch.env.Environment
- EnvironmentAwareCommand - Class in org.elasticsearch.cli
-
A cli command which requires an
Environment
to use current paths and settings. - EnvironmentAwareCommand(String) - Constructor for class org.elasticsearch.cli.EnvironmentAwareCommand
-
Construct the command with the specified command description.
- EnvironmentAwareCommand(String, Runnable) - Constructor for class org.elasticsearch.cli.EnvironmentAwareCommand
-
Construct the command with the specified command description and runnable to execute before main is invoked.
- ephemeralId - Variable in class org.elasticsearch.repositories.RepositoryInfo
- EPOCH - Static variable in class org.elasticsearch.common.Table
- EPOCH_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- EPOCH_SECOND - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- EpochTimeParser(boolean) - Constructor for class org.elasticsearch.common.joda.Joda.EpochTimeParser
-
Deprecated.
- EpochTimePrinter(boolean) - Constructor for class org.elasticsearch.common.joda.Joda.EpochTimePrinter
-
Deprecated.
- equals(long, AbstractHyperLogLogPlusPlus, long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
- equals(Object) - Method in class org.apache.lucene.queries.BinaryDocValuesRangeQuery
- equals(Object) - Method in class org.apache.lucene.queries.BlendedTermQuery
- equals(Object) - Method in class org.apache.lucene.queries.MinDocQuery
- equals(Object) - Method in class org.apache.lucene.queries.SearchAfterSortedDocQuery
- equals(Object) - Method in class org.apache.lucene.queries.SpanMatchNoDocsQuery
- equals(Object) - Method in class org.elasticsearch.action.ActionType
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.FeatureUpgradeStatus
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.IndexInfo
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse
-
We disregard exceptions when determining response equality
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse.Feature
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse.NodeResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse.SnapshottableFeature
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus
-
Without a convenient way to compare Exception equality, we consider only feature name and success or failure for equality.
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotRequest
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmVersion
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.stats.FieldScriptStats
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.stats.FieldStats
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.stats.IndexFeatureStats
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.stats.MappingStats
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.stats.RuntimeFieldStats
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.stats.VersionStats
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptContextResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptLanguageResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeToken
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeTokenList
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.CharFilteredText
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.DetailAnalyzeResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Response
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetadata
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Request
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedAlias
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedDataStream
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedIndex
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Response
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.rollover.Condition
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteComposableIndexTemplateAction.Request
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Response
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Request
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Response
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateRequest
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateResponse
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction.Request
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
- equals(Object) - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- equals(Object) - Method in class org.elasticsearch.action.datastreams.ModifyDataStreamsAction.Request
- equals(Object) - Method in class org.elasticsearch.action.explain.ExplainResponse
- equals(Object) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
- equals(Object) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexResponse
- equals(Object) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- equals(Object) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
- equals(Object) - Method in class org.elasticsearch.action.fieldcaps.IndexFieldCapabilities
- equals(Object) - Method in class org.elasticsearch.action.get.GetResponse
- equals(Object) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- equals(Object) - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- equals(Object) - Method in class org.elasticsearch.action.main.MainResponse
- equals(Object) - Method in class org.elasticsearch.action.OriginalIndices
- equals(Object) - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- equals(Object) - Method in class org.elasticsearch.action.search.MultiSearchRequest
- equals(Object) - Method in class org.elasticsearch.action.search.SearchRequest
- equals(Object) - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
- equals(Object) - Method in class org.elasticsearch.action.search.SearchScrollRequest
- equals(Object) - Method in class org.elasticsearch.action.search.SearchShard
- equals(Object) - Method in class org.elasticsearch.action.search.SearchShardIterator
- equals(Object) - Method in class org.elasticsearch.action.support.ActiveShardCount
- equals(Object) - Method in class org.elasticsearch.action.support.IndicesOptions
- equals(Object) - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- equals(Object) - Method in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- equals(Object) - Method in class org.elasticsearch.action.support.replication.ReplicationTask.Status
- equals(Object) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResponse
- equals(Object) - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
- equals(Object) - Method in class org.elasticsearch.Build
- equals(Object) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.FailedShardEntry
- equals(Object) - Method in class org.elasticsearch.cluster.block.ClusterBlock
- equals(Object) - Method in class org.elasticsearch.cluster.ClusterInfo.NodeAndPath
- equals(Object) - Method in class org.elasticsearch.cluster.ClusterInfo.ReservedSpace
- equals(Object) - Method in class org.elasticsearch.cluster.ClusterName
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfigExclusion
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfiguration
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.FollowersChecker.FollowerCheckRequest
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.Join
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.JoinRequest
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.PeersResponse
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.PreVoteRequest
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.PreVoteResponse
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.PublishRequest
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.PublishResponse
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.PublishWithJoinResponse
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.StartJoinRequest
- equals(Object) - Method in class org.elasticsearch.cluster.coordination.ApplyCommitRequest
- equals(Object) - Method in class org.elasticsearch.cluster.DiskUsage
- equals(Object) - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- equals(Object) - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- equals(Object) - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.ComponentTemplate
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.DataStream
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.DataStream.TimestampField
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.DataStreamAction
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.ConcreteIndex
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Tombstone
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.ItemUsage
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.Manifest
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.MappingMetadata
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.MappingMetadata.Routing
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.ShutdownPersistentTasksStatus
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.ShutdownPluginsStatus
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.ShutdownShardMigrationStatus
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- equals(Object) - Method in class org.elasticsearch.cluster.metadata.Template
- equals(Object) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- equals(Object) - Method in class org.elasticsearch.cluster.node.DiscoveryNodeRole
- equals(Object) - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
- equals(Object) - Method in class org.elasticsearch.cluster.RestoreInProgress
- equals(Object) - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
- equals(Object) - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- equals(Object) - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- equals(Object) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- equals(Object) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
- equals(Object) - Method in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
- equals(Object) - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- equals(Object) - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- equals(Object) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- equals(Object) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- equals(Object) - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
- equals(Object) - Method in class org.elasticsearch.cluster.routing.AllocationId
- equals(Object) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- equals(Object) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- equals(Object) - Method in class org.elasticsearch.cluster.routing.PlainShardIterator
- equals(Object) - Method in class org.elasticsearch.cluster.routing.RecoverySource
- equals(Object) - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- equals(Object) - Method in class org.elasticsearch.cluster.routing.RoutingNode
- equals(Object) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- equals(Object) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- equals(Object) - Method in class org.elasticsearch.cluster.routing.ShardRouting
- equals(Object) - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
- equals(Object) - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
- equals(Object) - Method in class org.elasticsearch.cluster.service.ClusterApplierRecordingService.Stats
- equals(Object) - Method in class org.elasticsearch.cluster.service.ClusterApplierRecordingService.Stats.Recording
- equals(Object) - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- equals(Object) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- equals(Object) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- equals(Object) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- equals(Object) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- equals(Object) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- equals(Object) - Method in class org.elasticsearch.common.blobstore.BlobPath
- equals(Object) - Method in class org.elasticsearch.common.bytes.AbstractBytesReference
- equals(Object) - Method in class org.elasticsearch.common.bytes.BytesArray
- equals(Object) - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- equals(Object) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- equals(Object) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- equals(Object) - Method in class org.elasticsearch.common.compress.CompressedXContent
- equals(Object) - Method in class org.elasticsearch.common.document.DocumentField
- equals(Object) - Method in class org.elasticsearch.common.Explicit
- equals(Object) - Method in class org.elasticsearch.common.FieldMemoryStats
- equals(Object) - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- equals(Object) - Method in class org.elasticsearch.common.geo.GeoPoint
- equals(Object) - Method in class org.elasticsearch.common.hash.MurmurHash3.Hash128
- equals(Object) - Method in class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
- equals(Object) - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- equals(Object) - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
- equals(Object) - Method in class org.elasticsearch.common.inject.internal.ProviderMethodsModule
- equals(Object) - Method in class org.elasticsearch.common.inject.Key
- equals(Object) - Method in class org.elasticsearch.common.inject.multibindings.MapBinder.RealMapBinder
- equals(Object) - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
- equals(Object) - Method in class org.elasticsearch.common.inject.spi.Dependency
- equals(Object) - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
- equals(Object) - Method in class org.elasticsearch.common.inject.spi.Message
- equals(Object) - Method in class org.elasticsearch.common.inject.TypeLiteral
- equals(Object) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- equals(Object) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- equals(Object) - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
- equals(Object) - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreQuery
- equals(Object) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- equals(Object) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Returns true if
o
is equal to this. - equals(Object) - Method in class org.elasticsearch.common.Rounding
- equals(Object) - Method in class org.elasticsearch.common.rounding.Rounding
-
Deprecated.
- equals(Object) - Method in class org.elasticsearch.common.settings.SecureString
-
Constant time equality to avoid potential timing attacks.
- equals(Object) - Method in class org.elasticsearch.common.settings.Setting.AffixKey
- equals(Object) - Method in class org.elasticsearch.common.settings.Setting
- equals(Object) - Method in class org.elasticsearch.common.settings.Setting.SimpleKey
- equals(Object) - Method in class org.elasticsearch.common.settings.Settings
- equals(Object) - Method in class org.elasticsearch.common.text.Text
- equals(Object) - Method in class org.elasticsearch.common.time.WriteableZoneId
- equals(Object) - Method in class org.elasticsearch.common.transport.TransportAddress
- equals(Object) - Method in class org.elasticsearch.common.unit.ByteSizeValue
- equals(Object) - Method in class org.elasticsearch.common.unit.DistanceUnit.Distance
- equals(Object) - Method in class org.elasticsearch.common.unit.Fuzziness
- equals(Object) - Method in class org.elasticsearch.common.unit.SizeValue
- equals(Object) - Method in class org.elasticsearch.common.util.CuckooFilter
- equals(Object) - Method in class org.elasticsearch.common.util.LazyMap
- equals(Object) - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
- equals(Object) - Method in class org.elasticsearch.discovery.PeersRequest
- equals(Object) - Method in class org.elasticsearch.env.NodeMetadata
- equals(Object) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- equals(Object) - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
- equals(Object) - Method in class org.elasticsearch.index.analysis.NameOrDefinition
- equals(Object) - Method in class org.elasticsearch.index.engine.Engine.CommitId
- equals(Object) - Method in class org.elasticsearch.index.engine.Segment
- equals(Object) - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- equals(Object) - Method in class org.elasticsearch.index.get.GetResult
- equals(Object) - Method in class org.elasticsearch.index.Index
- equals(Object) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Range
- equals(Object) - Method in class org.elasticsearch.index.mapper.Uid
- equals(Object) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- equals(Object) - Method in class org.elasticsearch.index.query.DateRangeIncludingNowQuery
- equals(Object) - Method in class org.elasticsearch.index.query.DistanceFeatureQueryBuilder.Origin
- equals(Object) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- equals(Object) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
- equals(Object) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- equals(Object) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Combine
- equals(Object) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Disjunction
- equals(Object) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider
- equals(Object) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Fuzzy
- equals(Object) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.IntervalFilter
- equals(Object) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Match
- equals(Object) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Prefix
- equals(Object) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Wildcard
- equals(Object) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- equals(Object) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- equals(Object) - Method in class org.elasticsearch.index.refresh.RefreshStats
- equals(Object) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- equals(Object) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- equals(Object) - Method in class org.elasticsearch.index.reindex.RemoteInfo
- equals(Object) - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
- equals(Object) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
- equals(Object) - Method in class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
- equals(Object) - Method in class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- equals(Object) - Method in class org.elasticsearch.index.seqno.RetentionLease
- equals(Object) - Method in class org.elasticsearch.index.seqno.RetentionLeases
- equals(Object) - Method in class org.elasticsearch.index.seqno.RetentionLeaseStats
- equals(Object) - Method in class org.elasticsearch.index.seqno.SeqNoStats
- equals(Object) - Method in class org.elasticsearch.index.shard.IndexLongFieldRange
- equals(Object) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- equals(Object) - Method in class org.elasticsearch.index.shard.ReplicationGroup
- equals(Object) - Method in class org.elasticsearch.index.shard.ShardCountStats
- equals(Object) - Method in class org.elasticsearch.index.shard.ShardId
- equals(Object) - Method in class org.elasticsearch.index.shard.ShardLongFieldRange
- equals(Object) - Method in class org.elasticsearch.index.shard.ShardPath
- equals(Object) - Method in class org.elasticsearch.index.shard.ShardStateMetadata
- equals(Object) - Method in class org.elasticsearch.index.similarity.SimilarityProvider
- equals(Object) - Method in class org.elasticsearch.index.translog.Translog.Delete
- equals(Object) - Method in class org.elasticsearch.index.translog.Translog.Index
- equals(Object) - Method in class org.elasticsearch.index.translog.Translog.Location
- equals(Object) - Method in class org.elasticsearch.index.translog.Translog.NoOp
- equals(Object) - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
- equals(Object) - Method in class org.elasticsearch.indices.recovery.RecoveryState.FileDetail
- equals(Object) - Method in class org.elasticsearch.indices.TermsLookup
- equals(Object) - Method in class org.elasticsearch.ingest.IngestDocument
- equals(Object) - Method in class org.elasticsearch.ingest.IngestInfo
- equals(Object) - Method in class org.elasticsearch.ingest.IngestMetadata
- equals(Object) - Method in class org.elasticsearch.ingest.IngestStats
- equals(Object) - Method in class org.elasticsearch.ingest.IngestStats.PipelineStat
- equals(Object) - Method in class org.elasticsearch.ingest.IngestStats.ProcessorStat
- equals(Object) - Method in class org.elasticsearch.ingest.IngestStats.Stats
- equals(Object) - Method in class org.elasticsearch.ingest.PipelineConfiguration
- equals(Object) - Method in class org.elasticsearch.ingest.ProcessorInfo
- equals(Object) - Method in class org.elasticsearch.ingest.ValueSource.ByteValue
- equals(Object) - Method in class org.elasticsearch.ingest.ValueSource.ListValue
- equals(Object) - Method in class org.elasticsearch.ingest.ValueSource.MapValue
- equals(Object) - Method in class org.elasticsearch.ingest.ValueSource.ObjectValue
- equals(Object) - Method in class org.elasticsearch.ingest.ValueSource.TemplatedValue
- equals(Object) - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
- equals(Object) - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction.Request
- equals(Object) - Method in class org.elasticsearch.persistent.PersistentTaskResponse
- equals(Object) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Assignment
- equals(Object) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- equals(Object) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- equals(Object) - Method in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- equals(Object) - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- equals(Object) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- equals(Object) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- equals(Object) - Method in class org.elasticsearch.plugins.ActionPlugin.ActionHandler
- equals(Object) - Method in class org.elasticsearch.plugins.PluginDescriptor
- equals(Object) - Method in class org.elasticsearch.plugins.PluginsService.Bundle
- equals(Object) - Method in class org.elasticsearch.repositories.IndexId
- equals(Object) - Method in class org.elasticsearch.repositories.IndexMetaDataGenerations
- equals(Object) - Method in class org.elasticsearch.repositories.RepositoryData
- equals(Object) - Method in class org.elasticsearch.repositories.RepositoryData.SnapshotDetails
- equals(Object) - Method in class org.elasticsearch.repositories.RepositoryInfo
- equals(Object) - Method in class org.elasticsearch.repositories.RepositoryShardId
- equals(Object) - Method in class org.elasticsearch.repositories.RepositoryStats
- equals(Object) - Method in class org.elasticsearch.repositories.RepositoryStatsSnapshot
- equals(Object) - Method in class org.elasticsearch.repositories.ShardGeneration
- equals(Object) - Method in class org.elasticsearch.repositories.ShardGenerations
- equals(Object) - Method in class org.elasticsearch.repositories.ShardSnapshotInfo
- equals(Object) - Method in class org.elasticsearch.repositories.ShardSnapshotResult
- equals(Object) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- equals(Object) - Method in class org.elasticsearch.script.Script
- equals(Object) - Method in class org.elasticsearch.script.ScriptCache.CompilationRate
- equals(Object) - Method in class org.elasticsearch.script.ScriptContextInfo
- equals(Object) - Method in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo
- equals(Object) - Method in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo.ParameterInfo
- equals(Object) - Method in class org.elasticsearch.script.ScriptContextStats.TimeSeries
- equals(Object) - Method in class org.elasticsearch.script.ScriptException.Position
- equals(Object) - Method in class org.elasticsearch.script.ScriptLanguagesInfo
- equals(Object) - Method in class org.elasticsearch.script.ScriptMetadata
- equals(Object) - Method in class org.elasticsearch.script.StoredScriptSource
- equals(Object) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.Aggregations
- equals(Object) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.composite.GeoTileGridValuesSourceBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite.InternalBucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.filter.MergedPointRangeQuery
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DoubleBounds
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.EmptyBucketInfo
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket.BucketBounds
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.LongBounds
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder.Range
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ChiSquare
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.GND
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.JLHScore
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.MutualInformation
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.PercentageScore
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- equals(Object) - Method in class org.elasticsearch.search.aggregations.BucketOrder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- equals(Object) - Method in class org.elasticsearch.search.aggregations.InternalOrder.Aggregation
- equals(Object) - Method in class org.elasticsearch.search.aggregations.InternalOrder.CompoundOrder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalAvg
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalCardinality
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalMax
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalMedianAbsoluteDeviation
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalMin
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalScriptedMetric
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalSum
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTopHits
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalValueCount
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.InternalWeightedAvg
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.Percentile
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.Hdr
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.TDigest
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.TDigestState
- equals(Object) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalBucketMetricValue
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalDerivative
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel
- equals(Object) - Method in class org.elasticsearch.search.aggregations.support.AggregationInfo
- equals(Object) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
- equals(Object) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
- equals(Object) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- equals(Object) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- equals(Object) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry.RegistryKey
- equals(Object) - Method in class org.elasticsearch.search.builder.PointInTimeBuilder
- equals(Object) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- equals(Object) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.IndexBoost
- equals(Object) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- equals(Object) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- equals(Object) - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- equals(Object) - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- equals(Object) - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
- equals(Object) - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- equals(Object) - Method in class org.elasticsearch.search.fetch.subphase.FieldAndFormat
- equals(Object) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- equals(Object) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- equals(Object) - Method in class org.elasticsearch.search.internal.AliasFilter
- equals(Object) - Method in class org.elasticsearch.search.internal.ShardSearchContextId
- equals(Object) - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- equals(Object) - Method in class org.elasticsearch.search.profile.ProfileResult
- equals(Object) - Method in class org.elasticsearch.search.profile.query.CollectorResult
- equals(Object) - Method in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- equals(Object) - Method in class org.elasticsearch.search.profile.SearchProfileQueryPhaseResult
- equals(Object) - Method in class org.elasticsearch.search.profile.SearchProfileResults
- equals(Object) - Method in class org.elasticsearch.search.profile.SearchProfileResultsBuilder
- equals(Object) - Method in class org.elasticsearch.search.profile.SearchProfileShardResult
- equals(Object) - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- equals(Object) - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- equals(Object) - Method in class org.elasticsearch.search.runtime.AbstractScriptFieldQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.BooleanScriptFieldTermQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldRangeQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldTermQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldTermsQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.GeoPointScriptFieldDistanceFeatureQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.GeoPointScriptFieldGeoShapeQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.IpScriptFieldRangeQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.IpScriptFieldTermQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.IpScriptFieldTermsQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.LongScriptFieldDistanceFeatureQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.LongScriptFieldRangeQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.LongScriptFieldTermQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.LongScriptFieldTermsQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.StringScriptFieldFuzzyQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.StringScriptFieldPrefixQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.StringScriptFieldRangeQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.StringScriptFieldRegexpQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.StringScriptFieldTermQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.StringScriptFieldTermsQuery
- equals(Object) - Method in class org.elasticsearch.search.runtime.StringScriptFieldWildcardQuery
- equals(Object) - Method in class org.elasticsearch.search.Scroll
- equals(Object) - Method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- equals(Object) - Method in class org.elasticsearch.search.SearchExtBuilder
- equals(Object) - Method in class org.elasticsearch.search.SearchHit
- equals(Object) - Method in class org.elasticsearch.search.SearchHit.NestedIdentity
- equals(Object) - Method in class org.elasticsearch.search.SearchHits
- equals(Object) - Method in class org.elasticsearch.search.SearchShardTarget
- equals(Object) - Method in class org.elasticsearch.search.SearchSortValues
- equals(Object) - Method in class org.elasticsearch.search.SearchSortValuesAndFormats
- equals(Object) - Method in class org.elasticsearch.search.slice.SliceBuilder
- equals(Object) - Method in class org.elasticsearch.search.slice.SliceQuery
- equals(Object) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- equals(Object) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- equals(Object) - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- equals(Object) - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- equals(Object) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- equals(Object) - Method in class org.elasticsearch.search.sort.SortValue
- equals(Object) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- equals(Object) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
- equals(Object) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext
- equals(Object) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- equals(Object) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- equals(Object) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
- equals(Object) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- equals(Object) - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
- equals(Object) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
- equals(Object) - Method in class org.elasticsearch.search.suggest.completion.RegexOptions
- equals(Object) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- equals(Object) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- equals(Object) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- equals(Object) - Method in class org.elasticsearch.search.suggest.phrase.SmoothingModel
- equals(Object) - Method in class org.elasticsearch.search.suggest.Suggest
- equals(Object) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- equals(Object) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- equals(Object) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- equals(Object) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
- equals(Object) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- equals(Object) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- equals(Object) - Method in class org.elasticsearch.snapshots.InternalSnapshotsInfoService.SnapshotShard
- equals(Object) - Method in class org.elasticsearch.snapshots.RestoreInfo
- equals(Object) - Method in class org.elasticsearch.snapshots.Snapshot
- equals(Object) - Method in class org.elasticsearch.snapshots.SnapshotFeatureInfo
- equals(Object) - Method in class org.elasticsearch.snapshots.SnapshotId
- equals(Object) - Method in class org.elasticsearch.snapshots.SnapshotInfo
- equals(Object) - Method in class org.elasticsearch.snapshots.SnapshotInfo.IndexSnapshotDetails
- equals(Object) - Method in exception org.elasticsearch.snapshots.SnapshotShardFailure
- equals(Object) - Method in class org.elasticsearch.snapshots.UpdateIndexShardSnapshotStatusRequest
- equals(Object) - Method in class org.elasticsearch.tasks.RawTaskStatus
- equals(Object) - Method in class org.elasticsearch.tasks.TaskId
- equals(Object) - Method in class org.elasticsearch.tasks.TaskInfo
- equals(Object) - Method in class org.elasticsearch.tasks.TaskResult
- equals(Object) - Method in class org.elasticsearch.transport.ProxyConnectionStrategy.ProxyModeInfo
- equals(Object) - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- equals(Object) - Method in class org.elasticsearch.transport.SniffConnectionStrategy.SniffModeInfo
- equals(Object) - Method in class org.elasticsearch.upgrades.FeatureMigrationResults
- equals(Object) - Method in class org.elasticsearch.upgrades.SingleFeatureMigrationResult
- equals(Object) - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskParams
- equals(Object) - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskState
- equals(Object) - Method in class org.elasticsearch.Version
- equals(Type, Type) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
Returns true if
a
andb
are equal. - equals(ByteArray, ByteArray) - Method in class org.elasticsearch.common.util.BigArrays
- equalsAliases(Metadata) - Method in class org.elasticsearch.cluster.metadata.Metadata
- equalsIgnoreGenerations(RepositoriesMetadata) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
-
Checks if this instance and the given instance share the same repositories by checking that this instances' repositories and the repositories in
other
are equal or only differ in their values ofRepositoryMetadata.generation()
andRepositoryMetadata.pendingGeneration()
. - equalsIgnoreGenerations(RepositoryMetadata) - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
-
Checks if this instance is equal to the other instance in all fields other than
RepositoryMetadata.generation
andRepositoryMetadata.pendingGeneration
. - equalsIgnoringMetadata(ShardRouting) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
returns true if the current routing is identical to the other routing in all but meta fields, i.e., unassigned info
- equalsWithoutSliceStatus(Object, boolean, boolean) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- ERROR - Enum constant in enum class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.UpgradeStatus
- ERROR_FIELD - Static variable in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- errorFromXContent(XContentParser) - Static method in class org.elasticsearch.rest.BytesRestResponse
- ErrorHandler - Interface in org.elasticsearch.common.inject.internal
-
Handles errors in the Injector.
- errorInjectingConstructor(Throwable) - Method in class org.elasticsearch.common.inject.internal.Errors
- errorInjectingMethod(Throwable) - Method in class org.elasticsearch.common.inject.internal.Errors
- errorInProvider(RuntimeException) - Method in class org.elasticsearch.common.inject.internal.Errors
- errorInUserCode(Throwable, String, Object...) - Method in class org.elasticsearch.common.inject.internal.Errors
- errorInUserInjector(MembersInjector<?>, TypeLiteral<?>, RuntimeException) - Method in class org.elasticsearch.common.inject.internal.Errors
- errorMessage(String, String, Iterable<String>) - Method in class org.elasticsearch.common.xcontent.SuggestingErrorOnUnknown
- errorNotifyingInjectionListener(InjectionListener<?>, TypeLiteral<?>, RuntimeException) - Method in class org.elasticsearch.common.inject.internal.Errors
- errorNotifyingTypeListener(TypeListenerBinding, TypeLiteral<?>, Throwable) - Method in class org.elasticsearch.common.inject.internal.Errors
- Errors - Class in org.elasticsearch.common.inject.internal
-
A collection of error messages.
- Errors() - Constructor for class org.elasticsearch.common.inject.internal.Errors
- Errors(Object) - Constructor for class org.elasticsearch.common.inject.internal.Errors
- ErrorsException - Exception in org.elasticsearch.common.inject.internal
-
Indicates that a result could not be returned while preparing or resolving a binding.
- ErrorsException(Errors) - Constructor for exception org.elasticsearch.common.inject.internal.ErrorsException
- ES_PLUGIN_POLICY - Static variable in class org.elasticsearch.plugins.PluginDescriptor
- ES_PLUGIN_PROPERTIES - Static variable in class org.elasticsearch.plugins.PluginDescriptor
- ES_VERSION - Static variable in class org.elasticsearch.index.engine.Engine
- EsAbortPolicy - Class in org.elasticsearch.common.util.concurrent
- EsAbortPolicy() - Constructor for class org.elasticsearch.common.util.concurrent.EsAbortPolicy
- ESCacheHelper - Interface in org.elasticsearch.indices
-
Cache helper that allows swapping in implementations that are different to Lucene's IndexReader.CacheHelper which ties its lifecycle to that of the underlying reader.
- ESCacheHelper.ClosedListener - Interface in org.elasticsearch.indices
- ESCacheHelper.Wrapper - Class in org.elasticsearch.indices
-
Implementation of
ESCacheHelper
that wraps anIndexReader.CacheHelper
. - escape() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- escape(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Set to
true
to enable escaping of the query string - ESCAPE - Enum constant in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- escapeAndEncode(String) - Static method in class org.elasticsearch.common.logging.HeaderWarning
-
Escape and encode a string as a valid RFC 7230 quoted-string.
- EsExecutors - Class in org.elasticsearch.common.util.concurrent
- ESJsonLayout - Class in org.elasticsearch.common.logging
-
Formats log events as strings in a json format.
- ESJsonLayout(String, Charset, String[]) - Constructor for class org.elasticsearch.common.logging.ESJsonLayout
- ESJsonLayout.Builder<B extends ESJsonLayout.Builder<B>> - Class in org.elasticsearch.common.logging
- ESLogMessage - Class in org.elasticsearch.common.logging
-
A base class for custom log4j logger messages.
- ESLogMessage(Map<String, Object>, String, Object...) - Constructor for class org.elasticsearch.common.logging.ESLogMessage
-
This is an abstract class, so this is safe.
- ESMessageFieldConverter - Class in org.elasticsearch.common.logging
-
Pattern converter to populate ESMessageField in a pattern.
- ESMessageFieldConverter(String) - Constructor for class org.elasticsearch.common.logging.ESMessageFieldConverter
- EsRejectedExecutionException - Exception in org.elasticsearch.common.util.concurrent
- EsRejectedExecutionException() - Constructor for exception org.elasticsearch.common.util.concurrent.EsRejectedExecutionException
- EsRejectedExecutionException(String) - Constructor for exception org.elasticsearch.common.util.concurrent.EsRejectedExecutionException
- EsRejectedExecutionException(String, boolean) - Constructor for exception org.elasticsearch.common.util.concurrent.EsRejectedExecutionException
- EsRejectedExecutionHandler - Class in org.elasticsearch.common.util.concurrent
- EsRejectedExecutionHandler() - Constructor for class org.elasticsearch.common.util.concurrent.EsRejectedExecutionHandler
- EsThreadPoolExecutor - Class in org.elasticsearch.common.util.concurrent
-
An extension to thread pool executor, allowing (in the future) to add specific additional stats to it.
- EsThreadPoolExecutor.ShutdownListener - Interface in org.elasticsearch.common.util.concurrent
- ESTIMATED_TIME_INTERVAL_SETTING - Static variable in class org.elasticsearch.threadpool.ThreadPool
- estimatedMinAndMax() - Method in class org.elasticsearch.search.CanMatchShardResponse
- estimatedNumberOfOperations() - Method in class org.elasticsearch.index.translog.TranslogStats
- estimatedSizeInBytes() - Method in class org.elasticsearch.action.bulk.BulkRequest
-
The estimated size in bytes of the bulk request.
- estimatedSizeInBytes() - Method in class org.elasticsearch.index.engine.Engine.Delete
- estimatedSizeInBytes() - Method in class org.elasticsearch.index.engine.Engine.Index
- estimatedSizeInBytes() - Method in class org.elasticsearch.index.engine.Engine.NoOp
- estimatedSizeInBytes() - Method in class org.elasticsearch.index.engine.Engine.Operation
- estimateMillis() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
-
Converts this DateHistogramInterval into a millisecond representation.
- estimateNumberOfHistoryOperations(String, Engine.HistorySource, long) - Method in class org.elasticsearch.index.engine.Engine
-
Returns the estimated number of history operations whose seq# at least
startingSeqNo
(inclusive) in this engine. - estimateNumberOfHistoryOperations(String, Engine.HistorySource, long) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Returns the estimated number of history operations whose seq# at least the provided seq# in this engine.
- estimateNumberOfHistoryOperations(String, Engine.HistorySource, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- estimateNumberOfHistoryOperations(String, Engine.HistorySource, long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the estimated number of history operations whose seq# at least the provided seq# in this shard.
- estimateParsedLength() - Method in class org.elasticsearch.common.joda.Joda.EpochTimeParser
-
Deprecated.
- estimatePrintedLength() - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
-
Deprecated.
- estimateSize() - Method in class org.elasticsearch.index.translog.Translog.Delete
- estimateSize() - Method in class org.elasticsearch.index.translog.Translog.Index
- estimateSize() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- estimateSize() - Method in interface org.elasticsearch.index.translog.Translog.Operation
- estimateStringFieldData() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData.PagedBytesEstimator
- estimateTotalOperationsFromMinSeq(long) - Method in class org.elasticsearch.index.translog.Translog
-
Returns the number of operations in the transaction files that contain operations with seq# above the given number.
- ESToParentBlockJoinQuery - Class in org.elasticsearch.index.search
-
A
ToParentBlockJoinQuery
that allows to retrieve its nested path. - ESToParentBlockJoinQuery(Query, BitSetProducer, ScoreMode, String) - Constructor for class org.elasticsearch.index.search.ESToParentBlockJoinQuery
- evaluate(double, double) - Method in interface org.elasticsearch.index.query.functionscore.DecayFunction
- evaluate(Condition.Stats) - Method in class org.elasticsearch.action.admin.indices.rollover.Condition
- evaluate(Condition.Stats) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- evaluate(Condition.Stats) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- evaluate(Condition.Stats) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxPrimaryShardSizeCondition
- evaluate(Condition.Stats) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- evaluate(Condition.Stats) - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownCondition
- eventListener - Variable in class org.elasticsearch.index.engine.Engine
- EVICTED - Enum constant in enum class org.elasticsearch.common.cache.RemovalNotification.RemovalReason
- EvictingQueue<T> - Class in org.elasticsearch.common.collect
-
An
EvictingQueue
is a non-blocking queue which is limited to a maximum size; when new elements are added to a full queue, elements are evicted from the head of the queue to accommodate the new elements. - EvictingQueue(int) - Constructor for class org.elasticsearch.common.collect.EvictingQueue
-
Construct a new
EvictingQueue
that holdsmaximumSize
elements. - ewma(double[], double) - Static method in class org.elasticsearch.search.aggregations.pipeline.MovingFunctions
-
Calculate a exponentially weighted moving average.
- EWMA_ALPHA - Static variable in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
- EwmaModel - Class in org.elasticsearch.search.aggregations.pipeline
-
Calculate a exponentially weighted moving average
- EwmaModel() - Constructor for class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- EwmaModel(double) - Constructor for class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- EwmaModel(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.EwmaModel
-
Read from a stream.
- EwmaModel.EWMAModelBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- EWMAModelBuilder() - Constructor for class org.elasticsearch.search.aggregations.pipeline.EwmaModel.EWMAModelBuilder
- ExceptionsHelper - Class in org.elasticsearch
- ExceptionsHelper() - Constructor for class org.elasticsearch.ExceptionsHelper
- EXCLUDE_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- EXCLUDE_YES_DECISIONS - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.DebugMode
-
debug mode is on, but YES decisions from a
Decision.Multi
are not included. - EXCLUDED_DATA_STREAMS_KEY - Static variable in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- excludeFilters() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- excludeQuery() - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- excludes() - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- EXCLUDES_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- execute - Variable in class org.elasticsearch.script.ScriptContextInfo
- execute() - Method in class org.elasticsearch.action.ActionRequestBuilder
- execute() - Method in class org.elasticsearch.action.support.replication.ReplicationOperation
- execute() - Method in interface org.elasticsearch.plugins.PluginsSynchronizer
- execute() - Method in class org.elasticsearch.script.AbstractFieldScript
- execute() - Method in class org.elasticsearch.script.AggregationScript
- execute() - Method in class org.elasticsearch.script.BucketAggregationScript
- execute() - Method in class org.elasticsearch.script.BucketAggregationSelectorScript
- execute() - Method in class org.elasticsearch.script.FieldScript
- execute() - Method in class org.elasticsearch.script.FilterScript
-
Return
true
if the current document matches the filter, orfalse
otherwise. - execute() - Method in class org.elasticsearch.script.NumberSortScript
- execute() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.CombineScript
- execute() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.InitScript
- execute() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- execute() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.ReduceScript
- execute() - Method in class org.elasticsearch.script.StringSortScript
- execute() - Method in class org.elasticsearch.script.TemplateScript
-
Run a template and return the resulting string, encoded in utf8 bytes.
- execute() - Method in class org.elasticsearch.script.TermsSetQueryScript
- execute() - Method in class org.elasticsearch.script.UpdateScript
- execute(double, ScriptedSimilarity.Query, ScriptedSimilarity.Field, ScriptedSimilarity.Term, ScriptedSimilarity.Doc) - Method in class org.elasticsearch.script.SimilarityScript
-
Compute the score.
- execute(Runnable) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
- execute(Runnable, TimeValue, Runnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- execute(String, T, IndexSearcher, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.Suggester
- execute(Map<String, Object>) - Method in class org.elasticsearch.script.IngestConditionalScript
- execute(Map<String, Object>) - Method in class org.elasticsearch.script.IngestScript
- execute(Map<String, Object>) - Method in class org.elasticsearch.script.SignificantTermsHeuristicScoreScript
- execute(Map<String, Object>, double[]) - Method in class org.elasticsearch.search.aggregations.pipeline.MovingFunctionScript
- execute(ActionListener<Response>) - Method in class org.elasticsearch.action.ActionRequestBuilder
- execute(ActionListener<T>) - Method in class org.elasticsearch.action.SingleResultDeduplicator
-
Execute the action for the given
listener
. - execute(ActionType<Response>, Request) - Method in interface org.elasticsearch.client.ElasticsearchClient
-
Executes a generic action, denoted by an
ActionType
. - execute(ActionType<Response>, Request) - Method in class org.elasticsearch.client.support.AbstractClient
- execute(ActionType<Response>, Request, ActionListener<Response>) - Method in interface org.elasticsearch.client.ElasticsearchClient
-
Executes a generic action, denoted by an
ActionType
. - execute(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.support.AbstractClient
-
This is the single execution point of *all* clients.
- execute(BulkRequest, long) - Method in class org.elasticsearch.action.bulk.BulkRequestHandler
- execute(Terminal, OptionSet) - Method in class org.elasticsearch.cli.EnvironmentAwareCommand
- execute(Terminal, OptionSet, Environment) - Method in class org.elasticsearch.cli.EnvironmentAwareCommand
-
Execute the command with the initialized
Environment
. - execute(Terminal, OptionSet, Environment) - Method in class org.elasticsearch.cli.KeyStoreAwareCommand
- execute(Terminal, OptionSet, Environment) - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- execute(Terminal, OptionSet, Environment) - Method in class org.elasticsearch.common.settings.BaseKeyStoreCommand
- execute(Terminal, OptionSet, Environment) - Method in class org.elasticsearch.common.settings.HasPasswordKeyStoreCommand
- execute(Terminal, Directory, Lock, PrintStream, boolean) - Method in class org.elasticsearch.index.shard.RemoveCorruptedLuceneSegmentsAction
- execute(Terminal, ShardPath, Directory) - Method in class org.elasticsearch.index.translog.TruncateTranslogAction
- execute(ClusterState) - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
-
Update the cluster state based on the current state.
- execute(ClusterState) - Method in class org.elasticsearch.cluster.LocalClusterUpdateTask
- execute(ClusterState) - Method in class org.elasticsearch.cluster.metadata.SystemIndexMetadataUpgradeService.SystemIndexMetadataUpdateTask
- execute(ClusterState) - Method in class org.elasticsearch.upgrades.MigrationResultsUpdateTask
- execute(ClusterState, List<ShardStateAction.FailedShardEntry>) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardFailedClusterStateTaskExecutor
- execute(ClusterState, List<ShardStateAction.StartedShardEntry>) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardStartedClusterStateTaskExecutor
- execute(ClusterState, List<ClusterStateUpdateTask>) - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
- execute(ClusterState, List<JoinTaskExecutor.Task>) - Method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor
- execute(ClusterState, List<NodeRemovalClusterStateTaskExecutor.Task>) - Method in class org.elasticsearch.cluster.coordination.NodeRemovalClusterStateTaskExecutor
- execute(ClusterState, List<LocalClusterUpdateTask>) - Method in class org.elasticsearch.cluster.LocalClusterUpdateTask
- execute(ClusterState, List<T>) - Method in interface org.elasticsearch.cluster.ClusterStateTaskExecutor
-
Update the cluster state based on the current state and the given tasks.
- execute(DiscoveryNode, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.TransportActionNodeProxy
- execute(RoutingAllocation, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
- execute(RoutingAllocation, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand
- execute(RoutingAllocation, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
- execute(RoutingAllocation, boolean) - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand
-
Executes the command on a
RoutingAllocation
setup - execute(RoutingAllocation, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Executes all wrapped commands on a given
RoutingAllocation
- execute(RoutingAllocation, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- execute(RoutingAllocation, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- execute(CancellableThreads.Interruptible) - Method in class org.elasticsearch.common.util.CancellableThreads
-
run the Interruptible, capturing the executing thread.
- execute(IntervalFilterScript.Interval) - Method in class org.elasticsearch.index.query.IntervalFilterScript
- execute(ScriptedSimilarity.Query, ScriptedSimilarity.Field, ScriptedSimilarity.Term) - Method in class org.elasticsearch.script.SimilarityWeightScript
-
Compute the weight.
- execute(IngestDocument) - Method in class org.elasticsearch.ingest.CompoundProcessor
- execute(IngestDocument) - Method in class org.elasticsearch.ingest.ConditionalProcessor
- execute(IngestDocument) - Method in class org.elasticsearch.ingest.DropProcessor
- execute(IngestDocument) - Method in class org.elasticsearch.ingest.PipelineProcessor
- execute(IngestDocument) - Method in interface org.elasticsearch.ingest.Processor
-
Introspect and potentially modify the incoming data.
- execute(IngestDocument) - Method in class org.elasticsearch.ingest.TrackingResultProcessor
- execute(IngestDocument, BiConsumer<IngestDocument, Exception>) - Method in class org.elasticsearch.ingest.CompoundProcessor
- execute(IngestDocument, BiConsumer<IngestDocument, Exception>) - Method in class org.elasticsearch.ingest.ConditionalProcessor
- execute(IngestDocument, BiConsumer<IngestDocument, Exception>) - Method in class org.elasticsearch.ingest.Pipeline
-
Modifies the data of a document to be indexed based on the processor this pipeline holds If
null
is returned then this document will be dropped and not indexed, otherwise this document will be kept and indexed. - execute(IngestDocument, BiConsumer<IngestDocument, Exception>) - Method in class org.elasticsearch.ingest.PipelineProcessor
- execute(IngestDocument, BiConsumer<IngestDocument, Exception>) - Method in interface org.elasticsearch.ingest.Processor
-
Introspect and potentially modify the incoming data.
- execute(IngestDocument, BiConsumer<IngestDocument, Exception>) - Method in class org.elasticsearch.ingest.TrackingResultProcessor
- execute(ScoreScript.ExplanationHolder) - Method in class org.elasticsearch.script.ScoreScript
- execute(SearchContext) - Method in class org.elasticsearch.search.aggregations.AggregationPhase
- execute(SearchContext) - Method in class org.elasticsearch.search.dfs.DfsPhase
- execute(SearchContext) - Method in class org.elasticsearch.search.fetch.FetchPhase
- execute(SearchContext) - Method in class org.elasticsearch.search.query.QueryPhase
- execute(SearchContext) - Method in class org.elasticsearch.search.rescore.RescorePhase
- execute(SearchContext) - Method in class org.elasticsearch.search.suggest.SuggestPhase
- execute(Task, Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.TransportAction
-
Use this method when the transport action should continue to run in the context of the current task
- execute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.TransportAction
-
Use this method when the transport action call should result in creation of a new task associated with the call.
- execute(Request, TaskListener<Response>) - Method in class org.elasticsearch.action.support.TransportAction
-
Execute the transport action on the local node, returning the
Task
used to track its execution and accepting aTaskListener
which listens for the completion of the action. - executeAsyncActions(ActionListener<Object>) - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
Executes all registered async actions and notifies the listener once it's done.
- executeAsyncActions(ActionListener<Object>) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- executeBulkRequest(int, Iterable<DocWriteRequest<?>>, BiConsumer<Integer, Exception>, BiConsumer<Thread, Exception>, IntConsumer, String) - Method in class org.elasticsearch.ingest.IngestService
- executeChunkRequest(Request, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.MultiChunkTransfer
- executeCommand(Terminal, OptionSet, Environment) - Method in class org.elasticsearch.common.settings.BaseKeyStoreCommand
-
This is called after the keystore password has been read from the stdin and the keystore is decrypted and loaded.
- executeCommand(Terminal, OptionSet, Environment) - Method in class org.elasticsearch.common.settings.UpgradeKeyStoreCommand
- executeConsistentStateUpdate(Function<RepositoryData, ClusterStateUpdateTask>, String, Consumer<Exception>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- executeConsistentStateUpdate(Function<RepositoryData, ClusterStateUpdateTask>, String, Consumer<Exception>) - Method in class org.elasticsearch.repositories.FilterRepository
- executeConsistentStateUpdate(Function<RepositoryData, ClusterStateUpdateTask>, String, Consumer<Exception>) - Method in interface org.elasticsearch.repositories.Repository
-
Execute a cluster state update with a consistent view of the current
RepositoryData
. - executeDfsPhase(ShardSearchRequest, SearchShardTask, ActionListener<SearchPhaseResult>) - Method in class org.elasticsearch.search.SearchService
- executeFetchPhase(ShardFetchRequest, SearchShardTask, ActionListener<FetchSearchResult>) - Method in class org.elasticsearch.search.SearchService
- executeFetchPhase(InternalScrollSearchRequest, SearchShardTask, ActionListener<ScrollQueryFetchSearchResult>) - Method in class org.elasticsearch.search.SearchService
- executeHandshake(DiscoveryNode, TcpChannel, ConnectionProfile, ActionListener<Version>) - Method in class org.elasticsearch.transport.TcpTransport
- executeLocally(ActionType<Response>, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.node.NodeClient
- executeLocally(ActionType<Response>, Request, TaskListener<Response>) - Method in class org.elasticsearch.client.node.NodeClient
- executeOnce(T, ActionListener<R>, BiConsumer<T, ActionListener<R>>) - Method in class org.elasticsearch.action.ResultDeduplicator
-
Ensures a given request not executed multiple times when another equal request is already in-flight.
- executeOnShardTarget(SearchTask, SearchShardIterator, Transport.Connection, ActionListener<SearchPhaseResult>) - Method in interface org.elasticsearch.action.search.TransportSearchAction.SinglePhaseSearchAction
- executePipeline(Pipeline, BiConsumer<IngestDocument, Exception>) - Method in class org.elasticsearch.ingest.IngestDocument
-
Executes the given pipeline with for this document unless the pipeline has already been executed for this document.
- executeQueryPhase(InternalScrollSearchRequest, SearchShardTask, ActionListener<ScrollQuerySearchResult>) - Method in class org.elasticsearch.search.SearchService
- executeQueryPhase(ShardSearchRequest, SearchShardTask, ActionListener<SearchPhaseResult>) - Method in class org.elasticsearch.search.SearchService
- executeQueryPhase(QuerySearchRequest, SearchShardTask, ActionListener<QuerySearchResult>) - Method in class org.elasticsearch.search.SearchService
- executeRequest(SearchTask, SearchRequest, String, boolean, TransportSearchAction.SinglePhaseSearchAction, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.search.TransportSearchAction
- executeScript(SearchLookup, LeafReaderContext, int, DocumentParserContext) - Method in class org.elasticsearch.index.mapper.FieldMapper
-
Execute the index-time script associated with this field mapper.
- executeShardAction(ActionListener<MultiGetResponse>, AtomicArray<MultiGetItemResponse>, Map<ShardId, MultiGetShardRequest>) - Method in class org.elasticsearch.action.get.TransportMultiGetAction
- executeShardAction(ActionListener<MultiTermVectorsResponse>, AtomicArray<MultiTermVectorsItemResponse>, Map<ShardId, MultiTermVectorsShardRequest>) - Method in class org.elasticsearch.action.termvectors.TransportMultiTermVectorsAction
- executeSnapshot(CreateSnapshotRequest, ActionListener<SnapshotInfo>) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Same as
SnapshotsService.createSnapshot(CreateSnapshotRequest, ActionListener)
but invokes its callback on completion of the snapshot. - executeSnapshotLegacy(CreateSnapshotRequest, ActionListener<SnapshotInfo>) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Same as
SnapshotsService.createSnapshot(CreateSnapshotRequest, ActionListener)
but invokes its callback on completion of the snapshot. - executeTask(Params, PersistentTaskState, AllocatedPersistentTask, PersistentTasksExecutor<Params>) - Method in class org.elasticsearch.persistent.NodePersistentTasksExecutor
- executing - Variable in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.Pending
- EXECUTION_HINT_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- EXECUTION_HINT_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- ExecutionCancelledException(String) - Constructor for exception org.elasticsearch.common.util.CancellableThreads.ExecutionCancelledException
- ExecutionCancelledException(StreamInput) - Constructor for exception org.elasticsearch.common.util.CancellableThreads.ExecutionCancelledException
- executionHint() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
-
Get the execution hint.
- executionHint() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
-
Expert: gets an execution hint to the aggregation.
- executionHint() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Expert: gets an execution hint to the aggregation.
- executionHint(String) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
-
Set the execution hint.
- executionHint(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
-
Expert: sets an execution hint to the aggregation.
- executionHint(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Expert: sets an execution hint to the aggregation.
- executionResults - Variable in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult
- executor - Variable in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- executor - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- executor() - Method in class org.elasticsearch.action.ActionListenerResponseHandler
- executor() - Method in interface org.elasticsearch.index.shard.GlobalCheckpointListeners.GlobalCheckpointListener
-
The executor on which the listener is notified.
- executor() - Method in class org.elasticsearch.transport.EmptyTransportResponseHandler
- executor() - Method in class org.elasticsearch.transport.FutureTransportResponseHandler
- executor() - Method in class org.elasticsearch.transport.PlainTransportFuture
- executor() - Method in interface org.elasticsearch.transport.TransportResponseHandler
- executor() - Method in class org.elasticsearch.transport.TransportService.ContextRestoreResponseHandler
- executor(String) - Method in class org.elasticsearch.threadpool.ThreadPool
-
Get the
ExecutorService
with the given name. - executor(IndexShard) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- executor(ShardId) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- executor(ShardId) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- ExecutorBuilder<U extends org.elasticsearch.threadpool.ExecutorBuilder.ExecutorSettings> - Class in org.elasticsearch.threadpool
-
Base class for executor builders.
- ExecutorBuilder(String) - Constructor for class org.elasticsearch.threadpool.ExecutorBuilder
- executorForGet(String) - Method in class org.elasticsearch.indices.ExecutorSelector
-
The "get" executor should be used when retrieving documents by ID.
- executorForSearch(String) - Method in class org.elasticsearch.indices.ExecutorSelector
-
The "search" executor should be used for search or aggregation operations.
- executorForWrite(String) - Method in class org.elasticsearch.indices.ExecutorSelector
-
The "write" executor should be used for operations that write new documents or update existing ones.
- ExecutorNames - Class in org.elasticsearch.indices
-
A class that gathers the names of thread pool executors that should be used for a particular system index or system data stream.
- ExecutorNames(String, String, String) - Constructor for class org.elasticsearch.indices.ExecutorNames
-
Create a new collection of thread pool names for a system descriptor to use.
- executorSelector - Variable in class org.elasticsearch.action.support.replication.TransportWriteAction
- ExecutorSelector - Class in org.elasticsearch.indices
-
Some operations need to use different executors for different index patterns.
- exist(String) - Static method in enum class org.elasticsearch.common.time.FormatNames
- EXISTING_INDEX_RESTORED - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of restoring into a closed index.
- EXISTING_SHARDS_ALLOCATOR_SETTING - Static variable in interface org.elasticsearch.cluster.routing.allocation.ExistingShardsAllocator
-
Allows plugins to override how we allocate shards that may already exist on disk in the cluster.
- EXISTING_STORE - Enum constant in enum class org.elasticsearch.cluster.routing.RecoverySource.Type
- ExistingShardsAllocator - Interface in org.elasticsearch.cluster.routing.allocation
-
Searches for, and allocates, shards for which there is an existing on-disk copy somewhere in the cluster.
- ExistingShardsAllocator.UnassignedAllocationHandler - Interface in org.elasticsearch.cluster.routing.allocation
- exists() - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistResponse
- exists() - Method in class org.elasticsearch.index.engine.Engine.GetResult
- exists() - Method in class org.elasticsearch.index.shard.ShardPath
- exists(Path...) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Returns
true
iff one of the files exists otherwisefalse
- exists(IndexSearcher, Query) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Check whether there is one or more documents matching the provided query.
- exists(IndicesExistsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices Exists.
- exists(IndicesExistsRequest, ActionListener<IndicesExistsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
The status of one or more indices.
- exists(Settings) - Method in class org.elasticsearch.common.settings.SecureSetting
- exists(Settings) - Method in class org.elasticsearch.common.settings.Setting
-
Returns true if and only if this setting is present in the given settings instance.
- exists(Settings.Builder) - Method in class org.elasticsearch.common.settings.Setting
- existsOrFallbackExists(Settings) - Method in class org.elasticsearch.common.settings.Setting
-
Returns true if and only if this setting including fallback settings is present in the given settings instance.
- existsQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter to filter only documents where a field exists in them.
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.BooleanScriptFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper.TimestampFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DateScriptFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DocCountFieldMapper.DocCountFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DoubleScriptFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.GeoPointScriptFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper.IgnoredFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.IpScriptFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypeFieldType
- existsQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TypeFieldType
- ExistsQueryBuilder - Class in org.elasticsearch.index.query
-
Constructs a query that only match on documents that the field has a value in them.
- ExistsQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.ExistsQueryBuilder
- ExistsQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.ExistsQueryBuilder
-
Read from a stream.
- EXP_DECAY_FUNCTION - Static variable in class org.elasticsearch.index.query.functionscore.ExponentialDecayFunctionBuilder
- exp1() - Method in class org.elasticsearch.common.lucene.RegExp
-
Child expressions held by a container type expression.
- exp2() - Method in class org.elasticsearch.common.lucene.RegExp
-
Child expressions held by a container type expression.
- expand() - Method in class org.elasticsearch.common.io.stream.DelayableWriteable
-
Expands the inner
Writeable
to its original representation and returns it - expand() - Method in class org.elasticsearch.common.io.stream.DelayableWriteable.Serialized
- expandAliasesWildcards() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- expandAliasesWildcards() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- expandAliasesWildcards() - Method in interface org.elasticsearch.action.AliasesRequest
-
Returns true if wildcards expressions among aliases should be resolved, false otherwise
- expandToAllNodes() - Method in class org.elasticsearch.cluster.metadata.AutoExpandReplicas
- expandWilcardsClosed(boolean) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- expandWilcardsOpen(boolean) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- expandWildcardsClosed() - Method in class org.elasticsearch.action.support.IndicesOptions
- expandWildcardsHidden() - Method in class org.elasticsearch.action.support.IndicesOptions
- expandWildcardsOpen() - Method in class org.elasticsearch.action.support.IndicesOptions
- EXPECTATION_FAILED - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The expectation given in an Expect request-header field (see section 14.20) could not be met by this server, or, if the server is a proxy, the server has unambiguous evidence that the request could not be met by the next-hop server.
- EXPECTED_DATA_NODES_SETTING - Static variable in class org.elasticsearch.gateway.GatewayService
- EXPECTED_EXCEPTION_FIELDS - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- EXPECTED_MASTER_NODES_SETTING - Static variable in class org.elasticsearch.gateway.GatewayService
- EXPECTED_NODES_SETTING - Static variable in class org.elasticsearch.gateway.GatewayService
- expectedCommitId() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- expectEmptyRetentionLeases() - Method in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- expectEmptyRetentionLeases() - Method in class org.elasticsearch.cluster.routing.RecoverySource
- expectEmptyRetentionLeases() - Method in class org.elasticsearch.cluster.routing.RecoverySource.PeerRecoverySource
- expireContexts - Variable in class org.elasticsearch.script.ScriptService.ContextSettings
- explain() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Returns the current explain flag
- explain() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- explain() - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- explain() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Indicates if detailed information about query is requested
- explain() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Indicates whether each search hit will be returned with an explanation of the hit (ranking)
- explain() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicates whether each search hit will be returned with an explanation of the hit (ranking)
- explain() - Method in class org.elasticsearch.search.fetch.FetchContext
-
Should the response include `explain` output
- explain() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- explain() - Method in class org.elasticsearch.search.internal.SearchContext
- explain() - Method in class org.elasticsearch.search.internal.SubSearchContext
- explain(boolean) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Sets the explain flag, which will collect information about the reroute request without executing the actions.
- explain(boolean) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- explain(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Indicate if detailed information about query is requested
- explain(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Should each
SearchHit
be returned with an explanation of the hit (ranking). - explain(boolean) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- explain(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
- explain(boolean) - Method in class org.elasticsearch.search.internal.SubSearchContext
- explain(int, IndexSearcher, RescoreContext, Explanation) - Method in class org.elasticsearch.search.rescore.QueryRescorer
- explain(int, IndexSearcher, RescoreContext, Explanation) - Method in interface org.elasticsearch.search.rescore.Rescorer
-
Executes an
Explanation
phase on the rescorer. - explain(Boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Should each
SearchHit
be returned with an explanation of the hit (ranking). - explain(LeafReaderContext, int) - Method in class org.elasticsearch.search.profile.query.ProfileWeight
- explain(Explanation) - Method in interface org.elasticsearch.script.ExplainableScoreScript
-
Build the explanation of the current document being scored The script score needs the Explanation of the sub query score because it might use _score and want to explain how that was computed.
- explain(Explanation, Explanation, float) - Method in enum class org.elasticsearch.common.lucene.search.function.CombineFunction
- explain(ExplainRequest) - Method in interface org.elasticsearch.client.Client
-
Computes a score explanation for the specified request.
- explain(ExplainRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- explain(ExplainRequest, ActionListener<ExplainResponse>) - Method in interface org.elasticsearch.client.Client
-
Computes a score explanation for the specified request.
- explain(ExplainRequest, ActionListener<ExplainResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- EXPLAIN - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Fields
- EXPLAIN_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- ExplainableScoreScript - Interface in org.elasticsearch.script
-
To be implemented by
ScoreScript
which can provided anExplanation
of the score This is currently not used inside elasticsearch but it is used, see for example here: https://github.com/elastic/elasticsearch/issues/8561 - ExplainAction - Class in org.elasticsearch.action.explain
-
Entry point for the explain feature.
- explainConflictForReads(long, long) - Method in enum class org.elasticsearch.index.VersionType
-
Returns a human readable explanation for a version conflict on read.
- explainConflictForWrites(long, long, boolean) - Method in enum class org.elasticsearch.index.VersionType
-
Returns a human readable explanation for a version conflict on write.
- explainFunction(String, double, double) - Method in interface org.elasticsearch.index.query.functionscore.DecayFunction
- explainOrThrowMissingRoutingNode(RoutingAllocation, boolean, DiscoveryNode) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Handle case where a disco node cannot be found in the routing table.
- explainOrThrowRejectedCommand(boolean, RoutingAllocation, RuntimeException) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Utility method for rejecting the current allocation command based on provided exception
- explainOrThrowRejectedCommand(boolean, RoutingAllocation, String) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Utility method for rejecting the current allocation command based on provided reason
- ExplainPhase - Class in org.elasticsearch.search.fetch.subphase
-
Explains the scoring calculations for the top hits.
- ExplainPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.ExplainPhase
- ExplainRequest - Class in org.elasticsearch.action.explain
-
Explain request encapsulating the explain query and document identifier to get an explanation for.
- ExplainRequest() - Constructor for class org.elasticsearch.action.explain.ExplainRequest
- ExplainRequest(String, String) - Constructor for class org.elasticsearch.action.explain.ExplainRequest
- ExplainRequest(String, String, String) - Constructor for class org.elasticsearch.action.explain.ExplainRequest
-
Deprecated.Types are in the process of being removed. Use
instead.
- ExplainRequestBuilder - Class in org.elasticsearch.action.explain
-
A builder for
ExplainRequest
. - ExplainRequestBuilder(ElasticsearchClient, ExplainAction, String, String, String) - Constructor for class org.elasticsearch.action.explain.ExplainRequestBuilder
- ExplainResponse - Class in org.elasticsearch.action.explain
-
Response containing the score explanation.
- ExplainResponse(String, String, String, boolean) - Constructor for class org.elasticsearch.action.explain.ExplainResponse
- ExplainResponse(String, String, String, boolean, Explanation) - Constructor for class org.elasticsearch.action.explain.ExplainResponse
- ExplainResponse(String, String, String, boolean, Explanation, GetResult) - Constructor for class org.elasticsearch.action.explain.ExplainResponse
- ExplainResponse(StreamInput) - Constructor for class org.elasticsearch.action.explain.ExplainResponse
- explainScore(int, Explanation) - Method in class org.elasticsearch.common.lucene.search.function.LeafScoreFunction
- explainShard(ShardRouting, RoutingAllocation, ClusterInfo, boolean, boolean, AllocationService) - Static method in class org.elasticsearch.action.admin.cluster.allocation.TransportClusterAllocationExplainAction
- explainShardAllocation(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
- explainUnassignedShardAllocation(ShardRouting, RoutingAllocation) - Method in interface org.elasticsearch.cluster.routing.allocation.ExistingShardsAllocator
-
Returns an explanation for a single unassigned shard.
- explainUnassignedShardAllocation(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.gateway.GatewayAllocator
- explainWeight() - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- explanation(Explanation) - Method in class org.elasticsearch.search.SearchHit
- EXPLANATION_FIELD - Static variable in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- ExplanationHolder() - Constructor for class org.elasticsearch.script.ScoreScript.ExplanationHolder
- explanations() - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService.CommandsResult
-
Get the explanation of this result
- explanations() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
- EXPLANATIONS_FIELD - Static variable in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
- explicit() - Method in class org.elasticsearch.common.Explicit
- Explicit<T> - Class in org.elasticsearch.common
-
Holds a value that is either: a) set implicitly e.g.
- Explicit(T, boolean) - Constructor for class org.elasticsearch.common.Explicit
-
Create a value with an indication if this was an explicit choice
- explicitBoolParam(String, boolean, Function<FieldMapper, Explicit<Boolean>>, boolean) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Defines a parameter that takes the values
true
orfalse
, and will always serialize its value if configured. - exponentialBackoff() - Static method in class org.elasticsearch.action.bulk.BackoffPolicy
-
Creates an new exponential backoff policy with a default configuration of 50 ms initial wait period and 8 retries taking roughly 5.1 seconds in total.
- exponentialBackoff(TimeValue, int) - Static method in class org.elasticsearch.action.bulk.BackoffPolicy
-
Creates an new exponential backoff policy with the provided configuration.
- exponentialDecayFunction(String, Object, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- exponentialDecayFunction(String, Object, Object, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- exponentialDecayFunction(String, Object, Object, Object, double) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- ExponentialDecayFunctionBuilder - Class in org.elasticsearch.index.query.functionscore
- ExponentialDecayFunctionBuilder(String, Object, Object, Object) - Constructor for class org.elasticsearch.index.query.functionscore.ExponentialDecayFunctionBuilder
- ExponentialDecayFunctionBuilder(String, Object, Object, Object, double) - Constructor for class org.elasticsearch.index.query.functionscore.ExponentialDecayFunctionBuilder
- ExponentialDecayFunctionBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.ExponentialDecayFunctionBuilder
-
Read from a stream.
- ExponentiallyWeightedMovingAverage - Class in org.elasticsearch.common
-
Implements exponentially weighted moving averages (commonly abbreviated EWMA) for a single value.
- ExponentiallyWeightedMovingAverage(double, double) - Constructor for class org.elasticsearch.common.ExponentiallyWeightedMovingAverage
-
Create a new EWMA with a given
alpha
andinitialAvg
. - expose(Class<?>) - Method in interface org.elasticsearch.common.inject.PrivateBinder
-
Makes a binding for
type
available to the enclosing environment. - expose(Class<?>) - Method in class org.elasticsearch.common.inject.PrivateModule
-
Makes a binding for
type
available to other modules and the injector. - expose(Key<?>) - Method in interface org.elasticsearch.common.inject.PrivateBinder
-
Makes the binding for
key
available to the enclosing environment - expose(Key<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
-
Makes the binding for
key
available to other modules and the injector. - expose(TypeLiteral<?>) - Method in interface org.elasticsearch.common.inject.PrivateBinder
-
Makes a binding for
type
available to the enclosing environment. - expose(TypeLiteral<?>) - Method in class org.elasticsearch.common.inject.PrivateModule
-
Makes a binding for
type
available to other modules and the injector. - Exposed - Annotation Interface in org.elasticsearch.common.inject
-
Accompanies a @
Provides
method annotation in a private module to indicate that the provided binding is exposed. - ExposedBinding<T> - Interface in org.elasticsearch.common.inject.spi
-
A binding to a key exposed from an enclosed private environment.
- ExposedBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- ExposedBindingImpl(Object, Key<T>, Scoping, PrivateElements) - Constructor for class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- ExposedBindingImpl(Injector, Object, Key<T>, InternalFactory<T>, PrivateElements) - Constructor for class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- exposedButNotBound(Key<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
- ExposureBuilder<T> - Class in org.elasticsearch.common.inject.internal
-
For private binder's expose() method.
- ExposureBuilder(Binder, Object, Key<T>) - Constructor for class org.elasticsearch.common.inject.internal.ExposureBuilder
- ext() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- ext(List<SearchExtBuilder>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- EXT_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- extend(IntervalsSource, int) - Static method in class org.elasticsearch.index.query.IntervalBuilder
- EXTENDED_BOUNDS_FIELD - Static variable in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
- extendedBounds - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- extendedBounds() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Return extended bounds for this histogram, or
null
if none are set. - extendedBounds() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- extendedBounds(double, double) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Set extended bounds on this builder: buckets between
minBound
andmaxBound
will be created even if no documents fell into these buckets. - extendedBounds(DoubleBounds) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Set extended bounds on this builder: buckets between
minBound
andmaxBound
will be created even if no documents fell into these buckets. - extendedBounds(LongBounds) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set extended bounds on this histogram, so that buckets would also be generated on intervals that did not match any documents.
- ExtendedCommonTermsQuery - Class in org.apache.lucene.queries
-
Deprecated.Since max_optimization optimization landed in 7.0, normal MatchQuery will achieve the same result without any configuration.
- ExtendedCommonTermsQuery(BooleanClause.Occur, BooleanClause.Occur, float) - Constructor for class org.apache.lucene.queries.ExtendedCommonTermsQuery
-
Deprecated.
- extendedStats(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
ExtendedStats
aggregation with the given name. - ExtendedStats - Interface in org.elasticsearch.search.aggregations.metrics
-
Statistics over a set of values (either aggregated over field data or scripts)
- ExtendedStats.Bounds - Enum Class in org.elasticsearch.search.aggregations.metrics
- ExtendedStatsAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- ExtendedStatsAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- ExtendedStatsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
-
Read from a stream.
- ExtendedStatsAggregationBuilder(ExtendedStatsAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- ExtendedStatsAggregatorProvider - Interface in org.elasticsearch.search.aggregations.metrics
- extendedStatsBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- ExtendedStatsBucket - Interface in org.elasticsearch.search.aggregations.pipeline
-
Extended Statistics over a set of buckets
- ExtendedStatsBucketParser - Class in org.elasticsearch.search.aggregations.pipeline
- ExtendedStatsBucketParser() - Constructor for class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketParser
- ExtendedStatsBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- ExtendedStatsBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregationBuilder
- ExtendedStatsBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregationBuilder
-
Read from a stream.
- ExtendedStatsBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- ExtendedStatsBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregator
-
Read from a stream.
- extendWithShardRange(int, int, ShardLongFieldRange) - Method in class org.elasticsearch.index.shard.IndexLongFieldRange
- ExtensiblePlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
implementations to be themselves extensible. - ExtensiblePlugin.ExtensionLoader - Interface in org.elasticsearch.plugins
- EXTERNAL - Enum constant in enum class org.elasticsearch.index.engine.Engine.SearcherScope
- EXTERNAL - Enum constant in enum class org.elasticsearch.index.VersionType
- EXTERNAL - Enum constant in enum class org.elasticsearch.indices.SystemDataStreamDescriptor.Type
- EXTERNAL_GTE - Enum constant in enum class org.elasticsearch.index.VersionType
- EXTERNAL_MANAGED - Enum constant in enum class org.elasticsearch.indices.SystemIndexDescriptor.Type
- EXTERNAL_SYSTEM_INDEX_ACCESS_CONTROL_HEADER_KEY - Static variable in class org.elasticsearch.indices.SystemIndices
- EXTERNAL_UNMANAGED - Enum constant in enum class org.elasticsearch.indices.SystemIndexDescriptor.Type
- extra - Variable in class org.elasticsearch.search.sort.BucketedSort
- extractAndRegister(List<P>, Function<P, Map<String, T>>) - Method in class org.elasticsearch.common.NamedRegistry
- extractFields(Set<String>) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Combine
- extractFields(Set<String>) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Disjunction
- extractFields(Set<String>) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider
- extractFields(Set<String>) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Fuzzy
- extractFields(Set<String>) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Match
- extractFields(Set<String>) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Prefix
- extractFields(Set<String>) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Wildcard
- extractFromSource(String) - Method in class org.elasticsearch.script.AbstractFieldScript
- extractFromSource(String) - Method in class org.elasticsearch.script.GeoPointFieldScript
- extractGetResult(UpdateRequest, String, long, long, long, Map<String, Object>, XContentType, BytesReference) - Static method in class org.elasticsearch.action.update.UpdateHelper
-
Applies
UpdateRequest.fetchSource()
to the _source of the updated document to be returned in a update response. - extractInnerHitBuilders(Map<String, InnerHitContextBuilder>) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
For internal usage only! Extracts the inner hits from the query tree.
- extractInnerHitBuilders(Map<String, InnerHitContextBuilder>) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- extractInnerHitBuilders(Map<String, InnerHitContextBuilder>) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
- extractInnerHitBuilders(Map<String, InnerHitContextBuilder>) - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- extractInnerHitBuilders(Map<String, InnerHitContextBuilder>) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- extractInnerHitBuilders(Map<String, InnerHitContextBuilder>) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- extractInnerHitBuilders(Map<String, InnerHitContextBuilder>) - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- extractInnerHitBuilders(Map<String, InnerHitContextBuilder>) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
- extractInnerHits(QueryBuilder, Map<String, InnerHitContextBuilder>) - Static method in class org.elasticsearch.index.query.InnerHitContextBuilder
- extractMetadata() - Method in class org.elasticsearch.ingest.IngestDocument
-
one time operation that extracts the metadata fields from the ingest document and returns them.
- extractNestedSources(String, Map<?, ?>) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
-
For the provided nested path, return its source maps from the parent xContent map.
- extractRawValues(String) - Method in class org.elasticsearch.search.lookup.SourceLookup
-
Returns the values associated with the path.
- extractRawValues(String, Map<String, Object>) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
-
Extracts raw values (string, int, and so on) based on the path provided returning all of them as a single list.
- extractShardId(DirectoryReader) - Static method in class org.elasticsearch.index.shard.ShardUtils
-
Tries to extract the shard id from a reader if possible, when its not possible, will return null.
- extractShardId(LeafReader) - Static method in class org.elasticsearch.index.shard.ShardUtils
-
Tries to extract the shard id from a reader if possible, when its not possible, will return null.
- extractTerm(Query) - Static method in class org.elasticsearch.index.mapper.MappedFieldType
-
Extract a
Term
from a query created withMappedFieldType.termQuery(java.lang.Object, org.elasticsearch.index.query.SearchExecutionContext)
by recursively removingBoostQuery
wrappers. - extractTerms(Set<Term>) - Method in class org.elasticsearch.search.profile.query.ProfileWeight
- extractTraceId(String) - Static method in class org.elasticsearch.rest.RestUtils
-
Extract the trace id from the specified traceparent string.
- extractValue(String, Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
-
For the provided path, return its value in the source.
- extractValue(String, Map<?, ?>) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
-
For the provided path, return its value in the xContent map.
- extractValue(String, Map<?, ?>, Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
-
For the provided path, return its value in the xContent map.
- extractValue(Map<?, ?>, String...) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- extractWarningValueFromWarningHeader(String, boolean) - Static method in class org.elasticsearch.common.logging.HeaderWarning
-
Extracts the warning value from the value of a warning header that is formatted according to RFC 7234.
- extraXContent(XContentBuilder) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- extraXContent(XContentBuilder) - Method in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
F
- factor() - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- factor(float) - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- factories - Variable in class org.elasticsearch.search.aggregations.AggregatorFactory
- factories() - Method in class org.elasticsearch.search.aggregations.SearchContextAggregations
- factoriesBuilder - Variable in class org.elasticsearch.search.aggregations.AggregationBuilder
- Factory() - Constructor for class org.elasticsearch.ingest.DropProcessor.Factory
- Factory() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Factory
- Factory() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance.Factory
- Factory() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
- Factory(String) - Constructor for class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
- Factory(IngestService) - Constructor for class org.elasticsearch.ingest.PipelineProcessor.Factory
- FACTORY - Static variable in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange
- FACTORY - Static variable in class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance
- factoryClazz - Variable in class org.elasticsearch.script.ScriptContext
-
A factory class for constructing script or stateful factory instances.
- FactoryProvider<F> - Class in org.elasticsearch.common.inject.assistedinject
-
Provides a factory that combines the caller's arguments with injector-supplied values to construct objects.
- fail - Variable in class org.elasticsearch.index.reindex.ScrollableHitSource
- fail(ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>, SnapshotsInProgress.State, String) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- fail(RecoveryFailedException, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
fail the recovery and call listener
- FailableCache<K,
V> - Class in org.elasticsearch.common.inject.internal -
Lazily creates (and caches) values for keys.
- FailableCache() - Constructor for class org.elasticsearch.common.inject.internal.FailableCache
- failAllStatesAndClear(Exception) - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
clear the incoming queue.
- failDestructive(String[]) - Method in class org.elasticsearch.action.support.DestructiveOperations
-
Fail if there is wildcard usage in indices and the named is required for destructive operations.
- failed() - Method in enum class org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- failed() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- failed(SnapshotInfo, String) - Static method in class org.elasticsearch.snapshots.RestoreService
- FAILED - Enum constant in enum class org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- FAILED - Enum constant in enum class org.elasticsearch.cluster.SnapshotsInProgress.State
- FAILED - Enum constant in enum class org.elasticsearch.snapshots.SnapshotState
-
Snapshot failed
- FAILED_DEPENDENCY - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The 424 (Failed Dependency) status code means that the method could not be performed on the resource because the requested action depended on another action and that action failed.
- FAILED_FIELD - Static variable in class org.elasticsearch.rest.action.RestActions
- FAILED_SHARDS - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.SortBy
- FAILED_TO_OBTAIN_NODE_LOCK_MSG - Static variable in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- failedEngine - Variable in class org.elasticsearch.index.engine.Engine
- FailedNodeException - Exception in org.elasticsearch.action
- FailedNodeException(String, String, Throwable) - Constructor for exception org.elasticsearch.action.FailedNodeException
- FailedNodeException(StreamInput) - Constructor for exception org.elasticsearch.action.FailedNodeException
- FailedShard - Class in org.elasticsearch.cluster.routing.allocation
-
A class representing a failed shard.
- FailedShard(ShardRouting, String, Exception, boolean) - Constructor for class org.elasticsearch.cluster.routing.allocation.FailedShard
- FailedShardEntry(ShardId, String, long, String, Exception, boolean) - Constructor for class org.elasticsearch.cluster.action.shard.ShardStateAction.FailedShardEntry
- failedShards() - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
-
total number of shards for which the operation failed
- failedShards() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- failedShards() - Method in class org.elasticsearch.snapshots.RestoreInfo
-
Number of failed shards
- failedShards() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Number of failed shards; a value of
0
will be returned if there were no failed shards, or ifSnapshotInfo.state()
returnsnull
. - failedShards(ImmutableOpenMap<ShardId, RestoreInProgress.ShardRestoreStatus>) - Static method in class org.elasticsearch.snapshots.RestoreService
- FailedToCommitClusterStateException - Exception in org.elasticsearch.cluster.coordination
-
Thrown when failing to publish a cluster state.
- FailedToCommitClusterStateException(String, Object...) - Constructor for exception org.elasticsearch.cluster.coordination.FailedToCommitClusterStateException
- FailedToCommitClusterStateException(String, Throwable, Object...) - Constructor for exception org.elasticsearch.cluster.coordination.FailedToCommitClusterStateException
- FailedToCommitClusterStateException(StreamInput) - Constructor for exception org.elasticsearch.cluster.coordination.FailedToCommitClusterStateException
- failEngine(IOException) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
- failEngine(String, Exception) - Method in class org.elasticsearch.index.engine.Engine
-
fail engine due to some error.
- failEngineLock - Variable in class org.elasticsearch.index.engine.Engine
- failIfCorrupted() - Method in class org.elasticsearch.index.store.Store
- failIfFrozen() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
This method fails if
SearchExecutionContext.freezeContext()
is called before on this context. - failIfNoDocValues() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- failIfNotIndexed() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- failOnUnsupportedField() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- failOnUnsupportedField(boolean) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Whether to fail or return no result when this query is run against a field which is not supported such as binary/numeric fields.
- failRecovery(long, RecoveryFailedException, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
fail the recovery with the given id (if found) and remove it from the recovery collection
- failShard(String, Exception) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Fail the primary shard.
- failShard(String, Exception) - Method in class org.elasticsearch.index.shard.IndexShard
-
Fails the shard and marks the shard store as corrupted if
e
is caused by index corruption - failShard(Logger, ShardRouting, UnassignedInfo, IndexMetadata, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Applies the relevant logic to handle a cancelled or failed shard.
- failShardIfNeeded(ShardRouting, long, String, Exception, ActionListener<Void>) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Replicas
-
Fail the specified shard if needed, removing it from the current set of active shards.
- failShardIfNeeded(ShardRouting, long, String, Exception, ActionListener<Void>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicasProxy
- failure() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- failure(int, DocWriteRequest.OpType, BulkItemResponse.Failure) - Static method in class org.elasticsearch.action.bulk.BulkItemResponse
- failure(Exception) - Static method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.TaskResult
- failure(String) - Static method in class org.elasticsearch.bootstrap.BootstrapCheck.BootstrapCheckResult
- failure(String, Exception) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus
-
Create a feature status for a failed reset operation
- failure(String, Exception) - Static method in class org.elasticsearch.upgrades.SingleFeatureMigrationResult
-
Creates a record indicating that migration failed.
- failure(T, Exception) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult.Builder
- Failure(String, int, Throwable) - Constructor for exception org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult.Failure
- Failure(String, int, Throwable) - Constructor for exception org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult.Failure
- Failure(String, int, Throwable, String) - Constructor for exception org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult.Failure
- Failure(String, int, Throwable, String) - Constructor for exception org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult.Failure
- Failure(String, String, int, Throwable) - Constructor for exception org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.Failure
- Failure(String, String, String, Exception) - Constructor for class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
For write failures before operation was assigned a sequence number.
- Failure(String, String, String, Exception) - Constructor for class org.elasticsearch.action.get.MultiGetResponse.Failure
- Failure(String, String, String, Exception) - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
- Failure(String, String, String, Exception, boolean) - Constructor for class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- Failure(String, String, String, Exception, long, long) - Constructor for class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
For write failures after operation was assigned a sequence number.
- Failure(String, String, String, Exception, RestStatus) - Constructor for class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- Failure(StreamInput) - Constructor for class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
Read from a stream.
- Failure(StreamInput) - Constructor for exception org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- Failure(StreamInput) - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
- Failure(ShardId, String, Exception, RestStatus, boolean) - Constructor for exception org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- FAILURE - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus.Status
- FAILURE - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Snapshot failed
- FAILURE - Enum constant in enum class org.elasticsearch.cluster.RestoreInProgress.State
-
Restore failed
- FAILURE - Enum constant in enum class org.elasticsearch.index.engine.Engine.Result.Type
- FAILURE - Enum constant in enum class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Snapshot failed
- FAILURE - Enum constant in enum class org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices.IndexRemovalReason
-
Something around index management has failed and the index should be removed.
- failureFromXContent(XContentParser) - Static method in exception org.elasticsearch.ElasticsearchException
- failureReason() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- failureReason() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- failures() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
Get the failed node exceptions.
- failures(Iterable<T>, Exception) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult.Builder
- FAILURES_FIELD - Static variable in class org.elasticsearch.rest.action.RestActions
- FAKE_PING_ID - Static variable in class org.elasticsearch.discovery.zen.ZenPing.PingResponse
-
An ID of a ping response that was generated on behalf of another node.
- FALSE - Enum constant in enum class org.elasticsearch.index.mapper.ObjectMapper.Dynamic
- FALSE - Enum constant in enum class org.elasticsearch.transport.Compression.Enabled
- FALSE - Static variable in class org.elasticsearch.action.support.master.AcknowledgedResponse
- FALSE - Static variable in class org.elasticsearch.index.mapper.BooleanFieldMapper.Values
- falses() - Method in class org.elasticsearch.script.BooleanFieldScript
-
How many
false
values were returned for this document. - familyTypeName() - Method in class org.elasticsearch.index.mapper.DocCountFieldMapper.DocCountFieldType
- familyTypeName() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns the field family type, as used in field capabilities
- fastForward() - Method in class org.elasticsearch.common.util.concurrent.CountDown
-
Fast forwards the count-down to zero and returns
true
iff the count down reached zero with this fast forward call otherwisefalse
- FastVectorHighlighter - Class in org.elasticsearch.search.fetch.subphase.highlight
- FastVectorHighlighter(Settings) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.FastVectorHighlighter
- FaultDetection - Class in org.elasticsearch.discovery.zen
-
A base class for
MasterFaultDetection
&NodesFaultDetection
, making sure both use the same setting. - FaultDetection(Settings, ThreadPool, TransportService, ClusterName) - Constructor for class org.elasticsearch.discovery.zen.FaultDetection
- FDM - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- FDT - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- FDX - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- Feature(String) - Constructor for class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse.Feature
- Feature(String, String, Collection<SystemIndexDescriptor>) - Constructor for class org.elasticsearch.indices.SystemIndices.Feature
-
Construct a Feature using the default clean-up function
- Feature(String, String, Collection<SystemIndexDescriptor>, Collection<SystemDataStreamDescriptor>) - Constructor for class org.elasticsearch.indices.SystemIndices.Feature
-
Construct a Feature using the default clean-up function
- Feature(String, String, Collection<SystemIndexDescriptor>, Collection<SystemDataStreamDescriptor>, Collection<AssociatedIndexDescriptor>, TriConsumer<ClusterService, Client, ActionListener<ResetFeatureStateResponse.ResetFeatureStateStatus>>, SystemIndices.Feature.MigrationPreparationHandler, SystemIndices.Feature.MigrationCompletionHandler) - Constructor for class org.elasticsearch.indices.SystemIndices.Feature
-
Construct a Feature with a custom cleanup function
- Feature(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse.Feature
- FEATURE_PREFIX - Static variable in class org.elasticsearch.transport.TransportSettings
- FEATURE_STATES_VERSION - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- FeatureMigrationResults - Class in org.elasticsearch.upgrades
-
Holds the results of the most recent attempt to migrate system indices.
- FeatureMigrationResults(Map<String, SingleFeatureMigrationResult>) - Constructor for class org.elasticsearch.upgrades.FeatureMigrationResults
- FeatureMigrationResults(StreamInput) - Constructor for class org.elasticsearch.upgrades.FeatureMigrationResults
- FeatureMigrationResults.ResultsDiff - Class in org.elasticsearch.upgrades
- features() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- features(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- featureStates() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- featureStates() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- featureStates() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- featureStates() - Method in class org.elasticsearch.snapshots.SnapshotInfo
- featureStates(String[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- featureStates(String[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- featureStates(List<String>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- featureStates(List<String>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- FeatureUpgradeStatus(String, Version, GetFeatureUpgradeStatusResponse.UpgradeStatus, List<GetFeatureUpgradeStatusResponse.IndexInfo>) - Constructor for class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.FeatureUpgradeStatus
- FeatureUpgradeStatus(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.FeatureUpgradeStatus
- FEET - Enum constant in enum class org.elasticsearch.common.unit.DistanceUnit
- fetch(SourceLookup) - Method in class org.elasticsearch.search.fetch.subphase.FieldFetcher
- FETCH_FIELDS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- FETCH_ID_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- FETCH_ID_SCROLL_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- FETCH_SHARD_STARTED - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- FETCH_SHARD_STORE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- FETCH_SOURCE - Static variable in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- FetchContext - Class in org.elasticsearch.search.fetch
-
Encapsulates state required to execute fetch phases
- FetchContext(SearchContext) - Constructor for class org.elasticsearch.search.fetch.FetchContext
-
Create a FetchContext based on a SearchContext
- fetchData(DiscoveryNodes, Set<String>) - Method in class org.elasticsearch.gateway.AsyncShardFetch
-
Fetches the data for the relevant shard.
- fetchData(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.gateway.PrimaryShardAllocator
- fetchData(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.gateway.ReplicaShardAllocator
- FetchDocValuesContext - Class in org.elasticsearch.search.fetch.subphase
-
All the required context to pull a field from the doc values.
- FetchDocValuesContext(SearchExecutionContext, List<FieldAndFormat>) - Constructor for class org.elasticsearch.search.fetch.subphase.FetchDocValuesContext
-
Create a new FetchDocValuesContext using the provided input list.
- FetchDocValuesPhase - Class in org.elasticsearch.search.fetch.subphase
-
Fetch sub phase which pulls data from doc values.
- FetchDocValuesPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.FetchDocValuesPhase
- fetchField(String) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Adds a field to load and return as part of the search request.
- fetchField(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a field to load and return as part of the search request.
- fetchField(FieldAndFormat) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Adds a field to load and return as part of the search request.
- fetchField(FieldAndFormat) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a field to load and return as part of the search request.
- fetchFields() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Gets the fields to load and return as part of the search request.
- fetchFields() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the fields to load and return as part of the search request.
- fetchFields() - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
-
Returns true if the stored fields should be fetched, false otherwise.
- fetchFieldsContext() - Method in class org.elasticsearch.search.fetch.FetchContext
-
Configuration for the 'fields' response
- fetchFieldsContext() - Method in class org.elasticsearch.search.internal.SearchContext
-
The context related to retrieving fields.
- fetchFieldsContext() - Method in class org.elasticsearch.search.internal.SubSearchContext
- fetchFieldsContext(FetchFieldsContext) - Method in class org.elasticsearch.search.internal.SearchContext
-
Sets the context related to retrieving fields.
- fetchFieldsContext(FetchFieldsContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
- FetchFieldsContext - Class in org.elasticsearch.search.fetch.subphase
-
The context needed to retrieve fields.
- FetchFieldsContext(List<FieldAndFormat>) - Constructor for class org.elasticsearch.search.fetch.subphase.FetchFieldsContext
- FetchFieldsPhase - Class in org.elasticsearch.search.fetch.subphase
-
A fetch sub-phase for high-level field retrieval.
- FetchFieldsPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.FetchFieldsPhase
- FETCHING_SHARD_DATA - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
-
Waiting on getting shard data from all nodes before making a decision about where to allocate the shard
- fetchLatestSnapshotsForShard(ShardId, ActionListener<Optional<ShardSnapshot>>) - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshotsService
- fetchPhase() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- fetchPhase() - Method in class org.elasticsearch.search.internal.SearchContext
- FetchPhase - Class in org.elasticsearch.search.fetch
-
Fetch phase of a search request, used to fetch the actual top matching documents to be returned to the client, identified after reducing all of the matches returned by the query phase
- FetchPhase(List<FetchSubPhase>) - Constructor for class org.elasticsearch.search.fetch.FetchPhase
- FetchPhaseConstructionContext(Map<String, Highlighter>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.FetchPhaseConstructionContext
- FetchPhaseExecutionException - Exception in org.elasticsearch.search.fetch
- FetchPhaseExecutionException(StreamInput) - Constructor for exception org.elasticsearch.search.fetch.FetchPhaseExecutionException
- FetchPhaseExecutionException(SearchShardTarget, String) - Constructor for exception org.elasticsearch.search.fetch.FetchPhaseExecutionException
- FetchPhaseExecutionException(SearchShardTarget, String, Throwable) - Constructor for exception org.elasticsearch.search.fetch.FetchPhaseExecutionException
- FetchProfiler - Class in org.elasticsearch.search.fetch
- FetchProfiler() - Constructor for class org.elasticsearch.search.fetch.FetchProfiler
-
Start profiling at the current time.
- FetchProfiler(long) - Constructor for class org.elasticsearch.search.fetch.FetchProfiler
-
Build the profiler starting at a fixed time.
- fetchResult() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- fetchResult() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- fetchResult() - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- fetchResult() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- fetchResult() - Method in class org.elasticsearch.search.internal.SearchContext
- fetchResult() - Method in class org.elasticsearch.search.internal.SubSearchContext
- fetchResult() - Method in class org.elasticsearch.search.SearchPhaseResult
-
Returns the fetch result iff it's included in this response otherwise
null
- FetchResult(ShardId, Map<DiscoveryNode, T>, Set<String>) - Constructor for class org.elasticsearch.gateway.AsyncShardFetch.FetchResult
- FetchScorePhase - Class in org.elasticsearch.search.fetch.subphase
- FetchScorePhase() - Constructor for class org.elasticsearch.search.fetch.subphase.FetchScorePhase
- fetchScores() - Method in class org.elasticsearch.search.fetch.FetchContext
-
Should the response include scores, even if scores were not calculated in the original query
- FetchSearchResult - Class in org.elasticsearch.search.fetch
- FetchSearchResult() - Constructor for class org.elasticsearch.search.fetch.FetchSearchResult
- FetchSearchResult(StreamInput) - Constructor for class org.elasticsearch.search.fetch.FetchSearchResult
- FetchSearchResult(ShardSearchContextId, SearchShardTarget) - Constructor for class org.elasticsearch.search.fetch.FetchSearchResult
- fetchSource() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Gets the
FetchSourceContext
which defines how the _source should be fetched. - fetchSource() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Gets the
FetchSourceContext
which defines how the _source should be fetched. - fetchSource() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the
FetchSourceContext
which defines how the _source should be fetched. - fetchSource() - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- fetchSource(boolean) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Indicates whether the response should contain the updated _source.
- fetchSource(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Indicates whether the response should contain the stored _source for every hit
- fetchSource(boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicates whether the response should contain the stored _source for every hit
- fetchSource(String[], String[]) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Indicate that _source should be returned, with an "include" and/or "exclude" set which can include simple wildcard elements.
- fetchSource(String[], String[]) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Indicate that _source should be returned with every hit, with an "include" and/or "exclude" set which can include simple wildcard elements.
- fetchSource(String[], String[]) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicate that _source should be returned with every hit, with an "include" and/or "exclude" set which can include simple wildcard elements.
- fetchSource(String, String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Indicate that _source should be returned with every hit, with an "include" and/or "exclude" set which can include simple wildcard elements.
- fetchSource(String, String) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Indicate that _source should be returned with every hit, with an "include" and/or "exclude" set which can include simple wildcard elements.
- fetchSource(String, String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicate that _source should be returned with every hit, with an "include" and/or "exclude" set which can include simple wildcard elements.
- fetchSource(FetchSourceContext) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Explicitly set the fetch source context for this request
- fetchSource(FetchSourceContext) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Indicate how the _source should be fetched.
- fetchSource(FetchSourceContext) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicate how the _source should be fetched.
- fetchSourceContext() - Method in class org.elasticsearch.action.explain.ExplainRequest
- fetchSourceContext() - Method in class org.elasticsearch.action.get.GetRequest
- fetchSourceContext() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- fetchSourceContext() - Method in class org.elasticsearch.search.fetch.FetchContext
-
Configuration for fetching _source
- fetchSourceContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- fetchSourceContext() - Method in class org.elasticsearch.search.internal.SearchContext
- fetchSourceContext() - Method in class org.elasticsearch.search.internal.SubSearchContext
- fetchSourceContext(FetchSourceContext) - Method in class org.elasticsearch.action.explain.ExplainRequest
-
Allows setting the
FetchSourceContext
for this request, controlling if and how _source should be returned. - fetchSourceContext(FetchSourceContext) - Method in class org.elasticsearch.action.get.GetRequest
-
Allows setting the
FetchSourceContext
for this request, controlling if and how _source should be returned. - fetchSourceContext(FetchSourceContext) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
Allows setting the
FetchSourceContext
for this request, controlling if and how _source should be returned. - fetchSourceContext(FetchSourceContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- fetchSourceContext(FetchSourceContext) - Method in class org.elasticsearch.search.internal.SearchContext
- fetchSourceContext(FetchSourceContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
- FetchSourceContext - Class in org.elasticsearch.search.fetch.subphase
-
Context used to fetch the
_source
. - FetchSourceContext(boolean) - Constructor for class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- FetchSourceContext(boolean, String[], String[]) - Constructor for class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- FetchSourceContext(StreamInput) - Constructor for class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- FetchSourcePhase - Class in org.elasticsearch.search.fetch.subphase
- FetchSourcePhase() - Constructor for class org.elasticsearch.search.fetch.subphase.FetchSourcePhase
- FetchSubPhase - Interface in org.elasticsearch.search.fetch
-
Sub phase within the fetch phase used to fetch things *about* the documents like highlighting or matched queries.
- FetchSubPhase.HitContext - Class in org.elasticsearch.search.fetch
- FetchSubPhaseProcessor - Interface in org.elasticsearch.search.fetch
-
Executes the logic for a
FetchSubPhase
against a particular leaf reader and hit - fetchValues(SourceLookup, List<Object>) - Method in class org.elasticsearch.index.mapper.ArraySourceValueFetcher
- fetchValues(SourceLookup, List<Object>) - Method in class org.elasticsearch.index.mapper.DocValueFetcher
- fetchValues(SourceLookup, List<Object>) - Method in class org.elasticsearch.index.mapper.NestedValueFetcher
- fetchValues(SourceLookup, List<Object>) - Method in class org.elasticsearch.index.mapper.SourceValueFetcher
- fetchValues(SourceLookup, List<Object>) - Method in class org.elasticsearch.index.mapper.StoredValueFetcher
- fetchValues(SourceLookup, List<Object>) - Method in interface org.elasticsearch.index.mapper.ValueFetcher
-
Given access to a document's _source, return this field's values.
- FetchVersionPhase - Class in org.elasticsearch.search.fetch.subphase
- FetchVersionPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.FetchVersionPhase
- field - Variable in class org.apache.lucene.search.grouping.CollapseTopFieldDocs
-
The field used for collapsing
- field - Variable in class org.elasticsearch.action.termvectors.TermVectorsFilter.ScoreTerm
- field - Variable in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.PointParser
- field - Variable in class org.elasticsearch.search.fetch.subphase.FieldAndFormat
-
The name of the field.
- field - Variable in class org.elasticsearch.search.fetch.subphase.highlight.FieldHighlightContext
- field - Variable in class org.elasticsearch.search.sort.SortFieldAndFormat
- field - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- field - Variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- field() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- field() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Gets the field to use for this source
- field() - Method in class org.elasticsearch.search.aggregations.support.FieldContext
- field() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Gets the field to use for this aggregation.
- field() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.Field
- field() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the
SuggestionBuilder.field()
parameter - field(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- field(String) - Method in class org.elasticsearch.index.get.GetResult
- field(String) - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
-
Adds a field to run the query against.
- field(String) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Adds a field to run the multi match against.
- field(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Adds a field to run the query string against.
- field(String) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Add a field to run the query against.
- field(String) - Method in class org.elasticsearch.script.DocBasedScript
- field(String) - Method in interface org.elasticsearch.script.DocReader
-
New-style field access
- field(String) - Method in class org.elasticsearch.script.DocValuesDocReader
- field(String) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Sets the field to use for this source
- field(String) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Sets the field to use for this aggregation.
- field(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Adds a field to be highlighted with default fragment size of 100 characters, and default number of fragments of 5 using the default encoder
- field(String) - Method in class org.elasticsearch.search.SearchHit
-
The hit field matching the given field name.
- field(String) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping.Builder
-
Set the name of the field to use
- field(String) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping.Builder
-
Set the name of the field containing a geolocation to use
- field(String, float) - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
-
Adds a field to run the query against with a specific boost.
- field(String, float) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Adds a field to run the multi match against with a specific boost.
- field(String, float) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Adds a field to run the query string against with a specific boost.
- field(String, float) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Add a field to run the query against with a specific boost.
- field(String, int) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Adds a field to be highlighted with a provided fragment size (in characters), and default number of fragments of 5.
- field(String, int, int) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Adds a field to be highlighted with a provided fragment size (in characters), and a provided (maximum) number of fragments.
- field(String, int, int, int) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Adds a field to be highlighted with a provided fragment size (in characters), and a provided (maximum) number of fragments.
- field(String, MultiValuesSourceFieldConfig) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- field(HighlightBuilder.Field) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- field(DateTimeZone) - Method in enum class org.elasticsearch.common.rounding.DateTimeUnit
- Field - Interface in org.elasticsearch.script.field
-
A field in a document accessible via scripting.
- Field(String) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
- Field(StreamInput) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
-
Read from a stream.
- FIELD - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Fields
- FIELD - Static variable in class org.elasticsearch.common.unit.Fuzziness
- FIELD_FIELD - Static variable in class org.elasticsearch.index.query.ExistsQueryBuilder
- FIELD_FIELD - Static variable in class org.elasticsearch.index.query.InnerHitBuilder
- FIELD_FIELD - Static variable in class org.elasticsearch.search.collapse.CollapseBuilder
- FIELD_FIELD - Static variable in class org.elasticsearch.search.slice.SliceBuilder
- FIELD_FIELDNAME - Static variable in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- FIELD_NAME - Static variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- FIELD_PRECISION - Static variable in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- FIELD_RANGE_SEARCH_SOURCE - Static variable in class org.elasticsearch.index.engine.ReadOnlyEngine
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.AllFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.BooleanFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.IdFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.IgnoredFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.KeywordFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.RoutingFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.SourceFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.TextFieldMapper.Defaults
- FIELD_TYPE - Static variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- FieldAliasMapper - Class in org.elasticsearch.index.mapper
-
A mapper for field aliases.
- FieldAliasMapper(String, String, String) - Constructor for class org.elasticsearch.index.mapper.FieldAliasMapper
- FieldAliasMapper.Builder - Class in org.elasticsearch.index.mapper
- FieldAliasMapper.Names - Class in org.elasticsearch.index.mapper
- FieldAliasMapper.TypeParser - Class in org.elasticsearch.index.mapper
- FieldAndFormat - Class in org.elasticsearch.search.fetch.subphase
-
Wrapper around a field name and the format that should be used to display values of this field.
- FieldAndFormat(String, String) - Constructor for class org.elasticsearch.search.fetch.subphase.FieldAndFormat
- FieldAndFormat(String, String, Boolean) - Constructor for class org.elasticsearch.search.fetch.subphase.FieldAndFormat
- FieldAndFormat(StreamInput) - Constructor for class org.elasticsearch.search.fetch.subphase.FieldAndFormat
-
Serialization constructor.
- FieldCapabilities - Class in org.elasticsearch.action.fieldcaps
-
Describes the capabilities of a field optionally merged across multiple indices.
- FieldCapabilities(String, String, boolean, boolean, boolean, String[], String[], String[], Map<String, Set<String>>) - Constructor for class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
Constructor for a set of indices.
- FieldCapabilitiesAction - Class in org.elasticsearch.action.fieldcaps
- FieldCapabilitiesFailure - Class in org.elasticsearch.action.fieldcaps
- FieldCapabilitiesFailure(String[], Exception) - Constructor for class org.elasticsearch.action.fieldcaps.FieldCapabilitiesFailure
- FieldCapabilitiesFailure(StreamInput) - Constructor for class org.elasticsearch.action.fieldcaps.FieldCapabilitiesFailure
- FieldCapabilitiesIndexRequest - Class in org.elasticsearch.action.fieldcaps
- FieldCapabilitiesIndexResponse - Class in org.elasticsearch.action.fieldcaps
- FieldCapabilitiesRequest - Class in org.elasticsearch.action.fieldcaps
- FieldCapabilitiesRequest() - Constructor for class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- FieldCapabilitiesRequest(StreamInput) - Constructor for class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- FieldCapabilitiesRequestBuilder - Class in org.elasticsearch.action.fieldcaps
- FieldCapabilitiesRequestBuilder(ElasticsearchClient, FieldCapabilitiesAction, String...) - Constructor for class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequestBuilder
- FieldCapabilitiesResponse - Class in org.elasticsearch.action.fieldcaps
-
Response for
FieldCapabilitiesRequest
requests. - FieldCapabilitiesResponse(String[], Map<String, Map<String, FieldCapabilities>>) - Constructor for class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
- FieldCapabilitiesResponse(String[], Map<String, Map<String, FieldCapabilities>>, List<FieldCapabilitiesFailure>) - Constructor for class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
- FieldCapabilitiesResponse(StreamInput) - Constructor for class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
- fieldCaps(FieldCapabilitiesRequest) - Method in interface org.elasticsearch.client.Client
-
An action that returns the field capabilities from the provided request
- fieldCaps(FieldCapabilitiesRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- fieldCaps(FieldCapabilitiesRequest, ActionListener<FieldCapabilitiesResponse>) - Method in interface org.elasticsearch.client.Client
-
An action that returns the field capabilities from the provided request
- fieldCaps(FieldCapabilitiesRequest, ActionListener<FieldCapabilitiesResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- fieldContext() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- FieldContext - Class in org.elasticsearch.search.aggregations.support
-
Used by all field data based aggregators.
- FieldContext(String, IndexFieldData<?>, MappedFieldType) - Constructor for class org.elasticsearch.search.aggregations.support.FieldContext
-
Constructs a field data context for the given field and its index field data
- fielddata() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- fielddata(boolean) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- fieldData - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- fieldData() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- fieldData() - Method in class org.elasticsearch.index.shard.IndexShard
- fieldData(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- Fielddata(IndexGeoPointFieldData) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint.Fielddata
- FieldData - Enum Class in org.elasticsearch.index.fielddata
-
Utility methods, similar to Lucene's
DocValues
. - FieldData - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- FieldData(IndexFieldData<?>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.FieldData
- FieldData(IndexNumericFieldData) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
- FieldData(IndexOrdinalsFieldData) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
- FIELDDATA - Static variable in interface org.elasticsearch.common.breaker.CircuitBreaker
-
The fielddata breaker tracks data used for fielddata (on fields) as well as the id cached used for parent/child queries.
- FIELDDATA_CACHE_KEY - Static variable in class org.elasticsearch.index.fielddata.IndexFieldDataService
- FIELDDATA_CACHE_VALUE_NODE - Static variable in class org.elasticsearch.index.fielddata.IndexFieldDataService
- FIELDDATA_CIRCUIT_BREAKER_LIMIT_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- FIELDDATA_CIRCUIT_BREAKER_OVERHEAD_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- FIELDDATA_CIRCUIT_BREAKER_TYPE_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- FIELDDATA_MAX_FREQUENCY - Static variable in class org.elasticsearch.index.mapper.TextFieldMapper.Defaults
- FIELDDATA_MIN_FREQUENCY - Static variable in class org.elasticsearch.index.mapper.TextFieldMapper.Defaults
- FIELDDATA_MIN_SEGMENT_SIZE - Static variable in class org.elasticsearch.index.mapper.TextFieldMapper.Defaults
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.BinaryFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.BooleanScriptFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.DateScriptFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.DoubleScriptFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.RootFlattenedFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.GeoPointScriptFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.IpScriptFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Return a fielddata builder for this field
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypeFieldType
- fielddataBuilder(String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.mapper.TypeFieldType
- fieldDataCache() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- fieldDataCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- fieldDataFields() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- fieldDataFields() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- fieldDataFields(String...) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
Sets specific search group stats to retrieve the stats for.
- fieldDataFields(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- fielddataFrequencyFilter(double, double, int) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- fieldDataStats(String...) - Method in class org.elasticsearch.index.shard.IndexShard
- FieldDataStats - Class in org.elasticsearch.index.fielddata
- FieldDataStats() - Constructor for class org.elasticsearch.index.fielddata.FieldDataStats
- FieldDataStats(long, long, FieldMemoryStats) - Constructor for class org.elasticsearch.index.fielddata.FieldDataStats
- FieldDataStats(StreamInput) - Constructor for class org.elasticsearch.index.fielddata.FieldDataStats
- FieldDataWeigher() - Constructor for class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.FieldDataWeigher
- FieldFetcher - Class in org.elasticsearch.search.fetch.subphase
-
A helper class to
FetchFieldsPhase
that's initialized with a list of field patterns to fetch. - FieldFetcher(Map<String, FieldFetcher.FieldContext>, CharacterRunAutomaton, List<String>) - Constructor for class org.elasticsearch.search.fetch.subphase.FieldFetcher
- FieldHighlightContext - Class in org.elasticsearch.search.fetch.subphase.highlight
- FieldHighlightContext(String, SearchHighlightContext.Field, MappedFieldType, FetchContext, FetchSubPhase.HitContext, Query, boolean, Map<String, Object>) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.FieldHighlightContext
- FieldLookup - Class in org.elasticsearch.search.lookup
- FieldMapper - Class in org.elasticsearch.index.mapper
- FieldMapper(String, MappedFieldType, Map<String, NamedAnalyzer>, FieldMapper.MultiFields, FieldMapper.CopyTo, boolean, String) - Constructor for class org.elasticsearch.index.mapper.FieldMapper
-
Create a FieldMapper that indexes into multiple analyzed fields
- FieldMapper(String, MappedFieldType, NamedAnalyzer, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.FieldMapper
-
Create a FieldMapper with a single associated index analyzer
- FieldMapper(String, MappedFieldType, NamedAnalyzer, FieldMapper.MultiFields, FieldMapper.CopyTo, boolean, String) - Constructor for class org.elasticsearch.index.mapper.FieldMapper
-
Create a FieldMapper with a single associated index analyzer
- FieldMapper(String, MappedFieldType, FieldMapper.MultiFields, FieldMapper.CopyTo) - Constructor for class org.elasticsearch.index.mapper.FieldMapper
-
Create a FieldMapper with no index analyzers
- FieldMapper(String, MappedFieldType, FieldMapper.MultiFields, FieldMapper.CopyTo, boolean, String) - Constructor for class org.elasticsearch.index.mapper.FieldMapper
-
Create a FieldMapper with no index analyzers
- FieldMapper.Builder - Class in org.elasticsearch.index.mapper
-
A Builder for a ParametrizedFieldMapper
- FieldMapper.Conflicts - Class in org.elasticsearch.index.mapper
- FieldMapper.CopyTo - Class in org.elasticsearch.index.mapper
-
Represents a list of fields with optional boost factor where the current field should be copied to
- FieldMapper.CopyTo.Builder - Class in org.elasticsearch.index.mapper
- FieldMapper.MergeValidator<T> - Interface in org.elasticsearch.index.mapper
- FieldMapper.MultiFields - Class in org.elasticsearch.index.mapper
- FieldMapper.MultiFields.Builder - Class in org.elasticsearch.index.mapper
- FieldMapper.Parameter<T> - Class in org.elasticsearch.index.mapper
-
A configurable parameter for a field mapper
- FieldMapper.Serializer<T> - Interface in org.elasticsearch.index.mapper
-
Serializes a parameter
- FieldMapper.SerializerCheck<T> - Interface in org.elasticsearch.index.mapper
-
Check on whether or not a parameter should be serialized
- FieldMapper.TypeParser - Class in org.elasticsearch.index.mapper
-
TypeParser implementation that automatically handles parsing
- fieldMappers() - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Returns an iterable over all the registered field mappers (including alias mappers)
- FieldMappingMetadata(String, BytesReference) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetadata
- fieldMappings(String, String, String) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
-
Returns the mappings of a specific field.
- fieldMaskingSpanQuery(SpanQueryBuilder, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
- FieldMaskingSpanQueryBuilder - Class in org.elasticsearch.index.query
- FieldMaskingSpanQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
-
Read from a stream.
- FieldMaskingSpanQueryBuilder(SpanQueryBuilder, String) - Constructor for class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
-
Constructs a new
FieldMaskingSpanQueryBuilder
given an innerSpanQueryBuilder
for a given field - FieldMemoryStats - Class in org.elasticsearch.common
-
A reusable class to encode
field -> memory size
mappings - FieldMemoryStats(ObjectLongHashMap<String>) - Constructor for class org.elasticsearch.common.FieldMemoryStats
-
Creates a new FieldMemoryStats instance
- FieldMemoryStats(StreamInput) - Constructor for class org.elasticsearch.common.FieldMemoryStats
-
Creates a new FieldMemoryStats instance from a stream
- fieldName - Variable in class org.elasticsearch.index.fielddata.IndexHistogramFieldData
- fieldName - Variable in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointIndexFieldData
- fieldName - Variable in class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData
- fieldName - Variable in class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData
- fieldName - Variable in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData
- fieldName - Variable in class org.elasticsearch.index.fielddata.plain.StringBinaryIndexFieldData
- fieldName - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- fieldName - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- fieldName - Variable in class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Name of field to match against.
- fieldName - Variable in class org.elasticsearch.script.AbstractFieldScript
- fieldName - Variable in class org.elasticsearch.search.fetch.subphase.highlight.FieldHighlightContext
- fieldName() - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- fieldName() - Method in class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Returns the field name used in this query.
- fieldName() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- fieldName() - Method in class org.elasticsearch.index.query.ExistsQueryBuilder
- fieldName() - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- fieldName() - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- fieldName() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- fieldName() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Returns the name of the field to base the bounding box computation on.
- fieldName() - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Name of the field this query is operating on.
- fieldName() - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.
- fieldName() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Returns the field name used in this query.
- fieldName() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Returns the field name used in this query.
- fieldName() - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Returns the field name used in this query.
- fieldName() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Returns the field name used in this query.
- fieldName() - Method in interface org.elasticsearch.index.query.MultiTermQueryBuilder
-
Get the field name for this query.
- fieldName() - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- fieldName() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Get the field name for this query.
- fieldName() - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
-
Returns the field name used in this query.
- fieldName() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- fieldName() - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- fieldName() - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- fieldName() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- fieldName() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns the geo point like field the distance based sort operates on.
- fieldName(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
-
Sets the name of the text field that will be the subject of this aggregation.
- FIELDNAME_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- FIELDNAME_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- fieldNames() - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
-
Gets the field names to load and return as part of the search request.
- FieldNamesFieldMapper - Class in org.elasticsearch.index.mapper
-
A mapper that indexes the field names of a document under
_field_names
. - FieldNamesFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- FieldNamesFieldMapper.FieldNamesFieldType - Class in org.elasticsearch.index.mapper
- FieldNamesProvidingStoredFieldsVisitor - Class in org.elasticsearch.index.fieldvisitor
-
Stored fields visitor which provides information about the field names that will be requested
- FieldNamesProvidingStoredFieldsVisitor() - Constructor for class org.elasticsearch.index.fieldvisitor.FieldNamesProvidingStoredFieldsVisitor
- fieldOptions() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.Field
- FieldOptions() - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- fields() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- fields() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- fields() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- fields() - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageShardRequest
- fields() - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsRequest
- fields() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- fields() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- fields() - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- fields() - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- fields() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- fields() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- fields() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- fields() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Returns the fields including their respective boosts to run the query against.
- fields() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns the fields including their respective boosts to run the query against.
- fields() - Method in class org.elasticsearch.search.fetch.subphase.FetchDocValuesContext
-
Returns the required docvalue fields.
- fields() - Method in class org.elasticsearch.search.fetch.subphase.FetchFieldsContext
- fields() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- fields() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext
- fields() - Method in class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext
- fields() - Method in class org.elasticsearch.search.lookup.FieldLookup
- fields() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
- fields(String) - Method in class org.elasticsearch.script.DocBasedScript
- fields(String) - Method in interface org.elasticsearch.script.DocReader
-
New-style field iterator
- fields(String) - Method in class org.elasticsearch.script.DocValuesDocReader
- fields(String...) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- fields(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- fields(String...) - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsRequest
- fields(String...) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
-
The list of field names to retrieve
- fields(String...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- fields(Map<String, Float>) - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
-
Add several fields to run the query against with a specific boost.
- fields(Map<String, Float>) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Add several fields to run the query against with a specific boost.
- fields(Map<String, Float>) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Add several fields to run the query against with a specific boost.
- fields(Map<String, Float>) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Add several fields to run the query against with a specific boost.
- fields(Map<String, List<Object>>) - Method in class org.elasticsearch.search.lookup.FieldLookup
-
Sets the post processed values.
- fields(IndexReader) - Static method in class org.elasticsearch.index.termvectors.TermVectorsService
- Fields() - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Fields
- Fields() - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineRequest.Fields
- Fields() - Constructor for class org.elasticsearch.index.mapper.CompletionFieldMapper.Fields
- Fields() - Constructor for class org.elasticsearch.search.SearchHit.Fields
- Fields() - Constructor for class org.elasticsearch.search.SearchHits.Fields
- FIELDS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- FIELDS_SET - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- FieldScript - Class in org.elasticsearch.script
-
A script to produce dynamic values for return fields.
- FieldScript() - Constructor for class org.elasticsearch.script.FieldScript
- FieldScript(Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.FieldScript
- FieldScript.Factory - Interface in org.elasticsearch.script
- FieldScript.LeafFactory - Interface in org.elasticsearch.script
-
A factory to construct
FieldScript
instances. - FieldScriptStats - Class in org.elasticsearch.action.admin.cluster.stats
-
Holds stats about the content of a script
- fieldSort(String) - Static method in class org.elasticsearch.search.sort.SortBuilders
-
Constructs a new field based sort.
- FieldSortBuilder - Class in org.elasticsearch.search.sort
-
A sort builder to sort based on a document field.
- FieldSortBuilder(String) - Constructor for class org.elasticsearch.search.sort.FieldSortBuilder
-
Constructs a new sort based on a document field.
- FieldSortBuilder(StreamInput) - Constructor for class org.elasticsearch.search.sort.FieldSortBuilder
-
Read from a stream.
- FieldSortBuilder(FieldSortBuilder) - Constructor for class org.elasticsearch.search.sort.FieldSortBuilder
-
Copy constructor.
- fieldStatistics() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- fieldStatistics() - Method in class org.elasticsearch.search.dfs.AggregatedDfs
- fieldStatistics() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- fieldStatistics(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the field statistics for each term in the shard or skip.
- fieldStatistics(ObjectObjectHashMap<String, CollectionStatistics>) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- FieldStatistics - Enum constant in enum class org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
- FieldStats - Class in org.elasticsearch.action.admin.cluster.stats
-
Holds stats about a mapped field.
- fieldsValues - Variable in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- FieldsVisitor - Class in org.elasticsearch.index.fieldvisitor
-
Base
StoredFieldVisitor
that retrieves all non-redundant metadata. - FieldsVisitor(boolean) - Constructor for class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- FieldsVisitor(boolean, String) - Constructor for class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- fieldType - Variable in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSource
- fieldType - Variable in class org.elasticsearch.search.fetch.subphase.highlight.FieldHighlightContext
- fieldType - Variable in class org.elasticsearch.search.fetch.subphase.highlight.SimpleFragmentsBuilder
- fieldType() - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.CustomDocValuesField
- fieldType() - Method in class org.elasticsearch.index.mapper.DateFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.DocCountFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.FieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.IpFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper
- fieldType() - Method in class org.elasticsearch.index.mapper.TextFieldMapper
- fieldType() - Method in class org.elasticsearch.search.aggregations.support.FieldContext
- fieldType() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
Convenience method for looking up the mapped field type backing this values source, if it exists.
- fieldType(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
Given the full name of a field, returns its
MappedFieldType
. - fieldType(String) - Method in class org.elasticsearch.search.lookup.SearchLookup
- FieldUsageShardRequest - Class in org.elasticsearch.action.admin.indices.stats
- FieldUsageShardResponse - Class in org.elasticsearch.action.admin.indices.stats
- fieldUsageStats(String...) - Method in class org.elasticsearch.index.shard.IndexShard
- FieldUsageStats - Class in org.elasticsearch.index.search.stats
- FieldUsageStats() - Constructor for class org.elasticsearch.index.search.stats.FieldUsageStats
- FieldUsageStats(Map<String, FieldUsageStats.PerFieldUsageStats>) - Constructor for class org.elasticsearch.index.search.stats.FieldUsageStats
- FieldUsageStats(StreamInput) - Constructor for class org.elasticsearch.index.search.stats.FieldUsageStats
- FieldUsageStats.PerFieldUsageStats - Class in org.elasticsearch.index.search.stats
- FieldUsageStats.UsageContext - Enum Class in org.elasticsearch.index.search.stats
- FieldUsageStatsAction - Class in org.elasticsearch.action.admin.indices.stats
- FieldUsageStatsRequest - Class in org.elasticsearch.action.admin.indices.stats
- FieldUsageStatsRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsRequest
- FieldUsageStatsRequest(String[], IndicesOptions) - Constructor for class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsRequest
- FieldUsageStatsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsRequest
- FieldUsageStatsResponse - Class in org.elasticsearch.action.admin.indices.stats
- FieldUsageStatsTrackingSession() - Constructor for class org.elasticsearch.index.search.stats.ShardFieldUsageTracker.FieldUsageStatsTrackingSession
- FieldUsageTrackingDirectoryReader - Class in org.elasticsearch.search.internal
-
Wraps a DirectoryReader and tracks all access to fields, notifying a
FieldUsageTrackingDirectoryReader.FieldUsageNotifier
upon access. - FieldUsageTrackingDirectoryReader(DirectoryReader, FieldUsageTrackingDirectoryReader.FieldUsageNotifier) - Constructor for class org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader
- FieldUsageTrackingDirectoryReader.FieldUsageNotifier - Interface in org.elasticsearch.search.internal
- fieldValueFactorFunction(String) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- FieldValueFactorFunction - Class in org.elasticsearch.common.lucene.search.function
-
A function_score function that multiplies the score with the value of a field from the document, optionally multiplying the field by a factor first, and applying a modification (log, ln, sqrt, square, etc) afterwards.
- FieldValueFactorFunction(String, float, FieldValueFactorFunction.Modifier, Double, IndexNumericFieldData) - Constructor for class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction
- FieldValueFactorFunction.Modifier - Enum Class in org.elasticsearch.common.lucene.search.function
-
The Type class encapsulates the modification types that can be applied to the score/value product.
- FieldValueFactorFunctionBuilder - Class in org.elasticsearch.index.query.functionscore
-
Builder to construct
field_value_factor
functions for a function score query. - FieldValueFactorFunctionBuilder(String) - Constructor for class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- FieldValueFactorFunctionBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
-
Read from a stream.
- FieldValues<T> - Interface in org.elasticsearch.search.lookup
-
Represents values for a given document
- fifteenMinutes - Variable in class org.elasticsearch.script.ScriptContextStats.TimeSeries
- file - Variable in class org.elasticsearch.bootstrap.PluginPolicyInfo
- file(String) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
- FILE_BASED_RECOVERY_THRESHOLD_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Determines a balance between file-based and operations-based peer recoveries.
- FILE_CHUNK - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- FILE_INFO_WRITER_UUIDS_IN_SHARD_DATA_VERSION - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- FileBasedSeedHostsProvider - Class in org.elasticsearch.discovery
-
An implementation of
SeedHostsProvider
that reads hosts/ports fromFileBasedSeedHostsProvider.UNICAST_HOSTS_FILE
. - FileBasedSeedHostsProvider(Path) - Constructor for class org.elasticsearch.discovery.FileBasedSeedHostsProvider
- FileChangesListener - Interface in org.elasticsearch.watcher
-
Callback interface that file changes File Watcher is using to notify listeners about changes.
- FileDetail(String, long, boolean) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.FileDetail
- FileDetail(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.FileDetail
- fileDetails - Variable in class org.elasticsearch.indices.recovery.RecoveryState.Index
- fileDetails - Variable in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- fileDetails() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- fileExists(String) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
- FileInfo(String, StoreFileMetadata, ByteSizeValue) - Constructor for class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Constructs a new instance of file info
- FileInfo(StreamInput) - Constructor for class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
- FilePermissionUtils - Class in org.elasticsearch.bootstrap
- FileRestoreContext - Class in org.elasticsearch.repositories.blobstore
-
This context will execute a file restore of the lucene files.
- FileRestoreContext(String, ShardId, SnapshotId, RecoveryState) - Constructor for class org.elasticsearch.repositories.blobstore.FileRestoreContext
-
Constructs new restore context
- files(Path) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Returns an array of all files in the given directory.
- files(Path, String) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Returns an array of all files in the given directory matching the glob.
- files(Path, DirectoryStream.Filter<Path>) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Returns an array of all files in the given directory matching.
- files(SegmentInfos) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Returns an iterable that allows to iterate over all files in this segments info
- FILES_INFO - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- FileStats(String, long, long, long, long) - Constructor for class org.elasticsearch.index.engine.SegmentsStats.FileStats
- fileStore - Variable in class org.elasticsearch.env.NodeEnvironment.DataPath
-
Cached FileStore from path
- FileSystemNatives - Class in org.elasticsearch.common.filesystem
-
This class provides utility methods for calling some native methods related to filesystems.
- FileSystemUtils - Class in org.elasticsearch.common.io
-
Elasticsearch utils to work with
Path
- FileWatcher - Class in org.elasticsearch.watcher
-
File resources watcher The file watcher checks directory and all its subdirectories for file changes and notifies its listeners accordingly
- FileWatcher(Path) - Constructor for class org.elasticsearch.watcher.FileWatcher
-
Creates new file watcher on the given directory
- FileWatcher(Path, boolean) - Constructor for class org.elasticsearch.watcher.FileWatcher
-
Creates new file watcher on the given directory
- fill(long, long, byte) - Method in interface org.elasticsearch.common.util.ByteArray
-
Fill slots between
fromIndex
inclusive totoIndex
exclusive withvalue
. - fill(long, long, double) - Method in interface org.elasticsearch.common.util.DoubleArray
-
Fill slots between
fromIndex
inclusive totoIndex
exclusive withvalue
. - fill(long, long, float) - Method in interface org.elasticsearch.common.util.FloatArray
-
Fill slots between
fromIndex
inclusive totoIndex
exclusive withvalue
. - fill(long, long, int) - Method in interface org.elasticsearch.common.util.IntArray
-
Fill slots between
fromIndex
inclusive totoIndex
exclusive withvalue
. - fill(long, long, long) - Method in interface org.elasticsearch.common.util.LongArray
-
Fill slots between
fromIndex
inclusive totoIndex
exclusive withvalue
. - fillBytesRef(BytesRefBuilder) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- fillDocIdsToLoad(int, ScoreDoc[]) - Method in class org.elasticsearch.action.search.SearchPhaseController
-
Builds an array, with potential null elements, with docs to load.
- fillInStackTrace() - Method in exception org.elasticsearch.cluster.NotMasterException
- fillInStackTrace() - Method in exception org.elasticsearch.discovery.zen.MasterFaultDetection.ThisIsNotTheMasterYouAreLookingForException
- fillInStackTrace() - Method in exception org.elasticsearch.index.engine.VersionConflictEngineException
- fillInStackTrace() - Method in exception org.elasticsearch.repositories.RepositoryVerificationException
- fillInStackTrace() - Method in exception org.elasticsearch.transport.NodeDisconnectedException
- fillInStackTrace() - Method in exception org.elasticsearch.transport.NotSerializableTransportException
- fillInStackTrace() - Method in exception org.elasticsearch.transport.ReceiveTimeoutTransportException
- fillInStackTrace() - Method in exception org.elasticsearch.transport.RemoteTransportException
- fillInStackTrace() - Method in exception org.elasticsearch.transport.ResponseHandlerFailureTransportException
- fillInStackTrace() - Method in exception org.elasticsearch.transport.TransportNotReadyException
- fillSegmentStats(SegmentReader, boolean, SegmentsStats) - Method in class org.elasticsearch.index.engine.Engine
- fillSeqNoGaps(long) - Method in class org.elasticsearch.index.engine.Engine
-
Fills up the local checkpoints history with no-ops until the local checkpoint and the max seen sequence ID are identical.
- fillSeqNoGaps(long) - Method in class org.elasticsearch.index.engine.InternalEngine
- fillSeqNoGaps(long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- filter - Variable in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.FilterScoreFunction
- filter() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Returns the filter associated with the alias
- filter() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- filter() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- filter() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Gets the queries that must appear in the matching documents but don't contribute to scoring
- filter() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- filter() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
- filter(Class<T>) - Method in class org.elasticsearch.search.suggest.Suggest
- filter(String) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Associates a filter to the alias
- filter(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- filter(String) - Method in class org.elasticsearch.cluster.metadata.AliasMetadata.Builder
- filter(String[], String[]) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
-
Returns a function that filters a document map based on the given include and exclude rules.
- filter(String, QueryBuilder) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Filter
aggregation with the given name. - filter(Predicate<String>) - Method in class org.elasticsearch.common.settings.Settings
-
Returns a new settings object that contains all setting of the current one filtered by the given settings key predicate.
- filter(Map<String, ?>, String[], String[]) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
-
Only keep properties in
map
that match theincludes
but not theexcludes
. - filter(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Associates a filter to the alias
- filter(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- filter(Map<String, Object>) - Method in class org.elasticsearch.cluster.metadata.AliasMetadata.Builder
- filter(LogEvent) - Method in class org.elasticsearch.common.logging.RateLimitingFilter
- filter(Logger, Level, Marker, Message, Throwable) - Method in class org.elasticsearch.common.logging.RateLimitingFilter
- filter(Message) - Method in class org.elasticsearch.common.logging.RateLimitingFilter
- filter(IntervalsSource, SearchExecutionContext, MappedFieldType) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.IntervalFilter
- filter(CompressedXContent) - Method in class org.elasticsearch.cluster.metadata.AliasMetadata.Builder
- filter(Settings) - Method in class org.elasticsearch.common.settings.SettingsFilter
- filter(QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Associates a filter to the alias
- filter(QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- filter(QueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Adds a query that must appear in the matching documents but will not contribute to scoring.
- filter(QueryBuilder) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Set the query that will filter the source.
- filter(FetchSourceContext) - Method in class org.elasticsearch.search.lookup.SourceLookup
- Filter - Interface in org.elasticsearch.search.aggregations.bucket.filter
-
A
filter
aggregation. - Filter() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.Filter
- FILTER - Static variable in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- FILTER_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStreamAlias
- FILTER_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- FILTER_FIELD - Static variable in class org.elasticsearch.search.sort.NestedSortBuilder
- FilterableTermsEnum - Class in org.elasticsearch.common.lucene.index
-
A frequency TermsEnum that returns frequencies derived from a collection of cached leaf termEnums.
- FilterableTermsEnum(IndexReader, String, int, Query) - Constructor for class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- FilterAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.filter
- FilterAggregationBuilder(String, QueryBuilder) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- FilterAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
-
Read from a stream.
- FilterAggregationBuilder(FilterAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- FilterAggregator - Class in org.elasticsearch.search.aggregations.bucket.filter
-
Aggregate all docs that match a filter.
- FilterAggregator(String, Supplier<Weight>, AggregatorFactories, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator
- FilterAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.filter
- FilterAggregatorFactory(String, QueryBuilder, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregatorFactory
- FilterAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This
AllocationDecider
control shard allocation by include and exclude filters via dynamic cluster and index routing settings. - FilterAllocationDecider(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
- FilterBlobContainer - Class in org.elasticsearch.common.blobstore.support
- FilterBlobContainer(BlobContainer) - Constructor for class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- FilterByFilterAggregator - Class in org.elasticsearch.search.aggregations.bucket.filter
-
Collects results by running each filter against the searcher and doesn't build any
LeafBucketCollector
s which is generally faster thanFiltersAggregator.Compatible
but doesn't support when there is a parent aggregator or any child aggregators. - FilterByFilterAggregator.AdapterBuilder<T> - Class in org.elasticsearch.search.aggregations.bucket.filter
-
Builds
FilterByFilterAggregator
when the filters are valid and it would be faster than a "native" aggregation implementation. - FilterClient - Class in org.elasticsearch.client
- FilterClient(Client) - Constructor for class org.elasticsearch.client.FilterClient
-
Creates a new FilterClient
- FilterClient(Settings, ThreadPool, Client) - Constructor for class org.elasticsearch.client.FilterClient
-
A Constructor that allows to pass settings and threadpool separately.
- filterCustomsForPre63Clients(ClusterState) - Static method in class org.elasticsearch.cluster.ClusterModule
-
For interoperability with transport clients older than 6.3, we need to strip customs from the cluster state that the client might not be able to deserialize
- filterDuplicateText(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
-
Control if duplicate paragraphs of text should try be filtered from the statistical text analysis.
- filtered(Query, Query) - Static method in class org.elasticsearch.common.lucene.search.Queries
- Filtered - Enum constant in enum class org.elasticsearch.common.settings.Setting.Property
-
should be filtered in some api (mask password/credentials)
- FilteredCollector - Class in org.elasticsearch.common.lucene.search
- FilteredCollector(Collector, Weight) - Constructor for class org.elasticsearch.common.lucene.search.FilteredCollector
- filteredNodes() - Method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.The list of filtered nodes that were not connected to, for example, due to mismatch in cluster name.
- FilteredSearchContext - Class in org.elasticsearch.search.internal
- FilteredSearchContext(SearchContext) - Constructor for class org.elasticsearch.search.internal.FilteredSearchContext
- FilterFieldNamesProvidingStoredFieldsVisitor - Class in org.elasticsearch.search.internal
- FilterFieldNamesProvidingStoredFieldsVisitor(FieldNamesProvidingStoredFieldsVisitor) - Constructor for class org.elasticsearch.search.internal.FilterFieldNamesProvidingStoredFieldsVisitor
- FilterFunctionBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
-
Read from a stream.
- FilterFunctionBuilder(ScoreFunctionBuilder<?>) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- FilterFunctionBuilder(QueryBuilder, ScoreFunctionBuilder<?>) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- filterFunctionBuilders() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Returns the filters and functions
- filterHeaders(Map<String, List<String>>) - Method in class org.elasticsearch.rest.RestResponse
- FilterIndexCommit - Class in org.elasticsearch.common.lucene
- FilterIndexCommit(IndexCommit) - Constructor for class org.elasticsearch.common.lucene.FilterIndexCommit
- FilterIndexOutput - Class in org.elasticsearch.common.lucene.store
-
IndexOutput that delegates all calls to another IndexOutput
- FilterIndexOutput(String, IndexOutput) - Constructor for class org.elasticsearch.common.lucene.store.FilterIndexOutput
- filterIndices(List<String>, String[], IndicesOptions) - Static method in class org.elasticsearch.snapshots.SnapshotUtils
-
Filters out list of available indices based on the list of selected indices.
- filteringAlias() - Method in class org.elasticsearch.action.explain.ExplainRequest
- filteringAlias(AliasFilter) - Method in class org.elasticsearch.action.explain.ExplainRequest
- filteringAliases() - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- filteringAliases(ClusterState, String, Set<String>) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Iterates through the list of indices and selects the effective list of filtering aliases for the given index.
- filteringRequired() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- filteringRequired() - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
- filterNodeIds(DiscoveryNodes, String[]) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- filterPlugins(Class<T>) - Method in class org.elasticsearch.plugins.PluginsService
- filterQuery(Query) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Add filters from slice or filtered aliases.
- filterQuery(Query) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- FilterRepository - Class in org.elasticsearch.repositories
- FilterRepository(Repository) - Constructor for class org.elasticsearch.repositories.FilterRepository
- filters() - Method in class org.elasticsearch.action.support.ActionFilters
-
Returns the action filters that have been injected
- filters() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
-
Get the filters.
- filters() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
-
Get the filters.
- filters(String, QueryBuilder...) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Filters
aggregation with the given name. - filters(String, FiltersAggregator.KeyedFilter...) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Filters
aggregation with the given name. - Filters - Interface in org.elasticsearch.search.aggregations.bucket.filter
-
A multi bucket aggregation where the buckets are defined by a set of filters (a bucket per filter).
- FILTERS_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator
- FILTERS_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
- Filters.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.filter
-
A bucket associated with a specific filter (identified by its key)
- FiltersAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.filter
- FiltersAggregationBuilder(String, QueryBuilder...) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- FiltersAggregationBuilder(String, FiltersAggregator.KeyedFilter...) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- FiltersAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
-
Read from a stream.
- FiltersAggregationBuilder(FiltersAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- FiltersAggregator - Class in org.elasticsearch.search.aggregations.bucket.filter
-
Aggregator for
filters
. - FiltersAggregator.KeyedFilter - Class in org.elasticsearch.search.aggregations.bucket.filter
- FiltersAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.filter
- FiltersAggregatorFactory(String, List<FiltersAggregator.KeyedFilter>, boolean, boolean, String, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregatorFactory
- FilterScoreFunction(Query, ScoreFunction) - Constructor for class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.FilterScoreFunction
- FilterScript - Class in org.elasticsearch.script
-
A script implementation of a query filter.
- FilterScript(Map<String, Object>, SearchLookup, DocReader) - Constructor for class org.elasticsearch.script.FilterScript
- FilterScript.Factory - Interface in org.elasticsearch.script
-
A factory to construct stateful
FilterScript
factories for a specific index. - FilterScript.LeafFactory - Interface in org.elasticsearch.script
-
A factory to construct
FilterScript
instances. - filterSettings() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the settings for filtering out terms.
- filterSettings(TermVectorsRequest.FilterSettings) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Sets the settings for filtering out terms.
- filterSettings(ToXContent.Params, Settings) - Static method in class org.elasticsearch.common.settings.SettingsFilter
- FilterSettings() - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- FilterSettings(Integer, Integer, Integer, Integer, Integer, Integer, Integer) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- FilterStoredFieldVisitor - Class in org.elasticsearch.search.internal
- FilterStoredFieldVisitor(StoredFieldVisitor) - Constructor for class org.elasticsearch.search.internal.FilterStoredFieldVisitor
- FilterStreamInput - Class in org.elasticsearch.common.io.stream
-
Wraps a
StreamInput
and delegates to it. - FilterStreamInput(StreamInput) - Constructor for class org.elasticsearch.common.io.stream.FilterStreamInput
- filterWithHeader(Map<String, String>) - Method in interface org.elasticsearch.client.Client
-
Returns a new lightweight Client that applies all given headers to each of the requests issued from it.
- filterWithHeader(Map<String, String>) - Method in class org.elasticsearch.client.support.AbstractClient
- Final - Enum constant in enum class org.elasticsearch.common.settings.Setting.Property
-
mark this setting as final, not updateable even when the context is not dynamic ie.
- FINAL_PIPELINE - Static variable in class org.elasticsearch.index.IndexSettings
- finalFailure - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryResult
- FINALIZE - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Snapshot metadata is being written or this shard's status in the cluster state is being updated
- FINALIZE - Enum constant in enum class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Snapshot metadata is being written
- FINALIZE - Enum constant in enum class org.elasticsearch.indices.recovery.RecoveryState.Stage
-
performing final task after all translog ops have been done
- FINALIZE - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- finalizeRecovery() - Method in class org.elasticsearch.index.shard.IndexShard
-
perform the last stages of recovery once all translog operations are done.
- finalizeRecovery(long, long, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- finalizeRecovery(long, long, ActionListener<Void>) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
The finalize request refreshes the engine now that new segments are available, enables garbage collection of tombstone files, updates the global checkpoint.
- finalizeRecovery(long, long, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- finalizeSnapshot(FinalizeSnapshotContext) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- finalizeSnapshot(FinalizeSnapshotContext) - Method in class org.elasticsearch.repositories.FilterRepository
- finalizeSnapshot(FinalizeSnapshotContext) - Method in interface org.elasticsearch.repositories.Repository
-
Finalizes snapshotting process
- FinalizeSnapshotContext - Class in org.elasticsearch.repositories
-
Context for finalizing a snapshot.
- FinalizeSnapshotContext(ShardGenerations, long, Metadata, SnapshotInfo, Version, ActionListener<Tuple<RepositoryData, SnapshotInfo>>) - Constructor for class org.elasticsearch.repositories.FinalizeSnapshotContext
- finalResponseIfSuccessful - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryResult
- find(long) - Method in class org.elasticsearch.common.util.LongHash
-
Get the id associated with
key
or -1 if the key is not contained in the hash. - find(long, long) - Method in class org.elasticsearch.common.util.LongLongHash
-
Get the id associated with
key
or -1 if the key is not contained in the hash. - find(long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds
-
Find the
owningBucketOrd, value
pair. - find(long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromMany
- find(long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromManySmall
- find(long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromSingle
- find(BytesRef) - Method in class org.elasticsearch.common.util.BytesRefHash
-
Sugar for
find(key, key.hashCode()
- find(BytesRef, int) - Method in class org.elasticsearch.common.util.BytesRefHash
-
Get the id associated with
key
- findAliases(AliasesRequest, String[]) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Finds the specific index aliases that match with the specified aliases directly or partially via wildcards, and that point to the specified concrete indices (directly or matching indices via wildcards).
- findAllAliases(String[]) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Finds the specific index aliases that point to the requested concrete indices directly or that match with the indices via wildcards.
- findAllShardIds(Index) - Method in class org.elasticsearch.env.NodeEnvironment
-
Tries to find all allocated shards for the given index on the current node.
- findAndProcessShardPath(OptionSet, Environment, Path[], int, ClusterState, CheckedConsumer<ShardPath, IOException>) - Method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- findAppender(Logger, Class<? extends Appender>) - Static method in class org.elasticsearch.common.logging.Loggers
- findBindingAnnotation(Errors, Member, Annotation[]) - Static method in class org.elasticsearch.common.inject.internal.Annotations
-
Returns the binding annotation on
member
, or null if there isn't one. - findBindingsByType(TypeLiteral<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns all explicit bindings for
type
. - findByAddress(TransportAddress) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get a node by its address
- findConflictingV1Templates(ClusterState, String, List<String>) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Return a map of v1 template names to their index patterns for v1 templates that would overlap with the given v2 template's index patterns.
- findConflictingV2Templates(ClusterState, String, List<String>) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Return a map of v2 template names to their index patterns for v2 templates that would overlap with the given template's index patterns.
- FindDanglingIndexAction - Class in org.elasticsearch.action.admin.indices.dangling.find
-
Represents a request to find a particular dangling index by UUID.
- FindDanglingIndexRequest - Class in org.elasticsearch.action.admin.indices.dangling.find
- FindDanglingIndexRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.dangling.find.FindDanglingIndexRequest
- FindDanglingIndexRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.dangling.find.FindDanglingIndexRequest
- FindDanglingIndexResponse - Class in org.elasticsearch.action.admin.indices.dangling.find
-
Models a response to a
FindDanglingIndexRequest
. - FindDanglingIndexResponse(ClusterName, List<NodeFindDanglingIndexResponse>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.indices.dangling.find.FindDanglingIndexResponse
- FindDanglingIndexResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.dangling.find.FindDanglingIndexResponse
- findDataStreams(String...) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Finds the parent data streams, if any, for the specified concrete indices.
- findDeadlocks() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer
- findDynamicTemplate(String, DynamicTemplate.XContentFieldType) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Find a dynamic mapping template for the given field and its matching type
- findForcedDeletesMerges(SegmentInfos, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.ShuffleForcedMergePolicy
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.apache.lucene.index.ShuffleForcedMergePolicy
- findForcedMerges(SegmentInfos, int, Map<SegmentCommitInfo, Boolean>, MergePolicy.MergeContext) - Method in class org.elasticsearch.index.shard.ElasticsearchMergePolicy
- findHeaderByName(String) - Method in class org.elasticsearch.common.Table
- findMappings(String[], String[], Function<String, Predicate<String>>, Runnable) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Finds all mappings for types and concrete indices.
- findMatchingDataStreamDescriptor(String) - Method in class org.elasticsearch.indices.SystemIndices
-
Finds a single matching
SystemDataStreamDescriptor
, if any, for the given DataStream name. - findMatchingDescriptor(String) - Method in class org.elasticsearch.indices.SystemIndices
-
Finds a single matching
SystemIndexDescriptor
, if any, for the given index name. - findNameFile(String) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
-
Finds reference to a snapshotted file by its snapshot name
- findNewDanglingIndices(Map<Index, IndexMetadata>, Metadata) - Method in class org.elasticsearch.gateway.DanglingIndicesState
-
Finds new dangling indices by iterating over the indices and trying to find indices that have state on disk, but are not part of the provided metadata, or not detected as dangled already.
- findNextDelayedAllocation(long, ClusterState) - Static method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Finds the next (closest) delay expiration of an delayed shard in nanoseconds based on current time.
- findPhysicalIndexFile(String) - Method in class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
-
Returns information about a physical file with the given name
- findPhysicalIndexFiles(String) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
-
Finds reference to a snapshotted file by its original name
- findPluginDirs(Path) - Static method in class org.elasticsearch.plugins.PluginsService
-
Extracts all installed plugin directories from the provided
rootPath
. - findSafeCommitPoint(List<IndexCommit>, long) - Static method in class org.elasticsearch.index.engine.CombinedDeletionPolicy
-
Find a safe commit point from a list of existing commits based on the supplied global checkpoint.
- findSafeIndexCommit(long) - Method in class org.elasticsearch.index.store.Store
-
Returns a
SequenceNumbers.CommitInfo
of the safe commit if exists. - findScopeAnnotation(Errors, Annotation[]) - Static method in class org.elasticsearch.common.inject.internal.Annotations
-
Returns the scoping annotation, or null if there isn't one.
- findScopeAnnotation(Errors, Class<?>) - Static method in class org.elasticsearch.common.inject.internal.Annotations
-
Returns the scope annotation on
type
, or null if none is specified. - findShardToExplain(ClusterAllocationExplainRequest, RoutingAllocation) - Static method in class org.elasticsearch.action.admin.cluster.allocation.TransportClusterAllocationExplainAction
- findTasks(String, Predicate<PersistentTasksCustomMetadata.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- findV1Templates(Metadata, String, Boolean) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Finds index templates whose index pattern matched with the given index name.
- findV2Template(Metadata, String, boolean) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Return the name (id) of the highest matching index template for the given index name.
- finish() - Method in class org.elasticsearch.search.fetch.FetchProfiler
-
Finish profiling at the current time.
- finish() - Method in class org.elasticsearch.transport.ReuseBuffersLZ4BlockOutputStream
-
Same as
ReuseBuffersLZ4BlockOutputStream.close()
except that it doesn't close the underlying stream. - finish(long) - Method in class org.elasticsearch.search.fetch.FetchProfiler
-
Finish profiling at a fixed time.
- finishAggregation() - Method in class org.elasticsearch.transport.InboundAggregator
- finishConstruction() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- finishHim() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- finishPart(T) - Method in class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
-
Finish writing the current buffer contents to storage and track them by the given
partId
. - finishPingingRound(UnicastZenPing.PingingRound) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
- finishRelocation(AllocationId) - Static method in class org.elasticsearch.cluster.routing.AllocationId
-
Creates a new allocation id finalizing a relocation.
- first() - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- FIRST - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- FIRST - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.composite.MissingOrder
-
Place buckets for missing values first.
- firstListElementsToCommaDelimitedString(List<T>, Function<T, String>, boolean) - Static method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Internal helper to cap the number of elements in a potentially long list for logging.
- firstMissingLocalTime() - Method in class org.elasticsearch.common.LocalTimeOffset.Gap
-
The first time that is missing from the local time because of this gap.
- firstNonOverlappingLocalTime() - Method in class org.elasticsearch.common.LocalTimeOffset.Overlap
-
The first local time after the overlap stops.
- firstOverlappingLocalTime() - Method in class org.elasticsearch.common.LocalTimeOffset.Overlap
-
The first local time to be appear twice.
- fiveMinutes - Variable in class org.elasticsearch.script.ScriptContextStats.TimeSeries
- FIXED - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
- FIXED - Enum constant in enum class org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
- FIXED_16 - Enum constant in enum class org.elasticsearch.index.mapper.RangeType.LengthType
- FIXED_4 - Enum constant in enum class org.elasticsearch.index.mapper.RangeType.LengthType
- FIXED_8 - Enum constant in enum class org.elasticsearch.index.mapper.RangeType.LengthType
- FIXED_AUTO_QUEUE_SIZE - Enum constant in enum class org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
- FIXED_TIMESTAMP_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStream.TimestampField
- FixedExecutorBuilder - Class in org.elasticsearch.threadpool
-
A builder for fixed executors.
- FixedExecutorBuilder(Settings, String, int, int, String) - Constructor for class org.elasticsearch.threadpool.FixedExecutorBuilder
-
Construct a fixed executor builder.
- FixedExecutorBuilder(Settings, String, int, int, String, boolean) - Constructor for class org.elasticsearch.threadpool.FixedExecutorBuilder
-
Construct a fixed executor builder.
- fixedInRange(long, long) - Method in class org.elasticsearch.common.LocalTimeOffset.Lookup
-
If the offset for a range is constant then return it, otherwise return
null
. - fixedInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Sets the interval of the DateHistogram using fixed units (`1ms`, `1s`, `10m`, `4h`, etc).
- fixedInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Sets the interval of the DateHistogram using fixed units (`1ms`, `1s`, `10m`, `4h`, etc).
- fixedInterval(DateHistogramInterval) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalConsumer
- fixedInterval(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
-
Sets the interval of the DateHistogram using fixed units (`1ms`, `1s`, `10m`, `4h`, etc).
- fixedOffset(ZoneId) - Static method in class org.elasticsearch.common.LocalTimeOffset
-
Lookup offsets without any known min or max time.
- fixedRoundingPoints() - Method in interface org.elasticsearch.common.Rounding.Prepared
-
If this rounding mechanism precalculates rounding points then this array stores dates such that each date between each entry.
- FixedTypeParser(Function<MappingParserContext, MetadataFieldMapper>) - Constructor for class org.elasticsearch.index.mapper.MetadataFieldMapper.FixedTypeParser
- fixNegativeQueryIfNeeded(Query) - Static method in class org.elasticsearch.common.lucene.search.Queries
- fixParent(Aggregator) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories
-
This returns a copy of
AggregatorFactories
modified so that calls toAggregatorFactories.createSubAggregators(org.elasticsearch.search.aggregations.Aggregator, org.elasticsearch.search.aggregations.CardinalityUpperBound)
will ignore the provided parent aggregator and always usefixedParent
provided in to this method. - fixRedundantIncludes() - Method in class org.elasticsearch.index.mapper.RootObjectMapper
-
Removes redundant root includes in
NestedObjectMapper
trees to avoid duplicate fields on the root mapper whenisIncludeInRoot
istrue
for a node that is itself included into a parent node, for which eitherisIncludeInRoot
istrue
or which is transitively included in root by a chain of nodes withisIncludeInParent
returningtrue
. - fixShardGeneration(ShardGeneration) - Static method in class org.elasticsearch.repositories.ShardGenerations
-
Filters out unreliable numeric shard generations read from
RepositoryData
orIndexShardSnapshotStatus
, returningnull
in their place. - fixWeightedFragInfo(FieldFragList.WeightedFragInfo) - Static method in class org.elasticsearch.search.fetch.subphase.highlight.FragmentBuilderHelper
-
Fixes problems with broken analysis chains if positions and offsets are messed up that can lead to
StringIndexOutOfBoundsException
in theFastVectorHighlighter
- flags() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
Returns the underlying stats flags.
- flags() - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- flags(int) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- flags(CommonStatsFlags) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
Sets the underlying stats flags.
- flags(RegexpFlag...) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- flags(SimpleQueryStringFlag...) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Specify the enabled features of the SimpleQueryString.
- flagsFromString(String) - Static method in class org.elasticsearch.common.regex.Regex
- flagsToString(int) - Static method in class org.elasticsearch.common.regex.Regex
- flatten(Iterable<? extends Iterable<T>>) - Static method in class org.elasticsearch.common.util.iterable.Iterables
-
Flattens the two level
Iterable
into a singleIterable
. - flatten(Map<String, Object>, boolean, boolean) - Static method in class org.elasticsearch.common.util.Maps
-
Returns an array where all internal maps and optionally arrays are flattened into the root map.
- flatten(Query, IndexReader, Collection<Query>, float) - Method in class org.apache.lucene.search.vectorhighlight.CustomFieldQuery
- flattenAllProcessors() - Method in class org.elasticsearch.ingest.Pipeline
-
Flattens the normal and on failure processors into a single list.
- FlattenedFieldMapper - Class in org.elasticsearch.index.mapper.flattened
-
A field mapper that accepts a JSON object and flattens it into a single field.
- FlattenedFieldMapper.Builder - Class in org.elasticsearch.index.mapper.flattened
- FlattenedFieldMapper.KeyedFlattenedFieldData - Class in org.elasticsearch.index.mapper.flattened
-
A field data implementation that gives access to the values associated with a particular JSON key.
- FlattenedFieldMapper.KeyedFlattenedFieldData.Builder - Class in org.elasticsearch.index.mapper.flattened
- FlattenedFieldMapper.KeyedFlattenedFieldType - Class in org.elasticsearch.index.mapper.flattened
-
A field type that represents the values under a particular JSON key, used when searching under a specific key as in 'my_flattened.key: some_value'.
- FlattenedFieldMapper.RootFlattenedFieldType - Class in org.elasticsearch.index.mapper.flattened
-
A field type that represents all 'root' values.
- flattenProcessors() - Method in class org.elasticsearch.ingest.CompoundProcessor
- flavor() - Method in class org.elasticsearch.Build
- FLOAT - Enum constant in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- FLOAT - Enum constant in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- FLOAT - Enum constant in enum class org.elasticsearch.index.mapper.RangeType
- FloatArray - Interface in org.elasticsearch.common.util
-
Abstraction of an array of double values.
- floatField(FieldInfo, float) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- floatField(FieldInfo, float) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- floatField(FieldInfo, float) - Method in class org.elasticsearch.search.internal.FilterFieldNamesProvidingStoredFieldsVisitor
- floatField(FieldInfo, float) - Method in class org.elasticsearch.search.internal.FilterStoredFieldVisitor
- floatParam(String, boolean, Function<FieldMapper, Float>, float) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Defines a parameter that takes a float value
- floatSetting(String, float, float, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- floatSetting(String, float, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- floatValue() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic.LongAccessor
- FloatValuesComparatorSource - Class in org.elasticsearch.index.fielddata.fieldcomparator
-
Comparator source for float values.
- FloatValuesComparatorSource(IndexNumericFieldData, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Constructor for class org.elasticsearch.index.fielddata.fieldcomparator.FloatValuesComparatorSource
- flush - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- flush() - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Should flush be performed after the merge.
- flush() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- flush() - Method in class org.elasticsearch.action.bulk.BulkProcessor
-
Flush pending delete or index requests.
- flush() - Method in class org.elasticsearch.bootstrap.plugins.LoggerTerminal
- flush() - Method in class org.elasticsearch.common.bytes.RecyclingBytesStreamOutput
- flush() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- flush() - Method in class org.elasticsearch.common.io.stream.DataOutputStreamOutput
- flush() - Method in class org.elasticsearch.common.io.stream.OutputStreamStreamOutput
- flush() - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Forces any buffered output to be written.
- flush() - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Flushes the stream.
- flush() - Method in class org.elasticsearch.index.engine.Engine
-
Flushes the state of the engine including the transaction log, clearing memory and persisting documents in the lucene index to disk including a potentially heavy and durable fsync operation.
- flush() - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
-
Flush the
flushBuffer
to the breaker, incrementing the total bytes and resetting the buffer. - flush() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
- flush() - Method in class org.elasticsearch.transport.ReuseBuffersLZ4BlockOutputStream
-
Flushes this compressed
OutputStream
. - flush(boolean) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Should flush be performed after the merge.
- flush(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- flush(boolean, boolean) - Method in class org.elasticsearch.index.engine.Engine
-
Flushes the state of the engine including the transaction log, clearing memory.
- flush(boolean, boolean) - Method in class org.elasticsearch.index.engine.InternalEngine
- flush(boolean, boolean) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- flush(FlushRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly flush one or more indices (releasing memory from the node).
- flush(FlushRequest) - Method in class org.elasticsearch.index.shard.IndexShard
-
Executes the given flush request against the engine.
- flush(FlushRequest, ActionListener<FlushResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly flush one or more indices (releasing memory from the node).
- Flush - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- FLUSH - Static variable in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest.Defaults
- FLUSH - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- FlushAction - Class in org.elasticsearch.action.admin.indices.flush
- flushAndClose() - Method in class org.elasticsearch.index.engine.Engine
-
Flush the engine (committing segments to disk and truncating the translog) and close it.
- flushBuffer() - Method in class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
-
Write the contents of
ChunkedBlobOutputStream.buffer
to storage. - flushedBytes - Variable in class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
-
Number of bytes flushed to blob storage so far.
- FlushFailedEngineException - Exception in org.elasticsearch.index.engine
- FlushFailedEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.FlushFailedEngineException
- FlushFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.FlushFailedEngineException
- flushOnCloseStream(BytesStream) - Static method in class org.elasticsearch.common.io.Streams
-
Wraps the given
BytesStream
in aStreamOutput
that simply flushes when close is called. - flushRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a flush indices request.
- FlushRequest - Class in org.elasticsearch.action.admin.indices.flush
-
A flush request to flush one or more indices.
- FlushRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.flush.FlushRequest
-
Constructs a new flush request against one or more indices.
- FlushRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.flush.FlushRequest
- FlushRequestBuilder - Class in org.elasticsearch.action.admin.indices.flush
- FlushRequestBuilder(ElasticsearchClient, FlushAction) - Constructor for class org.elasticsearch.action.admin.indices.flush.FlushRequestBuilder
- FlushResponse - Class in org.elasticsearch.action.admin.indices.flush
-
A response to flush action.
- flushStats() - Method in class org.elasticsearch.index.shard.IndexShard
- FlushStats - Class in org.elasticsearch.index.flush
- FlushStats() - Constructor for class org.elasticsearch.index.flush.FlushStats
- FlushStats(long, long, long) - Constructor for class org.elasticsearch.index.flush.FlushStats
- FlushStats(StreamInput) - Constructor for class org.elasticsearch.index.flush.FlushStats
- fmix(long) - Static method in enum class org.elasticsearch.common.hash.MurmurHash3
- FNM - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- FOLDER_FOUND_CAN_DELETE - Enum constant in enum class org.elasticsearch.indices.IndicesService.ShardDeletionCheckResult
- FOLLOW_UP_REROUTE_PRIORITY_SETTING - Static variable in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
Adjusts the priority of the followup reroute task.
- FOLLOWER - Enum constant in enum class org.elasticsearch.cluster.coordination.Coordinator.Mode
- FOLLOWER_CHECK_ACTION_NAME - Static variable in class org.elasticsearch.cluster.coordination.FollowersChecker
- FOLLOWER_CHECK_INTERVAL_SETTING - Static variable in class org.elasticsearch.cluster.coordination.FollowersChecker
- FOLLOWER_CHECK_RETRY_COUNT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.FollowersChecker
- FOLLOWER_CHECK_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.FollowersChecker
- FollowerCheckRequest(long, DiscoveryNode) - Constructor for class org.elasticsearch.cluster.coordination.FollowersChecker.FollowerCheckRequest
- FollowerCheckRequest(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.FollowersChecker.FollowerCheckRequest
- FollowersChecker - Class in org.elasticsearch.cluster.coordination
-
The FollowersChecker is responsible for allowing a leader to check that its followers are still connected and healthy.
- FollowersChecker(Settings, TransportService, Consumer<FollowersChecker.FollowerCheckRequest>, BiConsumer<DiscoveryNode, String>, NodeHealthService) - Constructor for class org.elasticsearch.cluster.coordination.FollowersChecker
- FollowersChecker.FollowerCheckRequest - Class in org.elasticsearch.cluster.coordination
- following(int) - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
-
Can be invoked only after a call to preceding(offset+1).
- forAnnotation(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.internal.Scoping
- FORBID_ALIASES_TO_MULTIPLE_INDICES - Enum constant in enum class org.elasticsearch.action.support.IndicesOptions.Option
- FORBID_CLOSED_INDICES - Enum constant in enum class org.elasticsearch.action.support.IndicesOptions.Option
- forbidClosedIndices() - Method in class org.elasticsearch.action.support.IndicesOptions
- FORBIDDEN - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server understood the request, but is refusing to fulfill it.
- force() - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
-
Force flushing, even if one is possibly not needed.
- force(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
-
Force flushing, even if one is possibly not needed.
- force(ReplicatedWriteRequest<?>) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- FORCE_MERGE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- FORCE_MERGE_UUID_KEY - Static variable in class org.elasticsearch.index.engine.Engine
- FORCE_RAM_TERM_DICT - Static variable in class org.elasticsearch.index.store.Store
-
This is an escape hatch for lucenes internal optimization that checks if the IndexInput is an instance of ByteBufferIndexInput and if that's the case doesn't load the term dictionary into ram but loads it off disk iff the fields is not an ID like field.
- FORCE_SOURCE_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- FORCE_STALE_PRIMARY_INSTANCE - Static variable in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- FORCE_UNIGRAM_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- FORCED_ALLOCATION_ID - Static variable in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
-
Special allocation id that shard has during initialization on allocate_stale_primary
- FORCED_EMPTY_PRIMARY - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned after forcing an empty primary
- forcedRefresh - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- forcedRefresh() - Method in class org.elasticsearch.action.DocWriteResponse
-
Did this request force a refresh? Requests that set
WriteRequest.setRefreshPolicy(RefreshPolicy)
toWriteRequest.RefreshPolicy.IMMEDIATE
will always return true for this. - forceExecutionOnPrimary - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- forceMerge(boolean, int, boolean, boolean, boolean, String) - Method in class org.elasticsearch.index.engine.Engine
-
Triggers a forced merge on this engine
- forceMerge(boolean, int, boolean, boolean, boolean, String) - Method in class org.elasticsearch.index.engine.InternalEngine
- forceMerge(boolean, int, boolean, boolean, boolean, String) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- forceMerge(ForceMergeRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly force merge one or more indices into a the number of segments.
- forceMerge(ForceMergeRequest) - Method in class org.elasticsearch.index.shard.IndexShard
- forceMerge(ForceMergeRequest, ActionListener<ForceMergeResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly force merge one or more indices into a the number of segments.
- ForceMergeAction - Class in org.elasticsearch.action.admin.indices.forcemerge
- forceMergeRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a force merge request.
- ForceMergeRequest - Class in org.elasticsearch.action.admin.indices.forcemerge
-
A request to force merging the segments of one or more indices.
- ForceMergeRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Constructs a merge request over one or more indices.
- ForceMergeRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
- ForceMergeRequest.Defaults - Class in org.elasticsearch.action.admin.indices.forcemerge
- ForceMergeRequestBuilder - Class in org.elasticsearch.action.admin.indices.forcemerge
-
A request to force merge one or more indices.
- ForceMergeRequestBuilder(ElasticsearchClient, ForceMergeAction) - Constructor for class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequestBuilder
- ForceMergeResponse - Class in org.elasticsearch.action.admin.indices.forcemerge
-
A response for force merge action.
- forceMergeUUID() - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Force merge UUID to use when force merging or
null
if not using one in a mixed version cluster containing nodes older thanForceMergeRequest.FORCE_MERGE_UUID_VERSION
. - forceMove() - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Returns
true
if the shard cannot remain on its current node and can be moved, returnsfalse
otherwise. - forcePut(E) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
-
Forces adding an element to the queue, without doing size checks.
- forceQueryCacheProvider(BiFunction<IndexSettings, IndicesQueryCache, QueryCache>) - Method in class org.elasticsearch.index.IndexModule
-
Forces a certain query cache to use instead of the default one.
- forceRefreshes() - Method in class org.elasticsearch.index.shard.RefreshListeners
-
Force-refreshes newly added listeners and forces a refresh if there are currently listeners registered.
- forceRegister(RequestHandlerRegistry<Request>) - Method in class org.elasticsearch.transport.Transport.RequestHandlers
- forceSource - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- forceSource - Variable in class org.elasticsearch.search.fetch.subphase.highlight.FieldHighlightContext
- forceSource() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- forceSource(Boolean) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Forces the highlighting to highlight fields based on the source even if fields are stored separately.
- forceSource(SearchHighlightContext.Field) - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext
- forceUnigrams() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the setting for
PhraseSuggestionBuilder.forceUnigrams()
- forceUnigrams(boolean) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
If set to
true
the phrase suggester will fail if the analyzer only produces ngrams. - forConstructorOf(Class<?>) - Static method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns a new injection point for the injectable constructor of
type
. - forConstructorOf(TypeLiteral<?>) - Static method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns a new injection point for the injectable constructor of
type
. - ForDoubles(BigArrays, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Constructor for class org.elasticsearch.search.sort.BucketedSort.ForDoubles
- forEach(BiConsumer<? super K, ? super V>) - Method in class org.elasticsearch.common.util.LazyMap
- forEach(BiConsumer<K, V>) - Method in class org.elasticsearch.common.cache.Cache
-
Performs an action for each cache entry in the cache.
- forEach(T) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- forEach(T) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- forEachBucket(Consumer<InternalAggregations>) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- forEachBucket(Consumer<InternalAggregations>) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Run a Consumer over all buckets in this aggregation.
- forEachBucket(Consumer<InternalAggregations>) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
- forEntries(List<SnapshotsInProgress.Entry>) - Static method in class org.elasticsearch.snapshots.InFlightShardSnapshotStates
-
Compute information about all shard ids that currently have in-flight state for the given repository.
- forFields(Collection<DateTimeFieldType>, boolean, boolean) - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter that outputs only those fields specified.
- forFinalReduction() - Method in interface org.elasticsearch.search.aggregations.InternalAggregation.ReduceContextBuilder
-
Build a InternalAggregation.ReduceContext to perform the final reduction.
- forFinalReduction(BigArrays, ScriptService, IntConsumer, PipelineAggregator.PipelineTree, Supplier<Boolean>) - Static method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
-
Build a InternalAggregation.ReduceContext to perform the final reduction.
- ForFloats(BigArrays, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Constructor for class org.elasticsearch.search.sort.BucketedSort.ForFloats
- forInjectionPoints(Set<InjectionPoint>) - Static method in class org.elasticsearch.common.inject.spi.Dependency
-
Returns the dependencies from the given injection points.
- forInsideTree(AggregationBuilder, ActionRequestValidationException) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder.ValidationContext
-
Build the context for a node inside the aggregation tree.
- forInstance(Scope) - Static method in class org.elasticsearch.common.inject.internal.Scoping
- forInstanceMethodsAndFields(Class<?>) - Static method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns all instance method and field injection points on
type
. - forInstanceMethodsAndFields(TypeLiteral<?>) - Static method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns all instance method and field injection points on
type
. - forkAndTrackFieldReferences(String) - Method in class org.elasticsearch.search.lookup.SearchLookup
-
Creates a copy of the current
SearchLookup
that looks fields up in the same way, but also tracks field references in order to detect cycles and prevent resolving fields that depend on more thanSearchLookup.MAX_FIELD_CHAIN_DEPTH
other fields. - forLeaf(LeafReaderContext) - Method in class org.elasticsearch.search.sort.BucketedSort
-
Get the BucketedSort.Leaf implementation that'll do that actual collecting.
- ForLongs(BigArrays, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Constructor for class org.elasticsearch.search.sort.BucketedSort.ForLongs
- format - Variable in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSource
- format - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- format - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- format - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- format - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- format - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- format - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- format - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- format - Variable in class org.elasticsearch.search.aggregations.bucket.terms.AbstractRareTermsAggregator
- format - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- format - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- format - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- format - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- format - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- format - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- format - Variable in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation
- format - Variable in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregator
- format - Variable in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
- format - Variable in class org.elasticsearch.search.fetch.subphase.FieldAndFormat
-
The format of the field, or
null
if defaults should be used. - format - Variable in class org.elasticsearch.search.sort.SortFieldAndFormat
- format() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Gets the format field to parse the from/to fields
- format() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Gets the format to use for the output of the aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
-
Gets the format to use on the output of this aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
-
Gets the format to use on the output of this aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
-
Gets the format to use on the output of this aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Gets the format to use on the output of this aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
-
Gets the format to use on the output of this aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
-
Gets the format to use on the output of this aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Gets the format to use for the output of the aggregation.
- format() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- format(double) - Method in class org.elasticsearch.search.DocValueFormat.BooleanDocValueFormat
- format(double) - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- format(double) - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- format(double) - Method in interface org.elasticsearch.search.DocValueFormat
-
Format a double value.
- format(double) - Method in class org.elasticsearch.search.DocValueFormat.GeoHashDocValueFormat
- format(double) - Method in class org.elasticsearch.search.DocValueFormat.GeoTileDocValueFormat
- format(double) - Method in class org.elasticsearch.search.DocValueFormat.RawDocValueFormat
- format(double) - Method in class org.elasticsearch.search.DocValueFormat.UnsignedLongShiftedDocValueFormat
-
Double docValues of the unsigned_long field type are already in the formatted representation, so we don't need to do anything here
- format(long) - Method in class org.elasticsearch.search.DocValueFormat.BooleanDocValueFormat
- format(long) - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- format(long) - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- format(long) - Method in interface org.elasticsearch.search.DocValueFormat
-
Format a long value.
- format(long) - Method in class org.elasticsearch.search.DocValueFormat.GeoHashDocValueFormat
- format(long) - Method in class org.elasticsearch.search.DocValueFormat.GeoTileDocValueFormat
- format(long) - Method in class org.elasticsearch.search.DocValueFormat.RawDocValueFormat
- format(long) - Method in class org.elasticsearch.search.DocValueFormat.UnsignedLongShiftedDocValueFormat
-
Formats a raw docValue that is stored in the shifted long format to the unsigned long representation.
- format(String) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
In case of format field, we can parse the from/to fields using this time format
- format(String) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Sets the format to use for the output of the aggregation.
- format(String) - Method in class org.elasticsearch.search.aggregations.bucket.composite.GeoTileGridValuesSourceBuilder
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
-
Sets the format to use on the output of this aggregation.
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
-
Sets the format to use on the output of this aggregation.
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
-
Sets the format to use on the output of this aggregation.
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Sets the format to use on the output of this aggregation.
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
-
Sets the format to use on the output of this aggregation.
- format(String) - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
-
Sets the format to use on the output of this aggregation.
- format(String) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
-
Sets the format to use for the output of the aggregation.
- format(String) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Sets the format to use for the output of the aggregation.
- format(String, Object...) - Static method in class org.elasticsearch.common.inject.internal.Errors
- format(String, Object...) - Static method in class org.elasticsearch.common.logging.LoggerMessageFormat
- format(String, String, Object...) - Static method in class org.elasticsearch.common.logging.LoggerMessageFormat
- format(String, Collection<Message>) - Static method in class org.elasticsearch.common.inject.internal.Errors
-
Returns the formatted message for an exception with the specified messages.
- format(InetAddress) - Static method in class org.elasticsearch.common.network.NetworkAddress
-
Formats a network address for display purposes.
- format(InetAddress, int) - Static method in class org.elasticsearch.common.network.NetworkAddress
-
Formats a network address and port for display purposes.
- format(InetAddress, PortsRange) - Static method in class org.elasticsearch.common.network.NetworkAddress
-
Formats a network address and port range for display purposes.
- format(InetSocketAddress) - Static method in class org.elasticsearch.common.network.NetworkAddress
-
Formats a network address and port for display purposes.
- format(DateTimeFormatter) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- format(TemporalAccessor) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- format(TemporalAccessor) - Method in interface org.elasticsearch.common.time.DateFormatter
-
Print the supplied java time accessor in a string based representation according to this formatter
- format(LogEvent, StringBuilder) - Method in class org.elasticsearch.common.logging.ClusterIdConverter
-
Formats the cluster.uuid into json fields.
- format(LogEvent, StringBuilder) - Method in class org.elasticsearch.common.logging.ESMessageFieldConverter
- format(LogEvent, StringBuilder) - Method in class org.elasticsearch.common.logging.JsonThrowablePatternConverter
- format(LogEvent, StringBuilder) - Method in class org.elasticsearch.common.logging.NodeAndClusterIdConverter
-
Formats the node.id and cluster.uuid into json fields.
- format(LogEvent, StringBuilder) - Method in class org.elasticsearch.common.logging.NodeIdConverter
-
Formats the node.id into json fields.
- format(LogEvent, StringBuilder) - Method in class org.elasticsearch.common.logging.NodeNamePatternConverter
- format(LogEvent, StringBuilder) - Method in class org.elasticsearch.common.logging.ProductOriginConverter
-
Formats the X-elastic-product-origin into plaintext logs/
- format(LogEvent, StringBuilder) - Method in class org.elasticsearch.common.logging.TraceIdConverter
-
Formats the trace.id into json fields.
- format(Passage[], String) - Method in class org.apache.lucene.search.uhighlight.CustomPassageFormatter
- format(BytesRef) - Method in class org.elasticsearch.search.DocValueFormat.BinaryDocValueFormat
- format(BytesRef) - Method in interface org.elasticsearch.search.DocValueFormat
-
Format a binary value.
- format(BytesRef) - Method in class org.elasticsearch.search.DocValueFormat.IpDocValueFormat
- format(BytesRef) - Method in class org.elasticsearch.search.DocValueFormat.RawDocValueFormat
- format(DocValueFormat) - Method in class org.elasticsearch.search.sort.SortValue
-
Format this value using the provided format.
- FORMAT - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
-
State format for
IndexMetadata
to write to and load from disk - FORMAT - Static variable in class org.elasticsearch.cluster.metadata.Manifest
- FORMAT - Static variable in class org.elasticsearch.cluster.metadata.Metadata
-
State format for
Metadata
to write to and load from disk - FORMAT - Static variable in class org.elasticsearch.env.NodeMetadata
- FORMAT - Static variable in class org.elasticsearch.gateway.MetadataStateFormat
- FORMAT - Static variable in class org.elasticsearch.index.shard.ShardStateMetadata
- FORMAT - Static variable in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsParser
- FORMAT - Static variable in interface org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.Parser
- FORMAT - Static variable in class org.elasticsearch.search.sort.FieldSortBuilder
- FORMAT_6_0 - Static variable in class org.elasticsearch.index.translog.Translog.Index
- FORMAT_NO_PARENT - Static variable in class org.elasticsearch.index.translog.Translog.Delete
- FORMAT_NO_PARENT - Static variable in class org.elasticsearch.index.translog.Translog.Index
- FORMAT_NO_VERSION_TYPE - Static variable in class org.elasticsearch.index.translog.Translog.Delete
- FORMAT_NO_VERSION_TYPE - Static variable in class org.elasticsearch.index.translog.Translog.Index
- FORMAT_PARAMS - Static variable in class org.elasticsearch.action.search.SearchRequest
- FORMAT_PARAMS - Static variable in class org.elasticsearch.common.settings.Settings
- format1Decimals(double, String) - Static method in class org.elasticsearch.common.Strings
-
Format the double value with a single decimal points, trimming trailing '.0'.
- formatInjectionPoint(Formatter, Dependency<?>, InjectionPoint) - Static method in class org.elasticsearch.common.inject.internal.Errors
- formatJoda(DateTime) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- formatJoda(DateTime) - Method in interface org.elasticsearch.common.time.DateFormatter
-
Return the given Joda
DateTime
formatted with this format. - formatMillis(long) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- formatMillis(long) - Method in interface org.elasticsearch.common.time.DateFormatter
-
Return the given millis-since-epoch formatted with this format.
- FormatNames - Enum Class in org.elasticsearch.common.time
- formats - Variable in class org.elasticsearch.search.sort.SortAndFormats
- formatSortValue(Object) - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- formatSortValue(Object) - Method in interface org.elasticsearch.search.DocValueFormat
-
Formats a value of a sort field in a search response.
- formatSortValue(Object) - Method in class org.elasticsearch.search.DocValueFormat.UnsignedLongShiftedDocValueFormat
- formatSource(Formatter, Object) - Static method in class org.elasticsearch.common.inject.internal.Errors
- formatStackTrace(StackTraceElement[]) - Static method in class org.elasticsearch.ExceptionsHelper
- formatSuggestion(String) - Static method in class org.elasticsearch.common.joda.JodaDeprecationPatterns
-
Formats deprecation message for suggestion field in a warning header.
- FormattedDocValues - Interface in org.elasticsearch.index.fielddata
- formatter - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- formatter() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- formatter() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- formatter() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
- formatter() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- formatter() - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
- formatter() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
- formatter() - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- formatter() - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
- formatValue(Object, DateFormatter) - Method in enum class org.elasticsearch.index.mapper.RangeType
- formatWarning(String) - Static method in class org.elasticsearch.common.logging.HeaderWarning
-
Format a warning string in the proper warning format by prepending a warn code, warn agent, wrapping the warning string in quotes, and appending the RFC 7231 date.
- forMember(Member) - Static method in class org.elasticsearch.common.inject.internal.StackTraceElements
- forModule(Module) - Static method in class org.elasticsearch.common.inject.internal.ProviderMethodsModule
-
Returns a module which creates bindings for provider methods from the given module.
- forName(String) - Static method in enum class org.elasticsearch.common.time.FormatNames
- forObject(Object) - Static method in class org.elasticsearch.common.inject.internal.ProviderMethodsModule
-
Returns a module which creates bindings for provider methods from the given object.
- forPartialReduction() - Method in interface org.elasticsearch.search.aggregations.InternalAggregation.ReduceContextBuilder
-
Build a InternalAggregation.ReduceContext to perform a partial reduction.
- forPartialReduction(BigArrays, ScriptService, Supplier<PipelineAggregator.PipelineTree>, Supplier<Boolean>) - Static method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
-
Build a InternalAggregation.ReduceContext to perform a partial reduction.
- forPath(ContentPath) - Static method in class org.elasticsearch.index.mapper.MapperBuilderContext
- forPattern(String) - Static method in class org.elasticsearch.common.joda.Joda
-
Deprecated.Parses a joda based pattern, including some named ones (similar to the built in Joda ISO ones).
- forPattern(String) - Static method in interface org.elasticsearch.common.time.DateFormatter
- forRepo(String) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- forSlice(TaskId, SearchRequest, int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Build a new request for a slice of the parent request.
- forSlice(TaskId, SearchRequest, int) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- forSlice(TaskId, SearchRequest, int) - Method in class org.elasticsearch.index.reindex.ReindexRequest
- forSlice(TaskId, SearchRequest, int) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- forStaticMethodsAndFields(Class<?>) - Static method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns all static method and field injection points on
type
. - forStaticMethodsAndFields(TypeLiteral) - Static method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns all static method and field injection points on
type
. - forString(String) - Static method in class org.elasticsearch.common.network.InetAddresses
-
Returns the
InetAddress
having the given string representation. - forTreeRoot(Collection<AggregationBuilder>, Collection<PipelineAggregationBuilder>, ActionRequestValidationException) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder.ValidationContext
-
Build the context for the root of the aggregation tree.
- forType(Class<?>) - Static method in class org.elasticsearch.common.inject.internal.StackTraceElements
- forwardIngestRequest(ActionType<?>, ActionRequest, ActionListener<?>) - Method in class org.elasticsearch.action.ingest.IngestActionForwarder
- FOUND - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The requested resource resides temporarily under a different URI.
- FOUND_PARSE_FIELD - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- fPut(int, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
A put operation that can be used in the fluent pattern.
- fPut(KType, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
A put operation that can be used in the fluent pattern.
- FRAGMENT_OFFSET_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- FRAGMENT_SIZE_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- FragmentBuilderHelper - Class in org.elasticsearch.search.fetch.subphase.highlight
-
Simple helper class for
FastVectorHighlighter
FragmentsBuilder
implementations. - fragmentCharSize() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- fragmenter - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- fragmenter() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- fragmenter() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- fragmenter(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Sets what fragmenter to use to break up text that is eligible for highlighting.
- FRAGMENTER_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- fragmentOffset() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- fragmentOffset(int) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
- fragments() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
-
The highlighted fragments.
- fragmentSize - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- fragmentSize() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- fragmentSize(Integer) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set the fragment size in characters, defaults to
HighlightBuilder.DEFAULT_FRAGMENT_CHAR_SIZE
- FREE_CONTEXT_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- FREE_CONTEXT_SCROLL_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- freeAllScrollContexts() - Method in class org.elasticsearch.search.SearchService
- freeReaderContext(ShardSearchContextId) - Method in class org.elasticsearch.search.SearchService
- freezeContext() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
if this method is called the query context will throw exception if methods are accessed that could yield different results across executions like
SearchExecutionContext.getClient()
- fRemove(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
Remove that can be used in the fluent pattern.
- fRemove(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
Remove that can be used in the fluent pattern.
- FREQ - Static variable in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- FREQS - Enum constant in enum class org.elasticsearch.index.search.stats.FieldUsageStats.UsageContext
- FreqTermsEnum - Class in org.elasticsearch.common.lucene.index
-
A frequency terms enum that maintains a cache of docFreq, totalTermFreq, or both for repeated term lookup.
- FreqTermsEnum(IndexReader, String, boolean, boolean, Query, BigArrays) - Constructor for class org.elasticsearch.common.lucene.index.FreqTermsEnum
- Frequencies() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.Frequencies
- frequency() - Method in class org.elasticsearch.watcher.WatcherHandle
- frequency(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
- Frequency() - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion.Frequency
- FREQUENCY - Enum constant in enum class org.elasticsearch.search.suggest.SortBy
-
Sort should first be based on document frequency, then score and then the term itself.
- FREQUENCY - Static variable in class org.elasticsearch.search.suggest.term.TermSuggestion
- from - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- from - Variable in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- from - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- from() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Gets the lower range value for this query.
- from() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Gets the from index to start the search from.
- from() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the from index to start the search from.
- from() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- from() - Method in class org.elasticsearch.search.internal.SearchContext
- from() - Method in class org.elasticsearch.search.internal.SubSearchContext
- from() - Method in class org.elasticsearch.search.query.QuerySearchResult
- from(double) - Static method in class org.elasticsearch.search.sort.SortValue
-
Get a SortValue for a double.
- from(int) - Static method in class org.elasticsearch.action.support.ActiveShardCount
-
Get an ActiveShardCount instance for the given value.
- from(int) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
From index to start the search from.
- from(int) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- from(int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
From index to start the search from.
- from(int) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- from(int) - Method in class org.elasticsearch.search.internal.SearchContext
- from(int) - Method in class org.elasticsearch.search.internal.SubSearchContext
- from(int) - Method in class org.elasticsearch.search.query.QuerySearchResult
- from(long) - Static method in class org.elasticsearch.search.sort.SortValue
-
Get a SortValue for a long.
- from(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- from(Object, boolean) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- from(TemporalAccessor) - Static method in class org.elasticsearch.common.time.DateFormatters
-
Convert a temporal accessor to a zoned date time object - as performant as possible.
- from(TemporalAccessor, Locale) - Static method in class org.elasticsearch.common.time.DateFormatters
- from(TemporalAccessor, Locale, ZoneId) - Static method in class org.elasticsearch.common.time.DateFormatters
- from(List<InternalAggregation>) - Static method in class org.elasticsearch.search.aggregations.InternalAggregations
- from(BytesRef) - Static method in class org.elasticsearch.search.sort.SortValue
-
Get a SortValue for bytes.
- from(SnapshotInfo, GetSnapshotsRequest.SortBy) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.After
- FROM - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- FROM_AS_STRING - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- FROM_FIELD - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- FROM_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- FROM_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- FROM_SORT_VALUE_VERSION - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- fromAllocationStatus(UnassignedInfo.AllocationStatus) - Static method in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
Gets an
AllocationDecision
from aUnassignedInfo.AllocationStatus
. - fromAsStr - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- fromAsString - Variable in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- fromByte(byte) - Static method in enum class org.elasticsearch.common.Priority
- fromByteArray(ByteArray, int) - Static method in interface org.elasticsearch.common.bytes.BytesReference
-
Returns BytesReference either wrapping the provided
ByteArray
or in case the has a backing raw byte array one that wraps that backing array directly. - fromByteBuffer(ByteBuffer) - Static method in interface org.elasticsearch.common.bytes.BytesReference
-
Returns BytesReference composed of the provided ByteBuffer.
- fromByteBuffers(ByteBuffer[]) - Static method in interface org.elasticsearch.common.bytes.BytesReference
-
Returns BytesReference composed of the provided ByteBuffers.
- fromBytes(byte[], DiscoveryNode, NamedWriteableRegistry) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
- fromCode(int) - Static method in enum class org.elasticsearch.rest.RestStatus
-
Turn a status code into a
RestStatus
, returning null if we don't know that status. - fromDecision(Decision.Type) - Static method in enum class org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
- fromDecision(Decision, DiscoveryNode, List<NodeAllocationResult>) - Static method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Creates a
AllocateUnassignedDecision
from the givenDecision
and the assigned node, if any. - fromDecisionType(Decision.Type) - Static method in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
Gets an
AllocationDecision
from aDecision.Type
- fromDiff(boolean) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- fromDisplayName(String, boolean) - Static method in enum class org.elasticsearch.Build.Flavor
- fromDisplayName(String, boolean) - Static method in enum class org.elasticsearch.Build.Type
- fromEdits(int) - Static method in class org.elasticsearch.common.unit.Fuzziness
-
Creates a
Fuzziness
instance from an edit distance. - fromExtension(String) - Static method in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- fromFile(String) - Static method in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- fromGeohash(long) - Static method in class org.elasticsearch.common.geo.GeoPoint
- fromGeohash(String) - Static method in class org.elasticsearch.common.geo.GeoPoint
- fromId(byte) - Static method in enum class org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
- fromId(byte) - Static method in enum class org.elasticsearch.action.DocWriteRequest.OpType
- fromId(byte) - Static method in enum class org.elasticsearch.action.search.SearchType
-
Constructs search type based on the internal id.
- fromId(byte) - Static method in enum class org.elasticsearch.action.ThreadingModel
- fromId(byte) - Static method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.State
- fromId(byte) - Static method in enum class org.elasticsearch.index.shard.IndexShardState
- fromId(byte) - Static method in enum class org.elasticsearch.index.translog.Translog.Operation.Type
- fromId(byte) - Static method in enum class org.elasticsearch.indices.recovery.RecoveryState.Stage
- fromId(int) - Static method in enum class org.elasticsearch.common.unit.ByteSizeUnit
- fromId(int) - Static method in class org.elasticsearch.Version
- fromIndexMetadata(IndexMetadata) - Static method in class org.elasticsearch.cluster.routing.IndexRouting
-
Build the routing from
IndexMetadata
. - fromLegacy(PercentilesMethod, double, int) - Static method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig
-
Deprecated.
- fromList(List<String>) - Static method in class org.elasticsearch.search.fetch.StoredFieldsContext
- FromMany(BigArrays) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromMany
- FromManySmall(BigArrays, int) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromManySmall
- fromMap(Map<String, Object>, IndicesOptions) - Static method in class org.elasticsearch.action.support.IndicesOptions
- fromMappers(Mapping, Collection<FieldMapper>, Collection<ObjectMapper>, Collection<FieldAliasMapper>) - Static method in class org.elasticsearch.index.mapper.MappingLookup
-
Creates a new
MappingLookup
instance given the provided mappers and mapping. - fromMapping(Mapping) - Static method in class org.elasticsearch.index.mapper.MappingLookup
-
Creates a new
MappingLookup
instance by parsing the provided mapping and extracting its field definitions. - fromMeters(double) - Method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Convert a value given in meters to a value of this unit
- fromName(String) - Static method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
- fromNode() - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- fromOptions(boolean, boolean, boolean, boolean) - Static method in class org.elasticsearch.action.support.IndicesOptions
- fromOptions(boolean, boolean, boolean, boolean, boolean) - Static method in class org.elasticsearch.action.support.IndicesOptions
- fromOptions(boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Static method in class org.elasticsearch.action.support.IndicesOptions
- fromOptions(boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Static method in class org.elasticsearch.action.support.IndicesOptions
- fromOptions(boolean, boolean, boolean, boolean, IndicesOptions) - Static method in class org.elasticsearch.action.support.IndicesOptions
- fromParameters(Object, Object, Object, Object, IndicesOptions) - Static method in class org.elasticsearch.action.support.IndicesOptions
- fromQueryParam(String) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.After
- fromRequest(RestRequest) - Static method in class org.elasticsearch.rest.action.admin.cluster.RestClusterHealthAction
- fromRequest(RestRequest, ClearIndicesCacheRequest) - Static method in class org.elasticsearch.rest.action.admin.indices.RestClearIndicesCacheAction
- fromRequest(RestRequest, IndicesOptions) - Static method in class org.elasticsearch.action.support.IndicesOptions
- fromRestRequest(String, RestRequest) - Static method in class org.elasticsearch.search.fetch.StoredFieldsContext
- fromSetting(String) - Static method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
- fromSettings(Settings) - Static method in class org.elasticsearch.http.CorsHandler
- fromSettings(Settings) - Static method in class org.elasticsearch.http.HttpHandlingSettings
- fromSettingsKey(String) - Static method in enum class org.elasticsearch.index.IndexModule.Type
- FromSingle(BigArrays) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromSingle
- fromSortValue() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- fromSortValue(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- fromStream(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateRequest
- fromStream(StreamInput) - Static method in enum class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
- fromStream(StreamInput) - Static method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig
- fromString(String) - Static method in enum class org.elasticsearch.action.DocWriteRequest.OpType
- fromString(String) - Static method in enum class org.elasticsearch.action.search.SearchType
-
The a string representation search type to execute, defaults to
SearchType.DEFAULT
. - fromString(String) - Static method in enum class org.elasticsearch.cluster.health.ClusterHealthStatus
- fromString(String) - Static method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.State
- fromString(String) - Static method in enum class org.elasticsearch.common.geo.GeoDistance
-
Get a
GeoDistance
according to a given name. - fromString(String) - Static method in enum class org.elasticsearch.common.geo.Orientation
- fromString(String) - Static method in enum class org.elasticsearch.common.lucene.search.function.CombineFunction
- fromString(String) - Static method in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- fromString(String) - Static method in enum class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- fromString(String) - Static method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Convert a String to a
DistanceUnit
- fromString(String) - Static method in enum class org.elasticsearch.index.mapper.DynamicTemplate.MatchType
- fromString(String) - Static method in enum class org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- fromString(String) - Static method in enum class org.elasticsearch.index.query.GeoExecType
- fromString(String) - Static method in enum class org.elasticsearch.index.query.GeoValidationMethod
- fromString(String) - Static method in enum class org.elasticsearch.index.query.Operator
- fromString(String) - Static method in class org.elasticsearch.index.shard.ShardId
-
Parse the string representation of this shardId back to an object.
- fromString(String) - Static method in enum class org.elasticsearch.index.VersionType
- fromString(String) - Static method in enum class org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
- fromString(String) - Static method in enum class org.elasticsearch.search.aggregations.bucket.composite.MissingOrder
- fromString(String) - Static method in enum class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
- fromString(String) - Static method in enum class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
- fromString(String) - Static method in enum class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
- fromString(String) - Static method in enum class org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- fromString(String) - Static method in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
- fromString(String) - Static method in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
- fromString(String) - Static method in enum class org.elasticsearch.search.MultiValueMode
-
A case insensitive version of
MultiValueMode.valueOf(String)
- fromString(String) - Static method in enum class org.elasticsearch.search.rescore.QueryRescoreMode
- fromString(String) - Static method in enum class org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
- fromString(String) - Static method in enum class org.elasticsearch.search.sort.SortMode
- fromString(String) - Static method in enum class org.elasticsearch.search.sort.SortOrder
- fromString(String) - Static method in enum class org.elasticsearch.search.suggest.completion.context.ContextMapping.Type
- fromString(String) - Static method in class org.elasticsearch.Version
-
Returns the version given its string representation, current version if the argument is null or empty
- fromString(String, DeprecationLogger) - Static method in enum class org.elasticsearch.common.geo.SpatialStrategy
- fromString(String, DeprecationLogger) - Static method in enum class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregatorFactory.ExecutionMode
- fromString(String, DeprecationLogger) - Static method in enum class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregatorFactory.ExecutionMode
- fromString(String, VersionType) - Static method in enum class org.elasticsearch.index.VersionType
- fromSystemIndexPlugin(SystemIndexPlugin, Settings) - Static method in class org.elasticsearch.indices.SystemIndices.Feature
-
Creates a
SystemIndices.Feature
from aSystemIndexPlugin
. - fromType(String) - Static method in enum class org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
- fromValue(byte) - Static method in enum class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Generate snapshot state from code
- fromValue(byte) - Static method in enum class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
- fromValue(byte) - Static method in enum class org.elasticsearch.cluster.health.ClusterHealthStatus
- fromValue(byte) - Static method in enum class org.elasticsearch.cluster.metadata.DataStreamAction.Type
- fromValue(byte) - Static method in enum class org.elasticsearch.cluster.RestoreInProgress.State
-
Returns state corresponding to state code
- fromValue(byte) - Static method in enum class org.elasticsearch.cluster.routing.ShardRoutingState
- fromValue(byte) - Static method in enum class org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- fromValue(byte) - Static method in enum class org.elasticsearch.cluster.SnapshotsInProgress.State
- fromValue(byte) - Static method in enum class org.elasticsearch.index.VersionType
- fromValue(byte) - Static method in enum class org.elasticsearch.snapshots.SnapshotState
-
Generate snapshot state from code
- fromXContent(boolean, XContentParser) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- fromXContent(String, XContentParser) - Static method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
- fromXContent(String, XContentParser) - Static method in class org.elasticsearch.search.fetch.StoredFieldsContext
- fromXContent(GeometryValidator, boolean, boolean, XContentParser) - Static method in class org.elasticsearch.common.geo.GeoJson
- fromXContent(GeometryValidator, boolean, boolean, XContentParser) - Method in enum class org.elasticsearch.common.geo.GeometryParserFormat
-
Parser JSON representation of a geometry
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptContextResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptLanguageResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Parses an alias and returns its parsed representation
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.flush.FlushResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetadata
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.open.OpenIndexResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.refresh.RefreshResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.rollover.MaxPrimaryShardSizeCondition
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- fromXContent(XContentParser) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- fromXContent(XContentParser) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.shrink.ResizeResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.bulk.BulkResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.delete.DeleteResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesFailure
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.get.GetResponse
-
This method can be used to parse a
GetResponse
object when it has been printed out as a xcontent using theGetResponse.toXContent(XContentBuilder, Params)
method. - fromXContent(XContentParser) - Static method in class org.elasticsearch.action.get.MultiGetResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.index.IndexResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.ingest.GetPipelineResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.main.MainResponse
- fromXContent(XContentParser) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.search.ClearScrollResponse
-
Parse the clear scroll response body into a new
ClearScrollResponse
object - fromXContent(XContentParser) - Static method in class org.elasticsearch.action.search.ClosePointInTimeRequest
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.search.OpenPointInTimeResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.search.SearchResponse
- fromXContent(XContentParser) - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
Parse a search scroll request from a request body provided through the REST layer.
- fromXContent(XContentParser) - Static method in exception org.elasticsearch.action.search.ShardSearchFailure
- fromXContent(XContentParser) - Static method in exception org.elasticsearch.action.support.DefaultShardOperationFailedException
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.support.IndicesOptions
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- fromXContent(XContentParser) - Static method in exception org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.TaskOperationFailure
- fromXContent(XContentParser) - Method in class org.elasticsearch.action.update.UpdateRequest
- fromXContent(XContentParser) - Static method in class org.elasticsearch.action.update.UpdateResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfigExclusion
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.health.ClusterShardHealth
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.AliasMetadata.Builder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.DataStream
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.DataStreamAction
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.DataStreamAlias
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.Manifest
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.Metadata
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Reads
AllocationCommands
from aXContentParser
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- fromXContent(XContentParser) - Static method in class org.elasticsearch.cluster.routing.AllocationId
- fromXContent(XContentParser) - Static method in class org.elasticsearch.common.document.DocumentField
- fromXContent(XContentParser) - Static method in class org.elasticsearch.common.settings.Settings
-
Parsers the generated xcontent from
Settings.toXContent(XContentBuilder, Params)
into a new Settings object. - fromXContent(XContentParser) - Static method in exception org.elasticsearch.ElasticsearchException
-
Generate a
ElasticsearchException
from aXContentParser
. - fromXContent(XContentParser) - Method in class org.elasticsearch.gateway.MetadataStateFormat
-
Reads a new instance of the state from the given XContentParser Subclasses need to implement this class for theirs specific state.
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.analysis.NameOrDefinition
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.get.GetResult
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.Index
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.BoostingQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.DistanceFeatureQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.ExistsQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- fromXContent(XContentParser) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionParser
-
Parses bodies of the kind
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- fromXContent(XContentParser) - Method in interface org.elasticsearch.index.query.functionscore.ScoreFunctionParser
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.IdsQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.InnerHitBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.IntervalQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.IntervalsSourceProvider.Combine
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.IntervalsSourceProvider.Disjunction
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.IntervalsSourceProvider
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.IntervalsSourceProvider.Fuzzy
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.IntervalsSourceProvider.IntervalFilter
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.IntervalsSourceProvider.Match
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.IntervalsSourceProvider.Prefix
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.IntervalsSourceProvider.Wildcard
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.MatchAllQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.MatchNoneQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.MatchQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.NestedQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.PrefixQueryBuilder
- fromXContent(XContentParser) - Method in interface org.elasticsearch.index.query.QueryParser
-
Creates a new
QueryBuilder
from the query held by theXContentParser
. - fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.RangeQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.RegexpQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.ScriptQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.SpanOrQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.SpanTermQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.TermQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.TermsQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.TypeQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.WildcardQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.query.WrapperQueryBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
-
Since
BulkByScrollTask.StatusOrException
can contain either anException
or aBulkByScrollTask.Status
we need to peek at a field first before deciding what needs to be parsed since the same object could contains either. - fromXContent(XContentParser) - Static method in class org.elasticsearch.index.reindex.ReindexRequest
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.seqno.RetentionLease
-
Parses a retention lease from
XContent
. - fromXContent(XContentParser) - Static method in class org.elasticsearch.index.seqno.RetentionLeases
-
Parses a retention leases collection from
XContent
. - fromXContent(XContentParser) - Static method in class org.elasticsearch.index.shard.IndexLongFieldRange
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Parses JSON that represents file info
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Parses shard snapshot metadata
- fromXContent(XContentParser) - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
- fromXContent(XContentParser) - Static method in class org.elasticsearch.ingest.IngestMetadata
- fromXContent(XContentParser) - Static method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- fromXContent(XContentParser) - Static method in class org.elasticsearch.repositories.ShardGeneration
- fromXContent(XContentParser) - Static method in class org.elasticsearch.script.ScriptContextInfo
- fromXContent(XContentParser) - Static method in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo
- fromXContent(XContentParser) - Static method in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo.ParameterInfo
- fromXContent(XContentParser) - Static method in class org.elasticsearch.script.ScriptLanguagesInfo
- fromXContent(XContentParser) - Static method in class org.elasticsearch.script.ScriptMetadata
-
This will parse XContent into
ScriptMetadata
. - fromXContent(XContentParser) - Static method in class org.elasticsearch.search.aggregations.Aggregations
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceParserHelper
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.builder.PointInTimeBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.builder.SearchSourceBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.collapse.CollapseBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.fetch.subphase.FieldAndFormat
-
Parse a
FieldAndFormat
from someXContent
. - fromXContent(XContentParser) - Static method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.profile.ProfileResult
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.profile.query.CollectorResult
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.profile.SearchProfileResults
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.SearchHit
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.SearchHit.NestedIdentity
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.SearchHits
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.SearchSortValues
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.slice.SliceBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.sort.NestedSortBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.sort.SortBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- fromXContent(XContentParser) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext
- fromXContent(XContentParser) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Prototype for the query context
- fromXContent(XContentParser) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.phrase.Laplace
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry.Option
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.phrase.SmoothingModel
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.Suggest
-
this parsing method assumes that the leading "suggest" field name has already been parsed by the caller
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.SuggestBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- fromXContent(XContentParser) - Static method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
- fromXContent(XContentParser) - Static method in class org.elasticsearch.snapshots.RestoreInfo
- fromXContent(XContentParser) - Static method in class org.elasticsearch.snapshots.SnapshotFeatureInfo
- fromXContent(XContentParser) - Static method in exception org.elasticsearch.snapshots.SnapshotShardFailure
-
Deserializes snapshot failure information from JSON
- fromXContent(XContentParser) - Static method in class org.elasticsearch.tasks.TaskInfo
- fromXContent(XContentParser) - Static method in class org.elasticsearch.upgrades.FeatureMigrationResults
- fromXContent(XContentParser) - Static method in class org.elasticsearch.upgrades.SingleFeatureMigrationResult
- fromXContent(XContentParser) - Static method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskParams
- fromXContent(XContentParser) - Static method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskState
- fromXContent(XContentParser, boolean) - Static method in class org.elasticsearch.action.explain.ExplainResponse
- fromXContent(XContentParser, boolean) - Static method in class org.elasticsearch.script.StoredScriptSource
-
This will parse XContent into a
StoredScriptSource
. - fromXContent(XContentParser, boolean) - Static method in class org.elasticsearch.search.builder.SearchSourceBuilder
- fromXContent(XContentParser, int) - Static method in class org.elasticsearch.action.bulk.BulkItemResponse
-
Reads a
BulkItemResponse
from aXContentParser
. - fromXContent(XContentParser, Integer) - Static method in class org.elasticsearch.index.query.BoolQueryBuilder
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.adjacency.ParsedAdjacencyMatrix
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilter
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoHashGrid
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoTileGrid
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.global.ParsedGlobal
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedHistogram
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.missing.ParsedMissing
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.nested.ParsedNested
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.nested.ParsedReverseNested
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.range.ParsedDateRange
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.range.ParsedGeoDistance
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.sampler.ParsedSampler
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongRareTerms
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantLongTerms
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantStringTerms
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringRareTerms
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedAvg
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedCardinality
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedGeoBounds
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedGeoCentroid
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedHDRPercentileRanks
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedHDRPercentiles
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedMax
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedMedianAbsoluteDeviation
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedMin
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedScriptedMetric
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedSum
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentileRanks
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentiles
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedTopHits
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedValueCount
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.metrics.ParsedWeightedAvg
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.ParsedBucketMetricValue
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.ParsedDerivative
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.ParsedExtendedStatsBucket
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.ParsedPercentilesBucket
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.ParsedSimpleValue
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.pipeline.ParsedStatsBucket
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.sort.FieldSortBuilder
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.sort.ScoreSortBuilder
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.sort.ScriptSortBuilder
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
- fromXContent(XContentParser, String) - Static method in class org.elasticsearch.search.suggest.term.TermSuggestion
- fromXContent(XContentParser, IndicesOptions) - Static method in class org.elasticsearch.action.support.IndicesOptions
- fromXContentEmbedded(XContentParser) - Static method in class org.elasticsearch.index.get.GetResult
- fromXContentEmbedded(XContentParser, String, String, String) - Static method in class org.elasticsearch.index.get.GetResult
- fromXContentInternal(String, XContentParser) - Static method in class org.elasticsearch.snapshots.SnapshotInfo
-
This method creates a SnapshotInfo from internal x-content.
- fromXContext(XContentParser) - Static method in class org.elasticsearch.action.search.MultiSearchResponse
- FROZEN_GROUP - Static variable in class org.elasticsearch.indices.ShardLimitValidator
- FROZEN_INDICES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.action.search.TransportSearchAction
- FS - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- FS - Enum constant in enum class org.elasticsearch.index.IndexModule.Type
- FsBlobContainer - Class in org.elasticsearch.common.blobstore.fs
-
A file system based implementation of
BlobContainer
. - FsBlobContainer(FsBlobStore, BlobPath, Path) - Constructor for class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- FsBlobStore - Class in org.elasticsearch.common.blobstore.fs
- FsBlobStore(int, Path, boolean) - Constructor for class org.elasticsearch.common.blobstore.fs.FsBlobStore
- FsDirectoryFactory - Class in org.elasticsearch.index.store
- FsDirectoryFactory() - Constructor for class org.elasticsearch.index.store.FsDirectoryFactory
- FsHealthService - Class in org.elasticsearch.monitor.fs
-
Runs periodically and attempts to create a temp file to see if the filesystem is writable.
- FsHealthService(Settings, ClusterSettings, ThreadPool, NodeEnvironment) - Constructor for class org.elasticsearch.monitor.fs.FsHealthService
- FsInfo - Class in org.elasticsearch.monitor.fs
- FsInfo(long, FsInfo.IoStats, FsInfo.Path[]) - Constructor for class org.elasticsearch.monitor.fs.FsInfo
- FsInfo(StreamInput) - Constructor for class org.elasticsearch.monitor.fs.FsInfo
-
Read from a stream.
- FsInfo.DeviceStats - Class in org.elasticsearch.monitor.fs
- FsInfo.IoStats - Class in org.elasticsearch.monitor.fs
- FsInfo.Path - Class in org.elasticsearch.monitor.fs
- FsProbe - Class in org.elasticsearch.monitor.fs
- FsProbe(NodeEnvironment) - Constructor for class org.elasticsearch.monitor.fs.FsProbe
- FsRepository - Class in org.elasticsearch.repositories.fs
-
Shared file system implementation of the BlobStoreRepository
- FsRepository(RepositoryMetadata, Environment, NamedXContentRegistry, ClusterService, BigArrays, RecoverySettings) - Constructor for class org.elasticsearch.repositories.fs.FsRepository
-
Constructs a shared file system repository.
- fsService() - Method in class org.elasticsearch.monitor.MonitorService
- FsService - Class in org.elasticsearch.monitor.fs
- FsService(Settings, NodeEnvironment) - Constructor for class org.elasticsearch.monitor.fs.FsService
- FULL_CONCURRENCY_VERSION - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- fullKeys(Setting.AffixSetting<?>, List<String>) - Static method in class org.elasticsearch.script.ScriptService.ContextSettings
-
the full keys for the contexts in the context affix setting
- fullName() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetadata
- fullPath() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- fullShardId() - Method in exception org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- function - Variable in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.FilterScoreFunction
- FUNCTION_NAME_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.GaussDecayFunctionBuilder
- FUNCTIONS_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- functionScoreQuery(FunctionScoreQueryBuilder.FilterFunctionBuilder[]) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that allows to define a custom scoring function
- functionScoreQuery(ScoreFunctionBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that allows to define a custom scoring function.
- functionScoreQuery(QueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A function_score query with no functions.
- functionScoreQuery(QueryBuilder, FunctionScoreQueryBuilder.FilterFunctionBuilder[]) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that allows to define a custom scoring function
- functionScoreQuery(QueryBuilder, ScoreFunctionBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that allows to define a custom scoring function.
- FunctionScoreQuery - Class in org.elasticsearch.common.lucene.search.function
-
A query that allows for a pluggable boost function / filter.
- FunctionScoreQuery(Query, Float, float) - Constructor for class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
Creates a FunctionScoreQuery without function.
- FunctionScoreQuery(Query, FunctionScoreQuery.ScoreMode, ScoreFunction[], CombineFunction, Float, float) - Constructor for class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
Creates a FunctionScoreQuery with multiple score functions
- FunctionScoreQuery(Query, ScoreFunction) - Constructor for class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
Creates a FunctionScoreQuery with a single
ScoreFunction
- FunctionScoreQuery(Query, ScoreFunction, CombineFunction, Float, float) - Constructor for class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
-
Creates a FunctionScoreQuery with a single function
- FunctionScoreQuery.FilterScoreFunction - Class in org.elasticsearch.common.lucene.search.function
- FunctionScoreQuery.ScoreMode - Enum Class in org.elasticsearch.common.lucene.search.function
- FunctionScoreQueryBuilder - Class in org.elasticsearch.index.query.functionscore
-
A query that uses a filters with a script associated with them to compute the score.
- FunctionScoreQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Read from a stream.
- FunctionScoreQueryBuilder(FunctionScoreQueryBuilder.FilterFunctionBuilder[]) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Creates a function_score query that executes the provided filters and functions on all documents
- FunctionScoreQueryBuilder(ScoreFunctionBuilder<?>) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Creates a function_score query that will execute the function provided on all documents
- FunctionScoreQueryBuilder(QueryBuilder) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Creates a function_score query without functions
- FunctionScoreQueryBuilder(QueryBuilder, FunctionScoreQueryBuilder.FilterFunctionBuilder[]) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Creates a function_score query that executes the provided filters and functions on documents that match a query.
- FunctionScoreQueryBuilder(QueryBuilder, ScoreFunctionBuilder<?>) - Constructor for class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Creates a function_score query that will execute the function provided in the context of the provided query
- FunctionScoreQueryBuilder.FilterFunctionBuilder - Class in org.elasticsearch.index.query.functionscore
-
Function to be associated with an optional filter, meaning it will be executed only for the documents that match the given filter.
- FutureTransportResponseHandler<T extends TransportResponse> - Class in org.elasticsearch.transport
-
A response handler to be used when all interaction will be done through the
TransportFuture
. - FutureTransportResponseHandler() - Constructor for class org.elasticsearch.transport.FutureTransportResponseHandler
- FutureUtils - Class in org.elasticsearch.common.util.concurrent
- FutureUtils() - Constructor for class org.elasticsearch.common.util.concurrent.FutureUtils
- fuzziness - Variable in class org.elasticsearch.index.search.MatchQueryParser
- fuzziness() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- fuzziness() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Gets the fuzziness used when evaluated to a fuzzy query type.
- fuzziness() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Gets the fuzziness used when evaluated to a fuzzy query type.
- fuzziness() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- fuzziness() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- fuzziness(Object) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Sets the fuzziness used when evaluated to a fuzzy query type.
- fuzziness(Object) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets the fuzziness used when evaluated to a fuzzy query type.
- fuzziness(Object) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Sets the fuzziness used when evaluated to a fuzzy query type.
- fuzziness(Fuzziness) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- fuzziness(Fuzziness) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Set the edit distance for fuzzy queries.
- Fuzziness - Class in org.elasticsearch.common.unit
-
A unit class that encapsulates all in-exact search parsing and conversion from similarities to edit distances etc.
- Fuzziness(StreamInput) - Constructor for class org.elasticsearch.common.unit.Fuzziness
-
Read from a stream.
- Fuzzy(String, int, boolean, Fuzziness, String, String) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.Fuzzy
- Fuzzy(StreamInput) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.Fuzzy
- FUZZY - Enum constant in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- FUZZY_REWRITE_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- FUZZY_TRANSPOSITIONS_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- fuzzyIntervals(String, int, int, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Create a fuzzy
IntervalsSource
for the given term. - fuzzyIntervals(String, int, int, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- fuzzyMaxExpansions() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- fuzzyMaxExpansions() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- fuzzyMaxExpansions() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
- fuzzyMaxExpansions(int) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- fuzzyMaxExpansions(int) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- fuzzyMaxExpansions(int) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
- fuzzyOptions - Variable in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- FuzzyOptions - Class in org.elasticsearch.search.suggest.completion
-
Fuzzy options for completion suggester
- FuzzyOptions.Builder - Class in org.elasticsearch.search.suggest.completion
-
Options for fuzzy queries
- fuzzyPrefixLength - Variable in class org.elasticsearch.index.search.MatchQueryParser
- fuzzyPrefixLength() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- fuzzyPrefixLength() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- fuzzyPrefixLength() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
- fuzzyPrefixLength(int) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Set the minimum prefix length for fuzzy queries.
- fuzzyPrefixLength(int) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- fuzzyPrefixLength(int) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
- fuzzyQuery(Object, Fuzziness, int, int, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- fuzzyQuery(Object, Fuzziness, int, int, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldType
- fuzzyQuery(Object, Fuzziness, int, int, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- fuzzyQuery(Object, Fuzziness, int, int, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- fuzzyQuery(Object, Fuzziness, int, int, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.StringFieldType
- fuzzyQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents using fuzzy query.
- fuzzyQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents using fuzzy query.
- fuzzyQuery(String, Fuzziness, int, int, int, boolean, boolean) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
-
Completion prefix fuzzy query
- FuzzyQueryBuilder - Class in org.elasticsearch.index.query
-
A Query that does fuzzy matching for a specific value.
- FuzzyQueryBuilder(String, boolean) - Constructor for class org.elasticsearch.index.query.FuzzyQueryBuilder
-
Constructs a new fuzzy query.
- FuzzyQueryBuilder(String, double) - Constructor for class org.elasticsearch.index.query.FuzzyQueryBuilder
-
Constructs a new fuzzy query.
- FuzzyQueryBuilder(String, float) - Constructor for class org.elasticsearch.index.query.FuzzyQueryBuilder
-
Constructs a new fuzzy query.
- FuzzyQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.FuzzyQueryBuilder
-
Constructs a new fuzzy query.
- FuzzyQueryBuilder(String, long) - Constructor for class org.elasticsearch.index.query.FuzzyQueryBuilder
-
Constructs a new fuzzy query.
- FuzzyQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.FuzzyQueryBuilder
-
Constructs a new fuzzy query.
- FuzzyQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.FuzzyQueryBuilder
-
Constructs a new fuzzy query.
- FuzzyQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.FuzzyQueryBuilder
-
Read from a stream.
- fuzzyRewrite() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Get the fuzzy_rewrite parameter
- fuzzyRewrite() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Get the fuzzy_rewrite parameter
- fuzzyRewrite() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- fuzzyRewrite() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- fuzzyRewrite(String) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Sets the fuzzy_rewrite parameter controlling how the fuzzy query will get rewritten
- fuzzyRewrite(String) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets the fuzzy_rewrite parameter controlling how the fuzzy query will get rewritten
- fuzzyRewrite(String) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- fuzzyRewrite(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- fuzzyRewriteMethod - Variable in class org.elasticsearch.index.search.MatchQueryParser
- fuzzyTranspositions() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Gets the fuzzy query transposition setting.
- fuzzyTranspositions() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Gets the fuzzy query transposition setting.
- fuzzyTranspositions() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- fuzzyTranspositions() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- fuzzyTranspositions() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- fuzzyTranspositions() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
- fuzzyTranspositions(boolean) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Sets whether transpositions are supported in fuzzy queries.
- fuzzyTranspositions(boolean) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets whether transpositions are supported in fuzzy queries.
- fuzzyTranspositions(boolean) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Sets whether transpositions are supported in fuzzy queries.
- fuzzyTranspositions(boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Sets whether transpositions are supported in fuzzy queries.
- fuzzyTranspositions(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Sets whether transpositions are supported in fuzzy queries.
- fuzzyTranspositions(boolean) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
G
- gamma(double) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
- GAP_POLICY - Static variable in interface org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.Parser
- gapPolicy - Variable in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregator
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
-
Gets the gap policy to use for this aggregation.
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
-
Gets the gap policy to use for this aggregation.
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
-
Gets the gap policy to use for this aggregation.
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Gets the GapPolicy to use on the output of this aggregation.
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
-
Gets the gap policy to use for this aggregation.
- gapPolicy() - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
-
Gets the GapPolicy to use on the output of this aggregation.
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
-
Sets the gap policy to use for this aggregation.
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
-
Sets the gap policy to use for this aggregation.
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
-
Sets the gap policy to use for this aggregation.
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Sets the GapPolicy to use on the output of this aggregation.
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
-
Sets the gap policy to use for this aggregation.
- gapPolicy(BucketHelpers.GapPolicy) - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
-
Sets the GapPolicy to use on the output of this aggregation.
- GarbageCollector(String, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
- GarbageCollector(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
- GarbageCollectors(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
- GarbageCollectors(JvmStats.GarbageCollector[]) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
- Gateway - Class in org.elasticsearch.gateway
- Gateway(Settings, ClusterService, TransportNodesListGatewayMetaState) - Constructor for class org.elasticsearch.gateway.Gateway
- GATEWAY - Enum constant in enum class org.elasticsearch.cluster.metadata.Metadata.XContentContext
- GATEWAY_TIMEOUT - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server, while acting as a gateway or proxy, did not receive a timely response from the upstream server specified by the URI (e.g.
- Gateway.GatewayStateRecoveredListener - Interface in org.elasticsearch.gateway
- GatewayAllocator - Class in org.elasticsearch.gateway
- GatewayAllocator() - Constructor for class org.elasticsearch.gateway.GatewayAllocator
- GatewayAllocator(RerouteService, TransportNodesListGatewayStartedShards, TransportNodesListShardStoreMetadata) - Constructor for class org.elasticsearch.gateway.GatewayAllocator
- GatewayMetaState - Class in org.elasticsearch.gateway
-
Loads (and maybe upgrades) cluster metadata at startup, and persistently stores cluster metadata for future restarts.
- GatewayMetaState() - Constructor for class org.elasticsearch.gateway.GatewayMetaState
- GatewayModule - Class in org.elasticsearch.gateway
- GatewayModule() - Constructor for class org.elasticsearch.gateway.GatewayModule
- GatewayService - Class in org.elasticsearch.gateway
- GatewayService(Settings, AllocationService, ClusterService, ThreadPool, TransportNodesListGatewayMetaState, Discovery) - Constructor for class org.elasticsearch.gateway.GatewayService
- gauge - Enum constant in enum class org.elasticsearch.index.mapper.TimeSeriesParams.MetricType
- GAUSS_DECAY_FUNCTION - Static variable in class org.elasticsearch.index.query.functionscore.GaussDecayFunctionBuilder
- gaussDecayFunction(String, Object, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- gaussDecayFunction(String, Object, Object, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- gaussDecayFunction(String, Object, Object, Object, double) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- GaussDecayFunctionBuilder - Class in org.elasticsearch.index.query.functionscore
- GaussDecayFunctionBuilder(String, Object, Object, Object) - Constructor for class org.elasticsearch.index.query.functionscore.GaussDecayFunctionBuilder
- GaussDecayFunctionBuilder(String, Object, Object, Object, double) - Constructor for class org.elasticsearch.index.query.functionscore.GaussDecayFunctionBuilder
- GaussDecayFunctionBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.GaussDecayFunctionBuilder
-
Read from a stream.
- GB - Enum constant in enum class org.elasticsearch.common.unit.ByteSizeUnit
- GC_OVERHEAD_DEBUG_SETTING - Static variable in class org.elasticsearch.monitor.jvm.JvmGcMonitorService
- GC_OVERHEAD_INFO_SETTING - Static variable in class org.elasticsearch.monitor.jvm.JvmGcMonitorService
- GC_OVERHEAD_WARN_SETTING - Static variable in class org.elasticsearch.monitor.jvm.JvmGcMonitorService
- GC_SETTING - Static variable in class org.elasticsearch.monitor.jvm.JvmGcMonitorService
- GcNames - Class in org.elasticsearch.monitor.jvm
- GcNames() - Constructor for class org.elasticsearch.monitor.jvm.GcNames
- generalCompilationRate - Variable in class org.elasticsearch.script.ScriptService.ContextSettings
- GeneralScriptException - Exception in org.elasticsearch.script
-
Deprecated.Use ScriptException for exceptions from the scripting engine, otherwise use a more appropriate exception (e.g. if thrown from various abstractions)
- GeneralScriptException(String) - Constructor for exception org.elasticsearch.script.GeneralScriptException
-
Deprecated.
- GeneralScriptException(String, Throwable) - Constructor for exception org.elasticsearch.script.GeneralScriptException
-
Deprecated.
- GeneralScriptException(StreamInput) - Constructor for exception org.elasticsearch.script.GeneralScriptException
-
Deprecated.
- GENERATE_SYNONYMS_PHRASE_QUERY - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- generateClusterUuidIfNeeded() - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- generateFailureXContent(XContentBuilder, ToXContent.Params, Exception, boolean) - Static method in exception org.elasticsearch.ElasticsearchException
-
Render any exception as a xcontent, encapsulated within a field or object named "error".
- generateListTasksRequest(RestRequest) - Static method in class org.elasticsearch.rest.action.admin.cluster.RestListTasksAction
- generateNodeId(Settings) - Static method in class org.elasticsearch.env.NodeEnvironment
- generateSeqNo() - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
Issue the next sequence number.
- generateSeqNoForOperationOnPrimary(Engine.Operation) - Method in class org.elasticsearch.index.engine.InternalEngine
- generateThrowableXContent(XContentBuilder, ToXContent.Params, Throwable) - Static method in exception org.elasticsearch.ElasticsearchException
-
Static toXContent helper method that renders
ElasticsearchException
orThrowable
instances as XContent, delegating the rendering toElasticsearchException.toXContent(XContentBuilder, Params)
orElasticsearchException.innerToXContent(XContentBuilder, Params, Throwable, String, String, Map, Map, Throwable)
. - generation - Variable in class org.elasticsearch.index.translog.BaseTranslogReader
- generation - Variable in class org.elasticsearch.index.translog.Translog.Location
- generation() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
-
Returns the safe repository generation.
- generation() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- generation() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- GENERATION_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- generic() - Method in class org.elasticsearch.threadpool.ThreadPool
-
Get the generic
ExecutorService
. - GENERIC - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- GenericArrayTypeImpl(Type) - Constructor for class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
- genericExecutor - Variable in class org.elasticsearch.ingest.Processor.Parameters
- geo(String) - Static method in class org.elasticsearch.search.suggest.completion.context.ContextBuilder
-
Create a new
GeoContextMapping
- GEO - Enum constant in enum class org.elasticsearch.search.suggest.completion.context.ContextMapping.Type
- GEO_POLYGON_DEPRECATION_MSG - Static variable in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.
- geoBoundingBox() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- geoBoundingBox(GeoBoundingBox) - Method in class org.elasticsearch.search.aggregations.bucket.composite.GeoTileGridValuesSourceBuilder
- GeoBoundingBox - Class in org.elasticsearch.common.geo
-
A class representing a Geo-Bounding-Box for use by Geo queries and aggregations that deal with extents/rectangles representing rectangular areas of interest.
- GeoBoundingBox(GeoPoint, GeoPoint) - Constructor for class org.elasticsearch.common.geo.GeoBoundingBox
- GeoBoundingBox(StreamInput) - Constructor for class org.elasticsearch.common.geo.GeoBoundingBox
- geoBoundingBoxQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter to filter based on a bounding box defined by top left and bottom right locations / points
- GeoBoundingBoxQueryBuilder - Class in org.elasticsearch.index.query
-
Creates a Lucene query that will filter for all documents that lie within the specified bounding box.
- GeoBoundingBoxQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Create new bounding box query.
- GeoBoundingBoxQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Read from a stream.
- geoBounds(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
GeoBounds
aggregation with the given name. - GeoBounds - Interface in org.elasticsearch.search.aggregations.metrics
-
An aggregation that computes a bounding box in which all documents of the current bucket are.
- GeoBoundsAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- GeoBoundsAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- GeoBoundsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
-
Read from a stream.
- GeoBoundsAggregationBuilder(GeoBoundsAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- GeoBoundsAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.metrics
- geoCentroid(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
GeoCentroid
aggregation with the given name. - GeoCentroid - Interface in org.elasticsearch.search.aggregations.metrics
-
Interface for
GeoCentroidAggregator
- GeoCentroidAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- GeoCentroidAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
- GeoCentroidAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
-
Read from a stream.
- GeoCentroidAggregationBuilder(GeoCentroidAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
- GeoContextMapping - Class in org.elasticsearch.search.suggest.completion.context
-
A
ContextMapping
that uses a geo location/area as a criteria. - GeoContextMapping.Builder - Class in org.elasticsearch.search.suggest.completion.context
- geoDisjointQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
- geoDisjointQuery(String, String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Deprecated.Types are in the process of being removed, use
QueryBuilders.geoDisjointQuery(String, String)
instead. - geoDisjointQuery(String, Geometry) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter to filter indexed shapes that are not intersection with the query shape
- geoDistance() - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Returns geo distance calculation type to use.
- geoDistance() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns the geo distance type used to compute the distance.
- geoDistance(String, GeoPoint) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
GeoDistance
aggregation with the given name. - geoDistance(GeoDistance) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Which type of geo distance calculation method to use.
- geoDistance(GeoDistance) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
The geo distance type used to compute the distance.
- GeoDistance - Enum Class in org.elasticsearch.common.geo
-
Geo distance calculation.
- GeoDistanceAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.range
- GeoDistanceAggregationBuilder(String, GeoPoint) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- GeoDistanceAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Read from a stream.
- GeoDistanceAggregationBuilder(GeoDistanceAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- GeoDistanceAggregationBuilder.Range - Class in org.elasticsearch.search.aggregations.bucket.range
- GeoDistanceAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.bucket.range
- geoDistanceQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter to filter based on a specific distance from a specific geo location / point.
- GeoDistanceQueryBuilder - Class in org.elasticsearch.index.query
-
Filter results of a query to include only those within a specific distance to some geo point.
- GeoDistanceQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Construct new GeoDistanceQueryBuilder.
- GeoDistanceQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Read from a stream.
- GeoDistanceRangeAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.range
- GeoDistanceRangeAggregatorFactory(String, ValuesSourceConfig, GeoPoint, GeoDistanceAggregationBuilder.Range[], DistanceUnit, GeoDistance, boolean, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>, GeoDistanceAggregatorSupplier) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceRangeAggregatorFactory
- geoDistanceSort(String, double, double) - Static method in class org.elasticsearch.search.sort.SortBuilders
-
A geo distance based sort.
- geoDistanceSort(String, String...) - Static method in class org.elasticsearch.search.sort.SortBuilders
-
Constructs a new distance based sort on a geo point like field.
- geoDistanceSort(String, GeoPoint...) - Static method in class org.elasticsearch.search.sort.SortBuilders
-
Constructs a new distance based sort on a geo point like field.
- GeoDistanceSortBuilder - Class in org.elasticsearch.search.sort
-
A geo distance based sorting on a geo point like field.
- GeoDistanceSortBuilder(String, double, double) - Constructor for class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Constructs a new distance based sort on a geo point like field.
- GeoDistanceSortBuilder(String, String...) - Constructor for class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Constructs a new distance based sort on a geo point like field.
- GeoDistanceSortBuilder(String, GeoPoint...) - Constructor for class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Constructs a new distance based sort on a geo point like field.
- GeoDistanceSortBuilder(StreamInput) - Constructor for class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Read from a stream.
- GeoExecType - Enum Class in org.elasticsearch.index.query
-
Specifies how a geo query should be run.
- GeoFormatterFactory<T> - Class in org.elasticsearch.common.geo
-
Output formatters for geo fields support extensions such as vector tiles.
- GeoFormatterFactory(List<GeoFormatterFactory.FormatterFactory<T>>) - Constructor for class org.elasticsearch.common.geo.GeoFormatterFactory
-
Creates an extensible geo formatter.
- GeoFormatterFactory.FormatterFactory<T> - Interface in org.elasticsearch.common.geo
-
Defines an extension point for geometry formatter
- GeoGrid - Interface in org.elasticsearch.search.aggregations.bucket.geogrid
-
A geo-grid aggregation.
- GeoGrid.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.geogrid
-
A bucket that is associated with a geo-grid cell.
- GeoGridAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- GeoGridAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- GeoGridAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
-
Read from a stream.
- GeoGridAggregationBuilder(GeoGridAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- GeoGridAggregationBuilder.PrecisionParser - Interface in org.elasticsearch.search.aggregations.bucket.geogrid
- GeoGridAggregator<T extends InternalGeoGrid<?>> - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Aggregates data expressed as longs (for efficiency's sake) but formats results as aggregation-specific strings.
- GeoGridAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.metrics
- geohash() - Method in class org.elasticsearch.common.geo.GeoPoint
- geohash(String) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Sets the center point for this query.
- GEOHASH - Static variable in class org.elasticsearch.common.geo.GeoUtils
- GEOHASH - Static variable in interface org.elasticsearch.search.DocValueFormat
- geoHashCellHeight(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the height (in meters) of geohash cells at a specific level
- GeoHashCellIdSource - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Class to help convert
MultiGeoPointValues
to GeoHash bucketing. - GeoHashCellIdSource(ValuesSource.GeoPoint, int, GeoBoundingBox) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashCellIdSource
- geoHashCellSize(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the size (in meters) of geohash cells at a specific level
- geoHashCellWidth(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the width (in meters) of geohash cells at a specific level
- geohashDistance(String) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- geohashDistanceWithDefault(String, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- geohashGrid(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
InternalGeoHashGrid
aggregation with the given name. - GeoHashGridAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- GeoHashGridAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- GeoHashGridAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- GeoHashGridAggregator - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Aggregates data expressed as GeoHash longs (for efficiency's sake) but formats results as Geohash strings.
- GeoHashGridAggregator(String, AggregatorFactories, ValuesSource.Numeric, int, int, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregator
- GeoHashGridAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- geoHashLevelsForPrecision(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the number of levels needed for a specific precision.
- geoHashLevelsForPrecision(String) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the number of levels needed for a specific precision.
- geoIntersectionQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
- geoIntersectionQuery(String, String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Deprecated.Types are in the process of being removed, use
QueryBuilders.geoIntersectionQuery(String, String)
instead. - geoIntersectionQuery(String, Geometry) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter to filter indexed shapes intersecting with shapes
- GeoJson - Class in org.elasticsearch.common.geo
-
Utility class for converting libs/geo shapes to and from GeoJson
- GEOJSON - Enum constant in enum class org.elasticsearch.common.geo.GeometryParserFormat
- GEOJSON - Static variable in class org.elasticsearch.common.geo.GeometryFormatterFactory
- GeoLineDecomposer - Class in org.elasticsearch.common.geo
-
Splits lines by datelines.
- Geometry() - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Geometry
- geometryFormat(XContentParser) - Static method in enum class org.elasticsearch.common.geo.GeometryParserFormat
-
Returns a geometry parser format object that can parse and then serialize the object back to the same format.
- GeometryFormatterFactory - Class in org.elasticsearch.common.geo
-
Output formatters supported by geometry fields.
- GeometryFormatterFactory() - Constructor for class org.elasticsearch.common.geo.GeometryFormatterFactory
- GeometryIO - Class in org.elasticsearch.common.geo
-
Utility class for binary serializtion/deserialization of libs/geo classes
- GeometryIO() - Constructor for class org.elasticsearch.common.geo.GeometryIO
- geometryParser - Variable in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
- GeometryParser - Class in org.elasticsearch.common.geo
-
An utility class with to read geometries from a XContentParser or generic object.
- GeometryParser(boolean, boolean, boolean) - Constructor for class org.elasticsearch.common.geo.GeometryParser
- GeometryParserFormat - Enum Class in org.elasticsearch.common.geo
-
Supported formats to read/write JSON geometries.
- GeoPoint - Class in org.elasticsearch.common.geo
- GeoPoint() - Constructor for class org.elasticsearch.common.geo.GeoPoint
- GeoPoint() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint
- GeoPoint(double, double) - Constructor for class org.elasticsearch.common.geo.GeoPoint
- GeoPoint(String) - Constructor for class org.elasticsearch.common.geo.GeoPoint
-
Create a new Geopoint from a string.
- GeoPoint(GeoPoint) - Constructor for class org.elasticsearch.common.geo.GeoPoint
- GEOPOINT - Enum constant in enum class org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- GEOPOINT - Enum constant in enum class org.elasticsearch.search.aggregations.support.ValueType
- GeoPointFieldMapper - Class in org.elasticsearch.index.mapper
-
Field Mapper for geo_point types.
- GeoPointFieldMapper(String, MappedFieldType, AbstractGeometryFieldMapper.Parser<GeoPoint>, GeoPointFieldMapper.Builder) - Constructor for class org.elasticsearch.index.mapper.GeoPointFieldMapper
- GeoPointFieldMapper(String, MappedFieldType, FieldMapper.MultiFields, FieldMapper.CopyTo, AbstractGeometryFieldMapper.Parser<GeoPoint>, GeoPointFieldMapper.Builder) - Constructor for class org.elasticsearch.index.mapper.GeoPointFieldMapper
- GeoPointFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- GeoPointFieldMapper.GeoPointFieldType - Class in org.elasticsearch.index.mapper
- GeoPointFieldScript - Class in org.elasticsearch.script
-
Script producing geo points.
- GeoPointFieldScript(String, Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.GeoPointFieldScript
- GeoPointFieldScript.Emit - Class in org.elasticsearch.script
- GeoPointFieldScript.Factory - Interface in org.elasticsearch.script
- GeoPointFieldScript.LeafFactory - Interface in org.elasticsearch.script
- GeoPointFieldType(String) - Constructor for class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointFieldType
- GeoPoints(MultiGeoPointValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- GeoPointScriptDocValues - Class in org.elasticsearch.index.fielddata
- GeoPointScriptFieldData - Class in org.elasticsearch.index.fielddata
- GeoPointScriptFieldData.Builder - Class in org.elasticsearch.index.fielddata
- GeoPointScriptFieldDistanceFeatureQuery - Class in org.elasticsearch.search.runtime
- GeoPointScriptFieldDistanceFeatureQuery(Script, Function<LeafReaderContext, AbstractLongFieldScript>, String, double, double, double) - Constructor for class org.elasticsearch.search.runtime.GeoPointScriptFieldDistanceFeatureQuery
- GeoPointScriptFieldExistsQuery - Class in org.elasticsearch.search.runtime
- GeoPointScriptFieldExistsQuery(Script, GeoPointFieldScript.LeafFactory, String) - Constructor for class org.elasticsearch.search.runtime.GeoPointScriptFieldExistsQuery
- GeoPointScriptFieldGeoShapeQuery - Class in org.elasticsearch.search.runtime
- GeoPointScriptFieldGeoShapeQuery(Script, GeoPointFieldScript.LeafFactory, String, ShapeRelation, LatLonGeometry...) - Constructor for class org.elasticsearch.search.runtime.GeoPointScriptFieldGeoShapeQuery
- GeoPointScriptFieldType - Class in org.elasticsearch.index.mapper
- geoPointValue() - Method in class org.elasticsearch.index.fielddata.GeoPointValues
-
Get the
GeoPoint
associated with the current document. - geoPointValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint.Fielddata
- geoPointValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint
- GeoPointValues - Class in org.elasticsearch.index.fielddata
-
Per-document geo-point values.
- GeoPointValues() - Constructor for class org.elasticsearch.index.fielddata.GeoPointValues
- GeoPolygonDecomposer - Class in org.elasticsearch.common.geo
-
Splits polygons by datelines.
- geoPolygonQuery(String, List<GeoPoint>) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Deprecated.
- GeoPolygonQueryBuilder - Class in org.elasticsearch.index.query
-
Deprecated.
- GeoPolygonQueryBuilder(String, List<GeoPoint>) - Constructor for class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.
- GeoPolygonQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.Read from a stream.
- GeoQueryContext - Class in org.elasticsearch.search.suggest.completion.context
-
Defines the query context for
GeoContextMapping
- GeoQueryContext.Builder - Class in org.elasticsearch.search.suggest.completion.context
- GeoShapeFieldMapper - Class in org.elasticsearch.index.mapper
-
FieldMapper for indexing
LatLonShape
s. - GeoShapeFieldMapper(String, MappedFieldType, FieldMapper.MultiFields, FieldMapper.CopyTo, GeoShapeIndexer, AbstractGeometryFieldMapper.Parser<Geometry>, GeoShapeFieldMapper.Builder) - Constructor for class org.elasticsearch.index.mapper.GeoShapeFieldMapper
- GeoShapeFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- GeoShapeFieldMapper.GeoShapeFieldType - Class in org.elasticsearch.index.mapper
- GeoShapeFieldType(String, boolean, Orientation, AbstractGeometryFieldMapper.Parser<Geometry>, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.GeoShapeFieldMapper.GeoShapeFieldType
- GeoShapeIndexer - Class in org.elasticsearch.index.mapper
-
Utility class that converts geometries into Lucene-compatible form for indexing in a geo_shape field.
- GeoShapeIndexer(boolean, String) - Constructor for class org.elasticsearch.index.mapper.GeoShapeIndexer
- GeoShapeParser - Class in org.elasticsearch.index.mapper
- GeoShapeParser(GeometryParser) - Constructor for class org.elasticsearch.index.mapper.GeoShapeParser
- geoShapeQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
- geoShapeQuery(String, String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Deprecated.Types are in the process of being removed, use
QueryBuilders.geoShapeQuery(String, String)
instead. - geoShapeQuery(String, Geometry) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter based on the relationship of a shape and indexed shapes
- geoShapeQuery(Geometry, String, ShapeRelation, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointFieldType
- geoShapeQuery(Geometry, String, ShapeRelation, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.GeoPointScriptFieldType
- geoShapeQuery(Geometry, String, ShapeRelation, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper.GeoShapeFieldType
- geoShapeQuery(Geometry, String, ShapeRelation, SearchExecutionContext) - Method in interface org.elasticsearch.index.mapper.GeoShapeQueryable
- geoShapeQuery(Geometry, String, SpatialStrategy, ShapeRelation, SearchExecutionContext) - Method in interface org.elasticsearch.index.mapper.GeoShapeQueryable
-
Deprecated.
- GeoShapeQueryable - Interface in org.elasticsearch.index.mapper
-
Implemented by
MappedFieldType
that support GeoShape queries. - GeoShapeQueryBuilder - Class in org.elasticsearch.index.query
-
Derived
AbstractGeometryQueryBuilder
that builds a lat, lon GeoShape Query. - GeoShapeQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Creates a new GeoShapeQueryBuilder whose Query will be against the given field name and will use the Shape found with the given ID
- GeoShapeQueryBuilder(String, String, String) - Constructor for class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Deprecated.use
GeoShapeQueryBuilder(String, String)
instead - GeoShapeQueryBuilder(String, Supplier<Geometry>, String, String) - Constructor for class org.elasticsearch.index.query.GeoShapeQueryBuilder
- GeoShapeQueryBuilder(String, Geometry) - Constructor for class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Creates a new GeoShapeQueryBuilder whose Query will be against the given field name using the given Shape
- GeoShapeQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.GeoShapeQueryBuilder
- GeoShapeUtils - Class in org.elasticsearch.common.geo
-
Utility class that transforms Elasticsearch geometry objects to the Lucene representation
- GEOTILE - Static variable in interface org.elasticsearch.search.DocValueFormat
- GeoTileCellIdSource - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Class to help convert
MultiGeoPointValues
to GeoTile bucketing. - GeoTileCellIdSource(ValuesSource.GeoPoint, int, GeoBoundingBox) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileCellIdSource
- geotileGrid(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
InternalGeoTileGrid
aggregation with the given name. - GeoTileGridAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- GeoTileGridAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregationBuilder
- GeoTileGridAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregationBuilder
- GeoTileGridAggregator - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Aggregates data expressed as geotile longs (for efficiency's sake) but formats results as geotile strings.
- GeoTileGridAggregator(String, AggregatorFactories, ValuesSource.Numeric, int, int, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregator
- GeoTileGridAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- GeoTileGridValuesSourceBuilder - Class in org.elasticsearch.search.aggregations.bucket.composite
- GeoTileGridValuesSourceBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.GeoTileGridValuesSourceBuilder
- GeoTileGridValuesSourceBuilder.GeoTileCompositeSuppier - Interface in org.elasticsearch.search.aggregations.bucket.composite
- GeoTileUtils - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Implements geotile key hashing, same as used by many map tile implementations.
- GeoUtils - Class in org.elasticsearch.common.geo
- GeoUtils.EffectivePoint - Enum Class in org.elasticsearch.common.geo
-
Represents the point of the geohash cell that should be used as the value of geohash
- GeoValidationMethod - Enum Class in org.elasticsearch.index.query
-
This enum is used to determine how to deal with invalid geo coordinates in geo related queries: On STRICT validation invalid coordinates cause an exception to be thrown.
- geoWithinQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
- geoWithinQuery(String, String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Deprecated.Types are in the process of being removed, use
QueryBuilders.geoWithinQuery(String, String)
instead. - geoWithinQuery(String, Geometry) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter to filter indexed shapes that are contained by a shape
- get - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- get() - Method in class org.elasticsearch.action.ActionRequestBuilder
-
Short version of execute().actionGet().
- get() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- get() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
-
Get the field capabilities map.
- get() - Method in class org.elasticsearch.cluster.AbstractNamedDiffable
- get() - Method in interface org.elasticsearch.common.CheckedSupplier
- get() - Method in class org.elasticsearch.common.inject.assistedinject.FactoryProvider
- get() - Method in class org.elasticsearch.common.inject.internal.ProviderMethod
- get() - Method in class org.elasticsearch.common.inject.internal.SourceProvider
-
Returns the calling line of code.
- get() - Method in class org.elasticsearch.common.inject.multibindings.MapBinder.RealMapBinder.MapBinderProviderWithDependencies
- get() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
- get() - Method in interface org.elasticsearch.common.inject.Provider
-
Provides an instance of
T
. - get() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup.ProviderImpl
- get() - Static method in class org.elasticsearch.common.Randomness
-
Provides a source of randomness that is reproducible when running under the Elasticsearch test suite, and otherwise produces a non-reproducible source of randomness.
- get() - Method in class org.elasticsearch.common.util.CachedSupplier
- get() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
- get() - Method in interface org.elasticsearch.index.analysis.AnalyzerProvider
- get() - Method in class org.elasticsearch.index.analysis.CustomAnalyzerProvider
- get() - Method in class org.elasticsearch.index.analysis.CustomNormalizerProvider
- get() - Method in class org.elasticsearch.index.analysis.KeywordAnalyzerProvider
- get() - Method in class org.elasticsearch.index.analysis.LowercaseNormalizerProvider
- get() - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProvider
- get() - Method in class org.elasticsearch.index.analysis.SimpleAnalyzerProvider
- get() - Method in class org.elasticsearch.index.analysis.StandardAnalyzerProvider
- get() - Method in class org.elasticsearch.index.analysis.StopAnalyzerProvider
- get() - Method in class org.elasticsearch.index.analysis.WhitespaceAnalyzerProvider
- get() - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- get() - Method in class org.elasticsearch.index.similarity.SimilarityProvider
-
Return the wrapped
Similarity
. - get() - Method in class org.elasticsearch.index.translog.TragicExceptionHolder
- get(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- get(boolean) - Static method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- get(boolean) - Static method in class org.elasticsearch.index.mapper.RoutingFieldMapper
- get(double, Explanation) - Method in class org.elasticsearch.script.ScoreScript.ExplanationHolder
- get(int) - Method in class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazyBits
- get(int) - Method in class org.apache.lucene.util.CombinedBitSet
- get(int) - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
- get(int) - Method in class org.elasticsearch.common.bytes.BytesArray
- get(int) - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Returns the byte at the specified index.
- get(int) - Method in class org.elasticsearch.common.bytes.CompositeBytesReference
- get(int) - Method in class org.elasticsearch.common.bytes.PagedBytesReference
- get(int) - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- get(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- get(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- get(int) - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
Gets the current value at position
i
. - get(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- get(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.BytesRefs
- get(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Dates
- get(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- get(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- get(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
- get(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Strings
- get(int) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType.IpScriptDocValues
- get(int) - Method in class org.elasticsearch.index.seqno.CountedBitSet
- get(long) - Method in class org.elasticsearch.common.util.BitArray
-
Is the
index
th bit set? - get(long) - Method in interface org.elasticsearch.common.util.ByteArray
-
Get an element given its index.
- get(long) - Method in interface org.elasticsearch.common.util.concurrent.ConcurrentMapLong
- get(long) - Method in interface org.elasticsearch.common.util.DoubleArray
-
Get an element given its index.
- get(long) - Method in interface org.elasticsearch.common.util.FloatArray
-
Get an element given its index.
- get(long) - Method in interface org.elasticsearch.common.util.IntArray
-
Get an element given its index.
- get(long) - Method in interface org.elasticsearch.common.util.LongArray
-
Get an element given its index.
- get(long) - Method in class org.elasticsearch.common.util.LongHash
-
Return the key at
0 <= index <= capacity()
. - get(long) - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
-
Get the value that is associated with
key
or null ifkey
was not present in the hash table. - get(long) - Method in interface org.elasticsearch.common.util.ObjectArray
-
Get an element given its index.
- get(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromMany
- get(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromManySmall
- get(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromSingle
- get(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds
-
Returns the value currently associated with the bucket ordinal.
- get(long) - Method in class org.elasticsearch.tasks.CancellableTasksTracker
-
Get the item that corresponds with the given task, or
null
if there is no such item. - get(long, int, BytesRef) - Method in interface org.elasticsearch.common.util.ByteArray
-
Get a reference to a slice.
- get(long, TimeUnit) - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
- get(long, BytesRef) - Method in class org.elasticsearch.common.util.BytesRefHash
-
Return the key at
0 <= index <= capacity()
. - get(Input, BooleanSupplier, ActionListener<Value>) - Method in class org.elasticsearch.common.util.CancellableSingleObjectCache
-
Start a retrieval for the value associated with the given
input
, and pass it to the givenlistener
. - get(Class<T>) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type.
- get(Class<T>) - Static method in class org.elasticsearch.common.inject.TypeLiteral
-
Gets type literal for the given
Class
instance. - get(Class<T>, Annotation) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type and an annotation.
- get(Class<T>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type and an annotation type.
- get(Iterable<T>, int) - Static method in class org.elasticsearch.common.util.iterable.Iterables
- get(Object) - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap
- get(Object) - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
- get(Object) - Method in class org.elasticsearch.common.util.LazyMap
- get(Object) - Method in class org.elasticsearch.script.DynamicMap
- get(Object) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- get(Object) - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- get(Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
- get(Type) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type.
- get(Type) - Static method in class org.elasticsearch.common.inject.TypeLiteral
-
Gets type literal for the given
Type
instance. - get(Type, Annotation) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type and an annotation.
- get(Type, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type and an annotation type.
- get(String) - Method in class org.elasticsearch.action.ActionRequestBuilder
-
Short version of execute().actionGet().
- get(String) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- get(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
-
Get a node by its id
- get(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get a node by its id
- get(String) - Method in class org.elasticsearch.cluster.RestoreInProgress
- get(String) - Method in class org.elasticsearch.common.FieldMemoryStats
-
Returns the fields value in bytes or
0
if it's not present in the stats - get(String) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Returns the
Setting
for the given key ornull
if the setting can not be found. - get(String) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Returns a setting value based on the setting key.
- get(String) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value associated with the setting key.
- get(String) - Method in class org.elasticsearch.index.analysis.IndexAnalyzers
-
Returns an analyzer mapped to the given name or
null
if not present - get(String) - Method in class org.elasticsearch.index.mapper.LuceneDocument
- get(String) - Method in class org.elasticsearch.index.search.stats.FieldUsageStats
- get(String) - Method in class org.elasticsearch.index.seqno.RetentionLeases
-
Returns the retention lease with the specified ID, or null if no such retention lease exists.
- get(String) - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
- get(String) - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- get(String) - Method in class org.elasticsearch.search.aggregations.Aggregations
-
Returns the aggregation that is associated with the specified name.
- get(String) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
-
Returns a context mapping by its name
- get(String, String) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value associated with the setting key.
- get(String, String, String[], boolean, long, VersionType, FetchSourceContext) - Method in class org.elasticsearch.index.get.ShardGetService
- get(TemporalField) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- get(Future<T>) - Static method in class org.elasticsearch.common.util.concurrent.FutureUtils
-
Calls
Future.get()
without the checked exceptions. - get(Future<T>, long, TimeUnit) - Static method in class org.elasticsearch.common.util.concurrent.FutureUtils
-
Calls
Future.get(long, TimeUnit)
without the checked exceptions. - get(K) - Method in class org.elasticsearch.common.cache.Cache
-
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
- get(K) - Method in class org.elasticsearch.common.collect.MapBuilder
- get(K, Errors) - Method in class org.elasticsearch.common.inject.internal.FailableCache
- get(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- get(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- get(GetRequest) - Method in interface org.elasticsearch.client.Client
-
Gets the document that was indexed from an index with a type and id.
- get(GetRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- get(GetRequest, ActionListener<GetResponse>) - Method in interface org.elasticsearch.client.Client
-
Gets the document that was indexed from an index with a type and id.
- get(GetRequest, ActionListener<GetResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- get(Errors, InternalContext, Dependency<?>) - Method in interface org.elasticsearch.common.inject.internal.InternalFactory
-
Creates an object to be injected.
- get(Errors, InternalContext, Dependency<?>) - Method in class org.elasticsearch.common.inject.internal.InternalFactory.Instance
- get(Key<T>) - Static method in class org.elasticsearch.common.inject.spi.Dependency
-
Returns a new dependency that is not attached to an injection point.
- get(TypeLiteral<T>) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type.
- get(TypeLiteral<T>, Annotation) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type and an annotation.
- get(TypeLiteral<T>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.Key
-
Gets a key for an injection type and an annotation type.
- get(Setting<T>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Returns the value for the given setting.
- get(Settings) - Method in class org.elasticsearch.common.settings.SecureSetting
- get(Settings) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
- get(Settings) - Method in class org.elasticsearch.common.settings.Setting
-
Returns the settings value.
- get(Settings, Setting<Long>) - Static method in class org.elasticsearch.common.Randomness
-
Provides a reproducible source of randomness seeded by a long seed in the settings with the key setting.
- get(Settings, Settings) - Method in class org.elasticsearch.common.settings.Setting
-
Returns the value for this setting but falls back to the second provided settings object
- get(CheckedConsumer<PlainActionFuture<T>, E>) - Static method in class org.elasticsearch.action.support.PlainActionFuture
- get(CheckedConsumer<PlainActionFuture<T>, E>, long, TimeUnit) - Static method in class org.elasticsearch.action.support.PlainActionFuture
- get(TimeValue) - Method in class org.elasticsearch.action.ActionRequestBuilder
-
Short version of execute().actionGet().
- get(Environment, String) - Method in interface org.elasticsearch.indices.analysis.AnalysisModule.AnalysisProvider
-
Creates a new global scope analysis provider without index specific settings not settings for the provider itself.
- get(Engine.Get) - Method in class org.elasticsearch.index.shard.IndexShard
- get(Engine.GetResult, String, String, String[], FetchSourceContext) - Method in class org.elasticsearch.index.get.ShardGetService
-
Returns
GetResult
based on the specifiedEngine.GetResult
argument. - get(Engine.Get, MappingLookup, DocumentParser, Function<Engine.Searcher, Engine.Searcher>) - Method in class org.elasticsearch.index.engine.Engine
- get(Engine.Get, MappingLookup, DocumentParser, Function<Engine.Searcher, Engine.Searcher>) - Method in class org.elasticsearch.index.engine.InternalEngine
- get(Engine.Get, MappingLookup, DocumentParser, Function<Engine.Searcher, Engine.Searcher>) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- get(IndexSettings, Environment, String, Settings) - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProviderFactory
- get(IndexSettings, Environment, String, Settings) - Method in class org.elasticsearch.index.analysis.PreConfiguredAnalysisComponent
- get(IndexSettings, Environment, String, Settings) - Method in interface org.elasticsearch.indices.analysis.AnalysisModule.AnalysisProvider
-
Creates a new analysis provider.
- get(Version) - Method in interface org.elasticsearch.indices.analysis.PreBuiltCacheFactory.PreBuiltCache
- Get - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- Get(boolean, boolean, String, String, Term) - Constructor for class org.elasticsearch.index.engine.Engine.Get
- GET - Enum constant in enum class org.elasticsearch.rest.RestRequest.Method
- GET - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- get_score() - Method in class org.elasticsearch.script.StringSortScript
-
Return the score of the current document.
- get_score() - Method in class org.elasticsearch.script.AggregationScript
- get_score() - Method in class org.elasticsearch.script.ScoreScript
-
Accessed as _score in the painless script
- get_score() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- get_value() - Method in class org.elasticsearch.script.AggregationScript
- getAbsolute() - Method in class org.elasticsearch.common.unit.RelativeByteSizeValue
- getAcceptedState() - Method in class org.elasticsearch.cluster.coordination.PublishRequest
- getAction() - Method in class org.elasticsearch.plugins.ActionPlugin.ActionHandler
- getAction() - Method in class org.elasticsearch.tasks.Task
-
Returns task action
- getAction() - Method in class org.elasticsearch.tasks.TaskInfo
- getAction() - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- GetAction - Class in org.elasticsearch.action.get
- getActionFilters() - Method in class org.elasticsearch.action.ActionModule
- getActionFilters() - Method in interface org.elasticsearch.plugins.ActionPlugin
-
ActionType filters added by this plugin.
- getActionName() - Method in class org.elasticsearch.transport.Header
- getActions() - Method in class org.elasticsearch.action.ActionModule
- getActions() - Method in class org.elasticsearch.action.datastreams.ModifyDataStreamsAction.Request
- getActions() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
Return the list of action masks for the actions that should be returned
- getActions() - Method in interface org.elasticsearch.plugins.ActionPlugin
-
Actions added by this plugin.
- getActive() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- getActiveContexts() - Method in class org.elasticsearch.search.SearchService
-
Returns the number of active contexts in this SearchService
- getActiveOperations() - Method in class org.elasticsearch.index.shard.IndexShard
- getActiveOperationsCount() - Method in class org.elasticsearch.index.shard.IndexShard
-
Obtain the active operation count, or
IndexShard.OPERATIONS_BLOCKED
if all permits are held (even if there are outstanding operations in flight). - getActivePrimaryShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getActivePrimaryShards() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getActivePrimaryShards() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getActiveShardCount() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- getActiveShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getActiveShards() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getActiveShards() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- getActiveShards() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getActiveShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of active shards - getActiveShardsPercent() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
-
The percentage of active shards, should be 100% in a green system
- getActiveShardsPercent() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getActualIndices() - Method in class org.elasticsearch.action.search.SearchContextId
- getActualTypeArguments() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- getAdaptiveSelectionStats() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getAdaptiveStats(Map<String, Long>) - Method in class org.elasticsearch.node.ResponseCollectorService
- getAdded() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.IndexGraveyardDiff
-
The index tombstones that were added between two states
- getAdditionalIndexSettingProviders() - Method in class org.elasticsearch.plugins.Plugin
-
An
IndexSettingProvider
allows hooking in to parts of an index lifecycle to provide explicit default settings for newly created indices. - getAdditionalIndexSettings(String, boolean, Settings) - Method in class org.elasticsearch.cluster.routing.allocation.DataTier.DefaultHotAllocationSettingProvider
- getAdditionalIndexSettings(String, boolean, Settings) - Method in interface org.elasticsearch.index.shard.IndexSettingProvider
-
Returns explicitly set default index
Settings
for the given index. - getAddress() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
The address that the node can be communicated with.
- getAddress() - Method in class org.elasticsearch.common.transport.TransportAddress
-
Returns a string representation of the enclosed
InetSocketAddress
- getAddress() - Method in class org.elasticsearch.http.HttpInfo
- getAddress() - Method in class org.elasticsearch.transport.ProxyConnectionStrategy.ProxyModeInfo
- getAddress() - Method in class org.elasticsearch.transport.TransportInfo
- getAgeInMillis() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedRunnable
-
The elapsed time in milliseconds since this instance was created, as calculated by the difference between
System.nanoTime()
at the time of creation, andSystem.nanoTime()
at the time of invocation of this method - getAggregatedDfs() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- getAggregatedDfs() - Method in class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- getAggregatedDfs(AggregatedDfs) - Method in class org.elasticsearch.search.internal.LegacyReaderContext
- getAggregatedDfs(AggregatedDfs) - Method in class org.elasticsearch.search.internal.ReaderContext
- getAggregationExtentions() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
Allows plugins to register new aggregations using aggregation names that are already defined in Core, as long as the new aggregations target different ValuesSourceTypes
- getAggregationProfiler() - Method in class org.elasticsearch.search.profile.Profilers
- getAggregationProfileResults() - Method in class org.elasticsearch.search.profile.SearchProfileQueryPhaseResult
- getAggregationProfileResults() - Method in class org.elasticsearch.search.profile.SearchProfileShardResult
- getAggregations() - Method in class org.elasticsearch.action.search.SearchResponse
- getAggregations() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
Aggregation
s added by this plugin. - getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite.InternalBucket
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- getAggregations() - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.ParsedSingleBucketAggregation
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getAggregations() - Method in interface org.elasticsearch.search.aggregations.bucket.SingleBucketAggregation
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket
- getAggregations() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- getAggregations() - Method in interface org.elasticsearch.search.aggregations.HasAggregations
- getAggregations() - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- getAggregations() - Method in class org.elasticsearch.search.aggregations.support.AggregationInfo
- getAggregationUsage() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- getAggregator(ValuesSourceRegistry.RegistryKey<T>, ValuesSourceConfig) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry
- getAggregatorFactories() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- getAggregatorPath(Aggregator) - Static method in class org.elasticsearch.search.profile.aggregation.AggregationProfiler
- getAggregatorReader() - Method in class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Deprecated.Pipelines implemented after 7.8.0 do not need to be sent across the wire
- getAggregatorRegistrar() - Method in class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Get the function to register the
ValuesSource
to aggregator mappings for this aggregation - getAlgorithm() - Method in class org.elasticsearch.common.hash.Murmur3Hasher
- getAlgorithm(long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
-
Algorithm used in the given bucket
- getAlgorithm(long) - Method in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- getAlias() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- getAlias() - Method in class org.elasticsearch.cluster.metadata.AliasAction.Add
-
Alias to add to the index.
- getAlias() - Method in class org.elasticsearch.cluster.metadata.AliasAction.Remove
-
Alias to remove from the index.
- getAlias() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- getAliasActions() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- getAliases() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesResponse
- getAliases() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- getAliases() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedIndex
- getAliases() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Response
- getAliases() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- getAliases() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.ConcreteIndex
- getAliases() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- getAliases() - Method in interface org.elasticsearch.cluster.metadata.IndexAbstraction
- getAliases() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getAliases() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- getAliases() - Method in class org.elasticsearch.search.internal.AliasFilter
-
Returns the aliases patters that are used to compose the
QueryBuilder
returned fromAliasFilter.getQueryBuilder()
- getAliases(GetAliasesRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get specific index aliases that exists in particular indices and / or by name.
- getAliases(GetAliasesRequest, ActionListener<GetAliasesResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get specific index aliases that exists in particular indices and / or by name.
- GetAliasesAction - Class in org.elasticsearch.action.admin.indices.alias.get
- GetAliasesRequest - Class in org.elasticsearch.action.admin.indices.alias.get
- GetAliasesRequest() - Constructor for class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- GetAliasesRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- GetAliasesRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- GetAliasesRequestBuilder - Class in org.elasticsearch.action.admin.indices.alias.get
- GetAliasesRequestBuilder(ElasticsearchClient, GetAliasesAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequestBuilder
- GetAliasesResponse - Class in org.elasticsearch.action.admin.indices.alias.get
- GetAliasesResponse(ImmutableOpenMap<String, List<AliasMetadata>>, Map<String, List<DataStreamAlias>>) - Constructor for class org.elasticsearch.action.admin.indices.alias.get.GetAliasesResponse
- GetAliasesResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.alias.get.GetAliasesResponse
- getAliasesVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getAliasFilter() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- getAliasMap() - Method in class org.elasticsearch.common.Table
- getAliasName() - Method in class org.elasticsearch.cluster.metadata.AliasAction.AddDataStreamAlias
- getAliasName() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getAllAddresses() - Static method in class org.elasticsearch.common.network.NetworkUtils
-
Returns all addresses (any scope) for interfaces that are up.
- getAllAllocationIds() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- getAllConcreteSettings(Settings) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
-
Returns a stream of all concrete setting instances for the given settings.
- getAllConnectedNodes() - Method in class org.elasticsearch.transport.ClusterConnectionManager
- getAllConnectedNodes() - Method in interface org.elasticsearch.transport.ConnectionManager
- getAllConnectedNodes() - Method in class org.elasticsearch.transport.RemoteConnectionManager
- getAllHeaderValues(String) - Method in class org.elasticsearch.rest.RestRequest
-
Get all values for the header or
null
if the header was not found - getAllInitializingShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of all initializing shards, including target shards of relocations - getAllIPV4Addresses() - Static method in class org.elasticsearch.common.network.NetworkUtils
- getAllIPV6Addresses() - Static method in class org.elasticsearch.common.network.NetworkUtils
- getAllMetadataFields() - Method in class org.elasticsearch.indices.IndicesService
-
Returns the registered metadata field names for all compatible versions.
- getAllMetadataMapperParsers() - Method in class org.elasticsearch.index.mapper.MapperRegistry
-
Return a map of all meta mappers that have been registered in all compatible versions.
- getAllNodeMetadataMap() - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- getAllNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Return all the nodes as a collection
- getAllNodeStatistics() - Method in class org.elasticsearch.node.ResponseCollectorService
- getAllocateDecision() - Method in class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
-
Gets the unassigned allocation decision for the shard.
- getAllocatedProcessors() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
- getAllocatedProcessors() - Method in class org.elasticsearch.monitor.os.OsInfo
- getAllocationComparator(RoutingAllocation) - Static method in class org.elasticsearch.gateway.PriorityComparator
-
Returns a PriorityComparator that uses the RoutingAllocation index metadata to access the index setting per index.
- getAllocationDecision() - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Returns the
AllocationDecision
denoting the result of an allocation attempt. - getAllocationDecision() - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Returns the
AllocationDecision
for moving this shard to another node. - getAllocationDelay() - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- getAllocationId() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
-
AllocationStatus id of the store, used to select the store that will be used as a primary.
- getAllocationId() - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.FailedShardEntry
- getAllocationId() - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Gets the allocation id for the existing shard copy that the allocator is assigning the shard to.
- getAllocationId() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
-
Gets the allocation id for the shard copy, if it exists.
- getAllocationId() - Method in class org.elasticsearch.cluster.routing.allocation.StaleShard
-
The allocation id of the stale shard.
- getAllocationId() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- getAllocationId() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- getAllocationService() - Method in class org.elasticsearch.cluster.ClusterModule
- getAllocationStatus() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
-
The allocationStatus status of the store.
- getAllocationStatus() - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Returns the status of an unsuccessful allocation attempt.
- getAllowAutoCreate() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- getAllowedElasticProductOrigins() - Method in class org.elasticsearch.indices.SystemDataStreamDescriptor
- getAllowedElasticProductOrigins() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getAllStats() - Method in class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
- getAlpha() - Method in class org.elasticsearch.search.suggest.phrase.Laplace
- getAnalysis() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getAnalysis() - Method in class org.elasticsearch.indices.IndicesService
- getAnalysisMode() - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- getAnalysisMode() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
-
Returns whether this analyzer can be updated
- getAnalysisMode() - Method in class org.elasticsearch.index.analysis.ReloadableCustomAnalyzer
- getAnalysisMode() - Method in interface org.elasticsearch.index.analysis.TokenFilterFactory
-
Get the
AnalysisMode
this filter is allowed to be used in. - getAnalysisRegistry() - Method in class org.elasticsearch.indices.analysis.AnalysisModule
- getAnalyzer() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getAnalyzer() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns an analyzer that will be used to parse source doc with.
- getAnalyzer() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the analyzer as the default analyzer in the engines
IndexWriter
- getAnalyzer() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getAnalyzer(String) - Method in class org.elasticsearch.index.analysis.AnalysisRegistry
-
Returns a registered
Analyzer
provider by name ornull
if the analyzer was not registered - getAnalyzer(MappedFieldType, boolean) - Method in class org.elasticsearch.index.search.MatchQueryParser
- getAnalyzer(Version) - Method in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- getAnalyzers() - Method in class org.elasticsearch.index.analysis.IndexAnalyzers
-
Returns an (unmodifiable) map of containing the index analyzers
- getAnalyzers() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional
Analyzer
s. - getAndSetNodeIdAndClusterId(ClusterService, ThreadContext) - Static method in class org.elasticsearch.common.logging.NodeAndClusterIdStateListener
-
Subscribes for the first cluster state update where nodeId and clusterId is present and sets these values in
NodeAndClusterIdConverter
. - getAnnotation() - Method in class org.elasticsearch.common.inject.Key
-
Gets the annotation.
- getAnnotationType() - Method in class org.elasticsearch.common.inject.Key
-
Gets the annotation type.
- getAnnotationType() - Method in class org.elasticsearch.common.inject.spi.ScopeBinding
- getAny() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- getAnyRemoteConnection() - Method in class org.elasticsearch.transport.RemoteConnectionManager
- getApplierRecordingStats() - Method in class org.elasticsearch.discovery.DiscoveryStats
- getApplierState() - Method in class org.elasticsearch.cluster.coordination.Coordinator
- getApproximateTiming() - Method in class org.elasticsearch.search.profile.Timer
-
Return an approximation of the total time spent between consecutive calls of #start and #stop.
- getArch() - Method in class org.elasticsearch.monitor.os.OsInfo
- getArguments() - Method in class org.elasticsearch.common.logging.ESLogMessage
- getArrayLength() - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
-
Get the size of the internal array using a method so we can override it during testing
- getAsBoolean() - Method in enum class org.elasticsearch.common.geo.Orientation
- getAsBoolean(String, Boolean) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as boolean) associated with the setting key.
- getAsBytesSize(String, ByteSizeValue) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as size) associated with the setting key.
- getAsCalendarInterval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
-
Returns the interval as a calendar interval.
- getAsDouble(String, Double) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as double) associated with the setting key.
- getAsFixedInterval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
-
Returns the interval as a Fixed interval.
- getAsFloat(String, Float) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as float) associated with the setting key.
- getAsGroups() - Method in class org.elasticsearch.common.settings.Settings
-
Returns group settings for the given setting prefix.
- getAsInt(String, Integer) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as int) associated with the setting key.
- getAsList(String) - Method in class org.elasticsearch.common.settings.Settings
-
The values associated with a setting key as an immutable list.
- getAsList(String, List<String>) - Method in class org.elasticsearch.common.settings.Settings
-
The values associated with a setting key as an immutable list.
- getAsList(String, List<String>, Boolean) - Method in class org.elasticsearch.common.settings.Settings
-
The values associated with a setting key as an immutable list.
- getAsLong() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
- getAsLong(String, Long) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as long) associated with the setting key.
- getAsMap() - Method in class org.elasticsearch.common.Table
- getAsMap() - Method in class org.elasticsearch.search.aggregations.Aggregations
-
Returns the
Aggregation
s keyed by aggregation name. - getAsMap(Settings) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
-
Returns a map of all namespaces to it's values give the provided settings
- getAsMemory(String, String) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as size) associated with the setting key.
- getAsPercent() - Method in class org.elasticsearch.common.unit.RatioValue
- getAsRatio() - Method in class org.elasticsearch.common.unit.RatioValue
- getAsSettings(String) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the settings mapped to the given setting name.
- getAssignment() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- getAssignment(SystemIndexMigrationTaskParams, Collection<DiscoveryNode>, ClusterState) - Method in class org.elasticsearch.upgrades.SystemIndexMigrationExecutor
- getAssignment(Params, Collection<DiscoveryNode>, ClusterState) - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
-
Returns the node id where the params has to be executed,
- getAssociatedIndexDescriptors() - Method in class org.elasticsearch.indices.SystemIndices.Feature
- getAssociatedIndexDescriptors() - Method in interface org.elasticsearch.plugins.SystemIndexPlugin
-
Returns a list of descriptors for "associated indices": indices which depend on this plugin's system indices, but are not themselves system indices.
- getAsTime(String, TimeValue) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the setting value (as time) associated with the setting key.
- getAsVersion(String, Version) - Method in class org.elasticsearch.common.settings.Settings
-
Returns a parsed version.
- getAt(int) - Method in class org.elasticsearch.action.admin.indices.segments.IndexShardSegments
- getAt(int) - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- getAt(int) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- getAt(int) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexShardUpgradeStatus
- getAt(int) - Method in class org.elasticsearch.search.SearchHits
-
Return the hit as the provided position.
- getAttributes() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeToken
- getAttributes() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedIndex
- getAttributes() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
The node attributes.
- getAttributes() - Method in class org.elasticsearch.index.engine.Segment
-
Return segment attributes.
- getAttributeValues(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- getAutoExpandReplicaChanges(Metadata, RoutingAllocation) - Static method in class org.elasticsearch.cluster.metadata.AutoExpandReplicas
-
Checks if there are replicas with the auto-expand feature that need to be adapted.
- getAutoGeneratedIdTimestamp() - Method in class org.elasticsearch.index.engine.Engine.Index
-
Returns a positive timestamp if the ID of this document is auto-generated by elasticsearch.
- getAutoGeneratedIdTimestamp() - Method in class org.elasticsearch.index.translog.Translog.Index
- getAutoGeneratedTimestamp() - Method in class org.elasticsearch.action.index.IndexRequest
-
Returns the timestamp the auto generated ID was created or -1L if the document has no auto generated timestamp.
- getAvailable() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- getAvailableLocales() - Method in class org.elasticsearch.common.time.IsoCalendarDataProvider
- getAvailableProcessors() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
- getAvailableProcessors() - Method in class org.elasticsearch.monitor.os.OsInfo
- getAverage() - Method in class org.elasticsearch.common.ExponentiallyWeightedMovingAverage
- getAvg() - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- getAvg() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- getAvg() - Method in interface org.elasticsearch.search.aggregations.metrics.Stats
- getAvgAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- getAvgAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- getAvgAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.Stats
- getAvgIndexPrimaryShards() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
the average number primary shards across the indices
- getAvgIndexReplication() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
average replication factor across the indices.
- getAvgIndexShards() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
average number of shards (primary+replicas) across the indices
- getAvgOpenFileDescriptors() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
- getBackingIndexNames(Metadata) - Method in class org.elasticsearch.indices.SystemDataStreamDescriptor
-
Retrieve backing indices for this system data stream
- getBackingIndexPattern() - Method in class org.elasticsearch.indices.SystemDataStreamDescriptor
- getBackingIndices() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedDataStream
- getBanCount() - Method in class org.elasticsearch.tasks.TaskManager
-
Returns the number of currently banned tasks.
- getBannedTaskIds() - Method in class org.elasticsearch.tasks.TaskManager
- getBatchedReduceSize() - Method in class org.elasticsearch.action.search.SearchRequest
-
Returns the number of shard results that should be reduced at once on the coordinating node.
- getBatches() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getBatches() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Number of scan responses this request has processed.
- getBatchSize() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Gets the batch size for this request
- getBatchSize() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Gets the batch size for this request
- getBigArrays() - Method in class org.elasticsearch.index.IndexService
-
The
BigArrays
to use for this index. - getBigArrays() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns a BigArrays instance for this engine
- getBigramLambda() - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- getBinaryValue(String) - Method in class org.elasticsearch.index.mapper.LuceneDocument
- getBinding() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- getBitsetMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getBitsetMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of how much the cached bit sets are taking.
- getBitSetProducer(Query) - Method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- getBlobStore() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getBlobStoreIndexShardSnapshots(IndexId, int, ShardGeneration) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Loads all available snapshots in the repository using the given
generation
for a shard. - getblock(byte[], int, int) - Static method in enum class org.elasticsearch.common.hash.MurmurHash3
- getBlock() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockClusterStateUpdateRequest
- getBlock() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockRequest
-
Returns the block to be added
- getBlock() - Method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
- getBlocks() - Method in class org.elasticsearch.cluster.ClusterState
- getBooleanQuery(List<BooleanClause>) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getBoost() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Query
-
The boost of the query.
- getBoost() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.IndexBoost
- getBoost() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext
-
Returns the query-time boost of the context
- getBoost() - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
-
Returns the query-time boost of the context
- getBoostFactor() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the boost factor used when boosting terms
- getBoostTermsFactor() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getBootClassPath() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getBootstrapChecks() - Method in class org.elasticsearch.plugins.Plugin
-
Returns a list of checks that are enforced when a node starts up once a node has the transport protocol bound to a non-loopback interface.
- getBottomSortValues() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- getBoundingBox() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Geometry
-
Returns the bounding box of this geometry
- getBoundingBox() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getBreaker() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getBreaker(String) - Method in class org.elasticsearch.common.breaker.PreallocatedCircuitBreakerService
- getBreaker(String) - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
- getBreaker(String) - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- getBreaker(String) - Method in class org.elasticsearch.indices.breaker.NoneCircuitBreakerService
- getBreakIterator(String) - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
- getBreakIterator(SearchHighlightContext.Field) - Method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrix
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.ParsedAdjacencyMatrix
- getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.filter.Filters
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedRareTerms
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.terms.RareTerms
-
Get the bucket for the given term, or null if there is no such bucket.
- getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.terms.SignificantTerms
-
Get the bucket for the given term, or null if there is no such bucket.
- getBucketByKey(String) - Method in interface org.elasticsearch.search.aggregations.bucket.terms.Terms
-
Get the bucket for the given term, or null if there is no such bucket.
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- getBucketByKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- getBucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- getBucketCountThresholds() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- getBucketInfo() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrix
-
The buckets created by this aggregation.
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.ParsedAdjacencyMatrix
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.filter.Filters
-
The buckets created by this aggregation.
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.geogrid.GeoGrid
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoGrid
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedHistogram
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range
-
Return the buckets of this range aggregation.
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedRareTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.RareTerms
-
Return the sorted list of the buckets in this terms aggregation.
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.SignificantTerms
- getBuckets() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.Terms
-
Return the sorted list of the buckets in this terms aggregation.
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- getBuckets() - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
- getBucketSize() - Method in class org.elasticsearch.search.sort.BucketedSort
-
The number of values to store per bucket.
- getBucketsPaths() - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
-
Return the consumed buckets paths.
- getBufferPools() - Method in class org.elasticsearch.monitor.jvm.JvmStats
- getBufferSize() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
The translog buffer size.
- getBuild() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
The build version of the node.
- getBuild() - Method in class org.elasticsearch.action.main.MainResponse
- getBuildHash() - Method in class org.elasticsearch.transport.TransportService.HandshakeResponse
- getBuiltInMetadataFields() - Static method in class org.elasticsearch.indices.IndicesModule
-
Returns a set containing all of the builtin metadata fields
- getBulkFailures() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
-
All of the bulk failures.
- getBulkRetries() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
-
The number of times that the request had retry bulk actions.
- getBulkRetries() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Number of retries that had to be attempted due to bulk actions being rejected.
- getBundledJdk() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getByAllocationId(String) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- getByAllocationId(ShardId, String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- getByAllocationId(ShardId, String) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- getByGcName(String, String) - Static method in class org.elasticsearch.monitor.jvm.GcNames
- getByKey(Object) - Method in class org.elasticsearch.index.mapper.LuceneDocument
-
Get back fields that have been previously added with
LuceneDocument.addWithKey(Object, IndexableField)
. - getByMemoryPoolName(String, String) - Static method in class org.elasticsearch.monitor.jvm.GcNames
-
Resolves the GC type by its memory pool name (
MemoryPoolMXBean.getName()
. - getByParent(TaskId) - Method in class org.elasticsearch.tasks.CancellableTasksTracker
-
Return a collection of all the tracked items with a given parent, which will include at least every item for which
CancellableTasksTracker.put(org.elasticsearch.tasks.Task, T)
completed, butCancellableTasksTracker.remove(org.elasticsearch.tasks.Task)
hasn't started. - getByPrefix(String) - Method in class org.elasticsearch.common.settings.Settings
-
A settings that are filtered (and key is removed) with the specified prefix.
- getByShardId(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingNode
- getByteLimit() - Method in exception org.elasticsearch.common.breaker.CircuitBreakingException
- getBytes() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getBytesRead() - Method in class org.elasticsearch.transport.StatsTracker
- getBytesValues() - Method in interface org.elasticsearch.index.fielddata.LeafFieldData
-
Return a String representation of the values.
- getBytesValues() - Method in class org.elasticsearch.index.fielddata.plain.AbstractLeafGeoPointFieldData
- getBytesValues() - Method in class org.elasticsearch.index.fielddata.plain.AbstractLeafOrdinalsFieldData
- getBytesValues() - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVLeafFieldData
- getBytesValues() - Method in class org.elasticsearch.index.fielddata.plain.LeafDoubleFieldData
- getBytesValues() - Method in class org.elasticsearch.index.fielddata.plain.LeafLongFieldData
- getBytesValues() - Method in class org.elasticsearch.index.mapper.flattened.KeyedFlattenedLeafFieldData
- getBytesWanted() - Method in exception org.elasticsearch.common.breaker.CircuitBreakingException
- getBytesWritten() - Method in class org.elasticsearch.transport.StatsTracker
- getCache() - Method in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- getCache() - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
- getCache(PreBuiltCacheFactory.CachingStrategy) - Static method in class org.elasticsearch.indices.analysis.PreBuiltCacheFactory
- getCacheCount() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
The number of
DocIdSet
s that have been cached. - getCacheEvictions() - Method in class org.elasticsearch.script.ScriptContextStats
- getCacheEvictions() - Method in class org.elasticsearch.script.ScriptStats
- getCacheEvictionsHistory() - Method in class org.elasticsearch.script.ScriptContextStats
- getCacheKey() - Method in interface org.elasticsearch.transport.Transport.Connection
-
Returns a key that this connection can be cached on.
- getCacheSize() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
The number of
DocIdSet
s that are in the cache. - getCachingStrategy() - Method in enum class org.elasticsearch.indices.analysis.PreBuiltTokenizers
- getCalendarInterval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Returns the interval as a date time unit if and only if it was configured as a calendar interval originally.
- getCamelCaseName() - Method in enum class org.elasticsearch.common.time.FormatNames
- getCanAllocateDecision() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
-
The decision details for allocating to this node.
- getCancellableTask(long) - Method in class org.elasticsearch.tasks.TaskManager
-
Returns a cancellable task with given id, or null if the task is not found.
- getCancellableTasks() - Method in class org.elasticsearch.tasks.TaskManager
-
Returns the list of currently running tasks on the node that can be cancelled
- getCanRemainDecision() - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Returns the decision for the shard being allowed to remain on its current node.
- getCategory() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext
-
Returns the category of the context
- getCause() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The actual cause of the failure.
- getCause() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- getCause() - Method in exception org.elasticsearch.action.ShardOperationFailedException
-
The cause of this failure
- getCause() - Method in class org.elasticsearch.action.TaskOperationFailure
- getCause() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
-
The failure cause.
- getCause() - Method in class org.elasticsearch.common.inject.spi.Message
-
Returns the throwable that caused this message, or
null
if this message was not caused by a throwable. - getCause() - Method in interface org.elasticsearch.ElasticsearchWrapperException
- getCentroid() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Geometry
-
Returns the centroid of this geometry
- getCentroid() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getCenturyOfEra() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getCgroup() - Method in class org.elasticsearch.monitor.os.OsStats
- getChainAwareTokenFilterFactory(TokenizerFactory, List<CharFilterFactory>, List<TokenFilterFactory>, Function<String, TokenFilterFactory>) - Method in interface org.elasticsearch.index.analysis.TokenFilterFactory
-
Rewrite the TokenFilterFactory to take into account the preceding analysis chain, or refer to other TokenFilterFactories
- getChannel() - Method in class org.elasticsearch.transport.TaskTransportChannel
- getChannel() - Method in class org.elasticsearch.transport.TcpTransportChannel
- getChannels() - Method in class org.elasticsearch.transport.TcpTransport.NodeChannels
- getChannelStats() - Method in interface org.elasticsearch.transport.TcpChannel
-
Returns stats about this channel
- getChannelType() - Method in class org.elasticsearch.transport.TaskTransportChannel
- getChannelType() - Method in class org.elasticsearch.transport.TcpTransportChannel
- getChannelType() - Method in interface org.elasticsearch.transport.TransportChannel
- getChannelVersion() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
-
Returns the minimum version of the channel that the request has been passed.
- getCharFilters() - Method in class org.elasticsearch.index.analysis.AnalyzerComponents
- getCharFilters() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional
CharFilter
s. - getChars() - Method in class org.elasticsearch.common.settings.SecureString
-
Returns the underlying char[].
- getCharset() - Method in class org.elasticsearch.common.logging.ESJsonLayout.Builder
- getCheckpointStates() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- getChecksum() - Method in class org.elasticsearch.common.lucene.store.FilterIndexOutput
- getChecksum() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- getChecksum() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
- getChild() - Method in class org.elasticsearch.search.SearchHit.NestedIdentity
-
Returns the next child nested level if there is any, otherwise
null
is returned. - getChildFieldType(String) - Method in interface org.elasticsearch.index.mapper.DynamicFieldType
-
Returns a dynamic MappedFieldType for the given path
- getChildFieldType(String) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.RootFlattenedFieldType
- getChildQuery() - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
-
Return the child query.
- getChildren() - Method in class org.elasticsearch.index.mapper.NestedObjectMapper
- getChildResources() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData.Consumer
- getChildResources() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- getChildResources() - Method in class org.elasticsearch.index.fielddata.ordinals.MultiOrdinals
- getChildResources() - Method in class org.elasticsearch.index.fielddata.ordinals.SinglePackedOrdinals
- getChildResources() - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVLeafFieldData
- getChildResources() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesLeafFieldData
- getChildResources() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetBytesLeafFieldData
- getChildResources() - Method in class org.elasticsearch.index.mapper.flattened.KeyedFlattenedLeafFieldData
- getChildTasks() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup
- getChronology() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getChunkSize() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- getCircuitBreaker(Settings) - Method in interface org.elasticsearch.plugins.CircuitBreakerPlugin
-
Each of the factory functions are passed to the configured
CircuitBreakerService
. - getCircuitBreakerService() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the circuit breaker service for this engine, or
null
if none is to be used. - getCircuitBreakerService() - Method in class org.elasticsearch.indices.IndicesService
- getClasses() - Method in class org.elasticsearch.monitor.jvm.JvmStats
- getClassname() - Method in class org.elasticsearch.plugins.PluginDescriptor
-
The entry point to the plugin.
- getClassPath() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getCleanStatus(Directory, Lock, PrintStream, boolean) - Method in class org.elasticsearch.index.shard.RemoveCorruptedLuceneSegmentsAction
- getCleanStatus(ShardPath, ClusterState, Directory) - Method in class org.elasticsearch.index.translog.TruncateTranslogAction
- getCleanUpFunction() - Method in class org.elasticsearch.indices.SystemIndices.Feature
- getClient() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- getClientActions() - Method in interface org.elasticsearch.plugins.ActionPlugin
-
Client actions added by this plugin.
- getClientStats() - Method in class org.elasticsearch.http.HttpStats
- getClusterAlias() - Method in class org.elasticsearch.action.search.SearchContextIdForNode
- getClusterAlias() - Method in class org.elasticsearch.action.search.SearchShard
-
Return the cluster alias if we are executing a cross cluster search request,
null
otherwise. - getClusterAlias() - Method in class org.elasticsearch.action.search.SearchShardIterator
-
Returns the alias of the cluster where the shard is located.
- getClusterAlias() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- getClusterAlias() - Method in class org.elasticsearch.search.SearchHit
-
Returns the cluster alias this hit comes from or null if it comes from a local cluster
- getClusterAlias() - Method in class org.elasticsearch.search.SearchShardTarget
- getClusterAlias() - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- getClusterApplierService() - Method in class org.elasticsearch.cluster.service.ClusterService
- getClusterInfo() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
Returns the cluster disk info for the cluster, or
null
if none available. - getClusterInfo() - Method in interface org.elasticsearch.cluster.ClusterInfoService
- getClusterInfo() - Method in class org.elasticsearch.cluster.EmptyClusterInfoService
- getClusterInfo() - Method in class org.elasticsearch.cluster.InternalClusterInfoService
- getClusterName() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getClusterName() - Method in class org.elasticsearch.action.admin.cluster.node.liveness.LivenessResponse
- getClusterName() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
-
The name of the cluster.
- getClusterName() - Method in class org.elasticsearch.action.main.MainResponse
- getClusterName() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
Get the
ClusterName
associated with all of the nodes. - getClusterName() - Method in class org.elasticsearch.cluster.ClusterState
- getClusterName() - Method in class org.elasticsearch.cluster.service.ClusterService
- getClusterName() - Method in class org.elasticsearch.transport.TransportService.HandshakeResponse
- getClusterRebalanceDecision() - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Returns the decision for being allowed to rebalance the shard.
- getClusters() - Method in class org.elasticsearch.action.search.SearchResponse
-
Returns info about what clusters the search was executed against.
- getClusterService() - Method in class org.elasticsearch.ingest.IngestService
- getClusterSettings() - Method in class org.elasticsearch.cluster.service.ClusterService
- getClusterSettings() - Method in class org.elasticsearch.common.settings.SettingsModule
- getClusterState() - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService.CommandsResult
-
the resulting cluster state, after the commands were applied
- getClusterStateSerializationStats() - Method in class org.elasticsearch.discovery.zen.PublishClusterStateStats
- getClusterStateUpdateStats() - Method in class org.elasticsearch.cluster.service.MasterService
- getClusterStateUpdateStats() - Method in class org.elasticsearch.discovery.DiscoveryStats
- getClusterStateVersion() - Method in class org.elasticsearch.cluster.metadata.Manifest
- getClusterStateVersion() - Method in class org.elasticsearch.discovery.zen.ElectMasterService.MasterCandidate
- getClusterStateVersion() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingResponse
-
the current cluster state version of that node (
ElectMasterService.MasterCandidate.UNRECOVERED_CLUSTER_VERSION
for not recovered) - getClusterUuid() - Method in class org.elasticsearch.action.main.MainResponse
- getClusterUUID() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- getClusterUUID() - Method in class org.elasticsearch.repositories.RepositoryData
- getClusterVersion() - Method in class org.elasticsearch.repositories.RepositoryStatsSnapshot
- getCodebaseJarMap(Set<URL>) - Static method in class org.elasticsearch.bootstrap.PolicyUtil
-
Return a map from codebase name to codebase url of jar codebases used by ES core.
- getCodec() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the
Codec
used in the enginesIndexWriter
- getCollapseField() - Method in class org.elasticsearch.search.SearchHits
-
In case field collapsing was performed, returns the field used for field collapsing, null otherwise
- getCollapseValues() - Method in class org.elasticsearch.search.SearchHits
-
In case field collapsing was performed, returns the values of the field that field collapsing was performed on, null otherwise
- getCollectionCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
- getCollectionTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
- getCollector() - Method in class org.elasticsearch.search.profile.query.QueryProfiler
-
Return the current root Collector for this search
- getCollectorResult() - Method in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- getCollectors() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
- getCollectorTree() - Method in class org.elasticsearch.search.profile.query.InternalProfileCollector
- getColumnNumber() - Method in exception org.elasticsearch.common.ParsingException
-
Column number of the location of the error
- getColumnNumber() - Method in exception org.elasticsearch.search.SearchParseException
-
Column number of the location of the error
- getCombineFunction() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- getCommands() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Returns the allocation commands to execute
- getCommitId() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getCommitLuceneVersion() - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshot
- getCommitStats() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- getCommitted() - Method in class org.elasticsearch.discovery.zen.PendingClusterStateStats
- getCommitTimeout() - Method in class org.elasticsearch.discovery.DiscoverySettings
- getCommitUserData() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
- getCommitVersion() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
- getCommitVersion() - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshot
- getComparator(int, int) - Method in class org.elasticsearch.search.sort.ShardDocSortField
- getComparator(SortOrder) - Static method in class org.elasticsearch.search.sort.MinAndMax
- getCompatibilityRole(Version) - Method in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
When serializing a
DiscoveryNodeRole
, the role may not be available to nodes of previous versions, where the role had not yet been added. - getCompatibleClusterStateDiffReceivedCount() - Method in class org.elasticsearch.discovery.zen.PublishClusterStateStats
- getCompilationLimitTriggered() - Method in class org.elasticsearch.script.ScriptContextStats
- getCompilationLimitTriggered() - Method in class org.elasticsearch.script.ScriptStats
- getCompilations() - Method in class org.elasticsearch.script.ScriptContextStats
- getCompilations() - Method in class org.elasticsearch.script.ScriptStats
- getCompilationsHistory() - Method in class org.elasticsearch.script.ScriptContextStats
- getCompleted() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- getCompletion() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getCompletion() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getCompletion() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getComponents() - Method in interface org.elasticsearch.index.analysis.AnalyzerComponentsProvider
- getComponents() - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- getComponents() - Method in class org.elasticsearch.index.analysis.ReloadableCustomAnalyzer
- GetComponentTemplateAction - Class in org.elasticsearch.action.admin.indices.template.get
-
Action to retrieve one or more component templates
- GetComponentTemplateAction.Request - Class in org.elasticsearch.action.admin.indices.template.get
-
Request that to retrieve one or more component templates
- GetComponentTemplateAction.Response - Class in org.elasticsearch.action.admin.indices.template.get
- getComponentTemplates() - Method in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Response
- getComponentTemplates() - Method in class org.elasticsearch.indices.SystemDataStreamDescriptor
- getComposableIndexTemplate() - Method in class org.elasticsearch.indices.SystemDataStreamDescriptor
- GetComposableIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.get
- GetComposableIndexTemplateAction.Request - Class in org.elasticsearch.action.admin.indices.template.get
-
Request that to retrieve one or more index templates
- GetComposableIndexTemplateAction.Response - Class in org.elasticsearch.action.admin.indices.template.get
- getComposableTemplates() - Method in class org.elasticsearch.cluster.metadata.ItemUsage
- getCompoundProcessor() - Method in class org.elasticsearch.ingest.Pipeline
-
Get the underlying
CompoundProcessor
containing the Pipeline's processors - getCompression() - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.TDigest
- getCompressionEnabled() - Method in class org.elasticsearch.transport.ConnectionProfile
-
Returns the compression enabled configuration or
null
if no explicit compression configuration is set on this profile. - getCompressionLevel() - Method in class org.elasticsearch.http.HttpHandlingSettings
- getCompressionScheme() - Method in class org.elasticsearch.transport.ConnectionProfile
-
Returns the configured compression scheme or
null
if no explicit compression scheme is set on this profile. - getCompressionScheme() - Method in class org.elasticsearch.transport.Header
- getComputationTimeMillis() - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- getComputedStats() - Method in class org.elasticsearch.node.AdaptiveSelectionStats
-
Returns a map of node id to the computed stats
- getConcreteAllClosedIndices() - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Returns all of the concrete indices that are closed.
- getConcreteAllIndices() - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Returns all the concrete indices.
- getConcreteAllOpenIndices() - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Returns all of the concrete indices that are open.
- getConcreteIndex() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
Returns a concrete index for this mapping or
null
if no concrete index is defined - getConcreteSetting(String) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
- getConcreteSetting(String) - Method in class org.elasticsearch.common.settings.Setting
- getConcreteSettingForNamespace(String) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
-
Get a setting with the given namespace filled in for prefix and suffix.
- getConcreteVisibleClosedIndices() - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Returns all of the concrete indices that are closed and not hidden.
- getConcreteVisibleIndices() - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Returns all the concrete indices that are not hidden.
- getConcreteVisibleOpenIndices() - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Returns all of the concrete indices that are open and not hidden.
- getCondition() - Method in class org.elasticsearch.ingest.ConditionalProcessor
- getConditionalWithResult() - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- getConditions() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- getConditionStatus() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
-
Returns the statuses of all the request conditions
- getConfig() - Method in class org.elasticsearch.index.translog.Translog
- getConfigAsMap() - Method in class org.elasticsearch.ingest.PipelineConfiguration
- getConfiguredDelayInMillis() - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Gets the total configured delay for allocating the replica shard when a node holding the replica left the cluster and the deciders are waiting to see if the node returns before allocating the replica elsewhere.
- getConfiguredInitialHeapSize() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getConfiguredMaxHeapSize() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getConnection(String) - Method in class org.elasticsearch.transport.RemoteClusterService
- getConnection(String, DiscoveryNode) - Method in class org.elasticsearch.action.search.SearchTransportService
-
Returns a connection to the given node on the provided cluster.
- getConnection(DiscoveryNode) - Method in class org.elasticsearch.transport.ClusterConnectionManager
-
Returns a connection for the given node if the node is connected.
- getConnection(DiscoveryNode) - Method in interface org.elasticsearch.transport.ConnectionManager
- getConnection(DiscoveryNode) - Method in class org.elasticsearch.transport.RemoteConnectionManager
- getConnection(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService
-
Returns either a real transport connection or a local node connection if we are using the local node optimization.
- getConnection(DiscoveryNode, String) - Method in class org.elasticsearch.transport.RemoteClusterService
-
Returns a connection to the given node on the given remote cluster
- getConnectionManager() - Method in class org.elasticsearch.transport.TransportService
- getConnectionProfile() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.PingingRound
- getConnectionProfile() - Method in class org.elasticsearch.transport.ClusterConnectionManager
- getConnectionProfile() - Method in interface org.elasticsearch.transport.ConnectionManager
- getConnectionProfile() - Method in class org.elasticsearch.transport.RemoteConnectionManager
- getConnectTimeout() - Method in class org.elasticsearch.index.reindex.RemoteInfo
-
Time to wait to connect to the external cluster.
- getConnectTimeout() - Method in class org.elasticsearch.transport.ConnectionProfile
-
Returns the connect timeout or
null
if no explicit timeout is set on this profile. - getConsistentSettings() - Method in class org.elasticsearch.common.settings.SettingsModule
- getConstructionContext(Object) - Method in class org.elasticsearch.common.inject.internal.InternalContext
- getConstructor() - Method in interface org.elasticsearch.common.inject.spi.ConstructorBinding
-
Gets the constructor this binding injects.
- getContentFormat() - Method in class org.elasticsearch.common.logging.ESJsonLayout
- getContentLength() - Method in class org.elasticsearch.transport.InboundMessage
- getContentType() - Method in class org.elasticsearch.action.index.IndexRequest
-
The content type.
- getContext() - Method in class org.elasticsearch.action.search.ParsedScrollId
- getContext() - Method in class org.elasticsearch.script.ScriptContextStats
- getContextId() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- getContextId() - Method in class org.elasticsearch.search.SearchPhaseResult
-
Returns the search context ID that is used to reference the search context on the executing node or
null
if no context was created. - getContextInfos() - Method in class org.elasticsearch.script.ScriptService
- getContextMappings() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- getContexts() - Method in interface org.elasticsearch.plugins.ScriptPlugin
-
Return script contexts this plugin wants to allow using.
- getContexts() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- getContexts(Setting.AffixSetting<?>, Settings, Set<String>) - Static method in class org.elasticsearch.script.ScriptService.ContextSettings
- getContextStats() - Method in class org.elasticsearch.script.ScriptCacheStats
-
Get the context specific stats, null if using general cache
- getContextStats() - Method in class org.elasticsearch.script.ScriptStats
- getCoordinatingOnlyNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get a
Map
of the coordinating only nodes (nodes which are neither master, nor data, nor ingest nodes) arranged by their ids - getCoordinatingRejections() - Method in class org.elasticsearch.index.stats.IndexingPressureStats
- getCoordinatorRewriteContext(Index) - Method in class org.elasticsearch.index.query.CoordinatorRewriteContextProvider
- getCoordinatorRewriteContextProvider(LongSupplier) - Method in class org.elasticsearch.indices.IndicesService
- getCoordinatorRewriteContextProvider(LongSupplier) - Method in class org.elasticsearch.search.SearchService
- getCopySettings() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- getCoreCacheHelper() - Method in class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazySoftDeletesFilterCodecReader
- getCoreCacheHelper() - Method in class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazySoftDeletesFilterLeafReader
- getCoreCacheHelper() - Method in class org.elasticsearch.common.lucene.index.ElasticsearchLeafReader
- getCoreKeysForIndex(String) - Method in class org.elasticsearch.common.lucene.ShardCoreKeyMap
-
Get the set of core cache keys associated with the given index.
- getCount() - Method in class org.elasticsearch.action.admin.cluster.stats.IndexFeatureStats
-
Return the number of times this feature is used across the cluster.
- getCount() - Method in class org.elasticsearch.common.util.CuckooFilter
-
Get the number of unique items that are being tracked
- getCount() - Method in class org.elasticsearch.index.engine.SegmentsStats.FileStats
- getCount() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
The number of segments.
- getCount() - Method in class org.elasticsearch.index.get.GetStats
- getCount() - Method in class org.elasticsearch.index.shard.DocsStats
- getCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
- getCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
- getCount() - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- getCount() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- getCount() - Method in interface org.elasticsearch.search.aggregations.metrics.Stats
- getCount() - Method in class org.elasticsearch.search.aggregations.MultiBucketConsumerService.MultiBucketConsumer
- getCount() - Method in class org.elasticsearch.search.profile.Timer
-
Return the number of times that
Timer.start()
has been called. - getCounts() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- getCounts() - Method in class org.elasticsearch.search.aggregations.metrics.InternalCardinality
- getCpu() - Method in class org.elasticsearch.monitor.os.OsStats
- getCpu() - Method in class org.elasticsearch.monitor.process.ProcessStats
- getCpuAcctControlGroup() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
-
The control group for the
cpuacct
subsystem. - getCpuAcctUsageNanos() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
-
The total CPU time consumed by all tasks in the
cpuacct
control group fromOsStats.Cgroup.cpuAcctControlGroup
. - getCpuCfsPeriodMicros() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
-
The period of time for how frequently the control group from
OsStats.Cgroup.cpuControlGroup
has its access to CPU resources reallocated. - getCpuCfsQuotaMicros() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
-
The total amount of time for which all tasks in the control group from
OsStats.Cgroup.cpuControlGroup
can run in one period as represented byOsStats.Cgroup.cpuCfsPeriodMicros
. - getCpuControlGroup() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
-
The control group for the
cpu
subsystem. - getCpuPercent() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
-
Cpu usage in percentages - 100 is 1 core.
- getCpuStat() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
-
The CPU time statistics.
- getCreated() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getCreated() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- getCreated() - Method in interface org.elasticsearch.index.reindex.SuccessfullyProcessed
-
Count of documents created.
- getCreated() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- getCreateIndexRequest() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Returns the inner
CreateIndexRequest
. - getCreationDate() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getCreationDateInNanos() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedRunnable
- getCreationDateMillis() - Method in class org.elasticsearch.action.admin.indices.dangling.DanglingIndexInfo
- getCreationVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Return the
Version
on which this index has been created. - getCtx() - Method in class org.elasticsearch.script.UpdateScript
-
Return the update context for this script.
- getCurrent() - Method in class org.elasticsearch.index.merge.MergeStats
-
The current number of merges executing.
- getCurrentCombinedCoordinatingAndPrimaryBytes() - Method in class org.elasticsearch.index.IndexingPressure
- getCurrentCombinedCoordinatingAndPrimaryBytes() - Method in class org.elasticsearch.index.stats.IndexingPressureStats
- getCurrentCoordinatingBytes() - Method in class org.elasticsearch.index.IndexingPressure
- getCurrentCoordinatingBytes() - Method in class org.elasticsearch.index.stats.IndexingPressureStats
- getCurrentFeature() - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskState
-
Gets the name of the feature which owns the index that's currently being migrated.
- getCurrentIndex() - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskState
-
Gets the name of the index that's currently being migrated.
- getCurrentNanoTime() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
returns the nano time captured at the beginning of the allocation.
- getCurrentNode() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Returns the node holding the replica shard to be explained.
- getCurrentNode() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
Returns the currently assigned node, or
null
if the shard is unassigned. - getCurrentNodeRanking() - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Gets the current ranking of the node to which the shard is currently assigned, relative to the other nodes in the cluster as reported in
NodeAllocationResult.getWeightRanking()
. - getCurrentNumDocs() - Method in class org.elasticsearch.index.merge.MergeStats
- getCurrentPrimaryBytes() - Method in class org.elasticsearch.index.IndexingPressure
- getCurrentPrimaryBytes() - Method in class org.elasticsearch.index.stats.IndexingPressureStats
- getCurrentQueryProfiler() - Method in class org.elasticsearch.search.profile.Profilers
-
Get the profiler for the query we are currently processing.
- getCurrentQueueSize() - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
-
Returns the current queue size (operations that are queued)
- getCurrentReference() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- getCurrentReplicaBytes() - Method in class org.elasticsearch.index.IndexingPressure
- getCurrentReplicaBytes() - Method in class org.elasticsearch.index.stats.IndexingPressureStats
- getCurrentSize() - Method in class org.elasticsearch.index.merge.MergeStats
- getCurrentSizeInBytes() - Method in class org.elasticsearch.index.merge.MergeStats
- getCurrentTerm() - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- getCurrentTerm() - Method in interface org.elasticsearch.cluster.coordination.CoordinationState.PersistedState
-
Returns the current term
- getCurrentTerm() - Method in class org.elasticsearch.cluster.coordination.InMemoryPersistedState
- getCurrentTerm() - Method in class org.elasticsearch.cluster.coordination.PreVoteRequest
- getCurrentTerm() - Method in class org.elasticsearch.cluster.coordination.PreVoteResponse
- getCurrentTerm() - Method in class org.elasticsearch.cluster.metadata.Manifest
- getCurrentTerm() - Method in class org.elasticsearch.discovery.PeerFinder
- getCustom(String) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- getCustomData(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getCustomDataPath() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeRequest
-
Returns the custom data path that is used to look up information for this shard.
- getCustomDataPath() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
-
Returns the custom data path that is used to look up information for this shard.
- getCustomDataPath() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodeRequest
-
Returns the custom data path that is used to look up information for this shard.
- getCustomDataPath() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.Request
-
Returns the custom data path that is used to look up information for this shard.
- getCustomNameResolver(Settings) - Method in interface org.elasticsearch.plugins.DiscoveryPlugin
-
Override to add additional
NetworkService.CustomNameResolver
s. - getCustoms() - Method in class org.elasticsearch.cluster.ClusterState
- getCustoms() - Method in class org.elasticsearch.cluster.metadata.Metadata
- getCustoms() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- getCutoffScore() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- getDanglingIndexInfo() - Method in class org.elasticsearch.action.admin.indices.dangling.find.NodeFindDanglingIndexResponse
- getDanglingIndices() - Method in class org.elasticsearch.action.admin.indices.dangling.list.NodeListDanglingIndicesResponse
- getDanglingIndices() - Method in class org.elasticsearch.gateway.DanglingIndicesState
-
Either return the current set of dangling indices, if auto-import is enabled, otherwise scan for dangling indices right away.
- getData() - Method in class org.elasticsearch.gateway.AsyncShardFetch.FetchResult
-
Returns the actual data, note, make sure to check
AsyncShardFetch.FetchResult.hasData()
first and only use this when there is an actual data. - getDataNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get a
Map
of the discovered data nodes arranged by their ids - getDataPath() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- getDataPath() - Method in class org.elasticsearch.index.shard.ShardPath
- getDataPath(ShardRouting) - Method in class org.elasticsearch.cluster.ClusterInfo
-
Returns the nodes absolute data-path the given shard is allocated on or
null
if the information is not available. - getDataPaths() - Method in class org.elasticsearch.env.NodeEnvironment.NodeLock
- getDataPaths() - Method in class org.elasticsearch.gateway.PersistedClusterStateService
- getDataStream() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedIndex
- getDataStream() - Method in class org.elasticsearch.cluster.metadata.DataStreamAction
- getDataStream() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- getDataStreamAliases() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesResponse
- getDataStreamAliases() - Method in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- getDataStreamDescriptors() - Method in class org.elasticsearch.indices.SystemIndices.Feature
- getDataStreamMappingSnippet() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- getDataStreamName() - Method in class org.elasticsearch.cluster.metadata.AliasAction.AddDataStreamAlias
- getDataStreamName() - Method in class org.elasticsearch.indices.SystemDataStreamDescriptor
- getDataStreams() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- getDataStreams() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Response
- getDataStreams() - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
-
Returns the data streams that are referenced
- getDataStreams() - Method in class org.elasticsearch.cluster.metadata.ItemUsage
- getDataStreamTemplate() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- getDateFormatter() - Method in class org.elasticsearch.index.mapper.MappingParserContext
-
Gets an optional default date format for date fields that do not have an explicit format set
- getDateMathParser() - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- getDateTimeUnit() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- getDateTransformers() - Method in class org.elasticsearch.common.xcontent.XContentElasticsearchExtension
- getDayOfMonth() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getDayOfWeek() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getDayOfWeekEnum() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getDayOfYear() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getDebugInfo() - Method in interface org.elasticsearch.search.fetch.FetchSubPhaseProcessor
-
Called when profiling after processing all documents to get any extra debug information the phase collected.
- getDebugInfo() - Method in class org.elasticsearch.search.profile.ProfileResult
-
The debug information about the profiled execution.
- getDebugMode() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- getDecayFunction() - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
-
Override this function if you want to produce your own scorer.
- getDecayFunction() - Method in class org.elasticsearch.index.query.functionscore.ExponentialDecayFunctionBuilder
- getDecayFunction() - Method in class org.elasticsearch.index.query.functionscore.GaussDecayFunctionBuilder
- getDecayFunction() - Method in class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
- getDecisions() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
-
Return the list of all decisions that make up this decision
- getDecisions() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- getDecisions() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- getDeclaredVersions(Class<?>) - Static method in class org.elasticsearch.Version
-
Extracts a sorted list of declared version constants from a class.
- getDeclaringClass() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
- getDecompressor(PageCacheRecycler, BytesReference) - Static method in interface org.elasticsearch.transport.TransportDecompressor
- getDefault(Settings) - Method in class org.elasticsearch.common.settings.SecureSetting
- getDefault(Settings) - Method in class org.elasticsearch.common.settings.Setting
-
Returns the default value for this setting.
- getDefault(MappingParserContext) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper.ConfigurableTypeParser
- getDefault(MappingParserContext) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper.FixedTypeParser
- getDefault(MappingParserContext) - Method in interface org.elasticsearch.index.mapper.MetadataFieldMapper.TypeParser
-
Get the default
MetadataFieldMapper
to use, if nothing had to be parsed. - getDefaultBackingIndexName(String, long) - Static method in class org.elasticsearch.cluster.metadata.DataStream
-
Generates the name of the index that conforms to the default naming convention for backing indices on data streams given the specified data stream name and generation and the current system time.
- getDefaultBackingIndexName(String, long, long) - Static method in class org.elasticsearch.cluster.metadata.DataStream
-
Generates the name of the index that conforms to the default naming convention for backing indices on data streams given the specified data stream name, generation, and time.
- getDefaultBackingIndexName(String, long, long, Version) - Static method in class org.elasticsearch.cluster.metadata.DataStream
- getDefaultBackingIndexName(String, long, Version) - Static method in class org.elasticsearch.cluster.metadata.DataStream
- getDefaultFields() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the default search fields for this index.
- getDefaultIndexAnalyzer() - Method in class org.elasticsearch.index.analysis.IndexAnalyzers
-
Returns the default index analyzer for this index
- getDefaultPipeline() - Method in class org.elasticsearch.index.IndexSettings
- getDefaultRaw(Settings) - Method in class org.elasticsearch.common.settings.SecureSetting
- getDefaultRaw(Settings) - Method in class org.elasticsearch.common.settings.Setting
-
Returns the default value string representation for this setting.
- getDefaultScoreCombiner() - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
- getDefaultSearchAnalyzer() - Method in class org.elasticsearch.index.analysis.IndexAnalyzers
-
Returns the default search analyzer for this index.
- getDefaultSearchQuoteAnalyzer() - Method in class org.elasticsearch.index.analysis.IndexAnalyzers
-
Returns the default search quote analyzer for this index
- getDefaultSeedAddresses() - Method in class org.elasticsearch.transport.TcpTransport
- getDefaultSeedAddresses() - Method in interface org.elasticsearch.transport.Transport
-
Returns a list of all local addresses for this transport
- getDefaultSeedAddresses() - Method in class org.elasticsearch.transport.TransportService
- getDefaultSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
-
Returns the default settings for the cluster (only if
include_defaults
was set to true in the request) - getDefaultSimilarity() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
The default similarity configured in the index settings.
- getDefaultSimilarity() - Method in class org.elasticsearch.index.similarity.SimilarityService
-
The default similarity configured in the index settings.
- getDefaultValue() - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Returns the default value of the parameter
- getDefaultValuesSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- getDefaultValuesSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- getDefaultValuesSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.composite.GeoTileGridValuesSourceBuilder
- getDefaultValuesSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- getDefaultValuesSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- getDelayedUnassignedShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
-
The number of unassigned shards that are currently being delayed (for example, due to node leaving the cluster and waiting for a timeout for the node to come back in order to allocate the shards back to it).
- getDelegate() - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
-
Returns the delegate members injector, or
null
if it has not yet been initialized. - getDelegate() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
-
Returns the delegate provider, or
null
if it has not yet been initialized. - getDelegate() - Method in class org.elasticsearch.index.shard.ElasticsearchMergePolicy
-
return the wrapped merge policy
- getDelegate() - Method in class org.elasticsearch.index.similarity.NonNegativeScoresSimilarity
- getDelegate() - Method in class org.elasticsearch.repositories.FilterRepository
- getDelegateRequest() - Method in class org.elasticsearch.http.HttpPipelinedRequest
- getDelegateRequest() - Method in class org.elasticsearch.http.HttpPipelinedResponse
- getDeleteCount() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
Returns the number of delete operation executed
- getDeleteCurrent() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
Returns the currently in-flight delete operations
- getDeleted() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getDeleted() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- getDeleted() - Method in interface org.elasticsearch.index.reindex.SuccessfullyProcessed
-
Count of successful delete operations.
- getDeleted() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- getDeleted() - Method in class org.elasticsearch.index.shard.DocsStats
- getDeleteDateInMillis() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Tombstone
-
The date in milliseconds that the index deletion event occurred, used for logging/debugging.
- getDeletedDocs() - Method in class org.elasticsearch.index.engine.Segment
- getDeletes() - Method in class org.elasticsearch.cluster.DiffableUtils.MapDiff
-
The keys that, when this diff is applied to a map, should be removed from the map.
- getDeletes() - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap.DiffableStringMapDiff
- getDeleteTime() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
The total amount of time spend on executing delete operations.
- getDeletionPolicy() - Method in class org.elasticsearch.index.translog.Translog
- getDependencies() - Method in class org.elasticsearch.common.inject.assistedinject.FactoryProvider
- getDependencies() - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- getDependencies() - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- getDependencies() - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- getDependencies() - Method in class org.elasticsearch.common.inject.internal.ProviderMethod
- getDependencies() - Method in class org.elasticsearch.common.inject.multibindings.MapBinder.RealMapBinder.MapBinderProviderWithDependencies
- getDependencies() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
- getDependencies() - Method in interface org.elasticsearch.common.inject.spi.ConvertedConstantBinding
-
Returns a singleton set containing only the converted key.
- getDependencies() - Method in interface org.elasticsearch.common.inject.spi.HasDependencies
-
Returns the known dependencies for this type.
- getDependencies() - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns the dependencies for this injection point.
- getDependencies() - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
-
Get the raw list of dependencies.
- getDependency() - Method in class org.elasticsearch.common.inject.internal.InternalContext
- getDeprecationLevel() - Method in class org.elasticsearch.rest.RestHandler.Route
- getDeprecationMessage() - Method in class org.elasticsearch.rest.RestHandler.Route
- getDescription() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
- getDescription() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- getDescription() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse.SnapshottableFeature
- getDescription() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- getDescription() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotRequest
- getDescription() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- getDescription() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
- getDescription() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- getDescription() - Method in class org.elasticsearch.action.admin.indices.diskusage.AnalyzeIndexDiskUsageRequest
- getDescription() - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
- getDescription() - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageShardRequest
- getDescription() - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsRequest
- getDescription() - Method in class org.elasticsearch.action.bulk.BulkRequest
- getDescription() - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- getDescription() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- getDescription() - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- getDescription() - Method in class org.elasticsearch.action.search.CanMatchNodeRequest
- getDescription() - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- getDescription() - Method in class org.elasticsearch.action.search.SearchScrollRequest
- getDescription() - Method in class org.elasticsearch.action.search.SearchTask
- getDescription() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- getDescription() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- getDescription() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- getDescription() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncRequest
- getDescription() - Method in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- getDescription() - Method in class org.elasticsearch.indices.AssociatedIndexDescriptor
- getDescription() - Method in class org.elasticsearch.indices.SystemDataStreamDescriptor
- getDescription() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getDescription() - Method in class org.elasticsearch.indices.SystemIndices.Feature
- getDescription() - Method in class org.elasticsearch.ingest.AbstractProcessor
- getDescription() - Method in class org.elasticsearch.ingest.CompoundProcessor
- getDescription() - Method in class org.elasticsearch.ingest.Pipeline
-
An optional description of what this pipeline is doing to the data gets processed by this pipeline.
- getDescription() - Method in interface org.elasticsearch.ingest.Processor
-
Gets the description of a processor.
- getDescription() - Method in class org.elasticsearch.ingest.TrackingResultProcessor
- getDescription() - Method in class org.elasticsearch.plugins.PluginDescriptor
-
The description of the plugin.
- getDescription() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
Returns a human readable description of this values source, for use in error messages and similar.
- getDescription() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- getDescription() - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
- getDescription() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- getDescription() - Method in class org.elasticsearch.search.query.QuerySearchRequest
- getDescription() - Method in class org.elasticsearch.tasks.Task
-
Generates task description
- getDescription() - Method in interface org.elasticsearch.tasks.TaskAwareRequest
-
Returns optional description of the request to be displayed by the task manager
- getDescription() - Method in class org.elasticsearch.tasks.TaskInfo
- getDescription(PersistentTasksCustomMetadata.PersistentTask<Params>) - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
-
Returns task description that will be available via task manager
- getDescriptionFromElement(E) - Method in class org.elasticsearch.search.profile.AbstractInternalProfileTree
- getDescriptionFromElement(Aggregator) - Method in class org.elasticsearch.search.profile.aggregation.InternalAggregationProfileTree
- getDescriptions() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
-
Description patters on which to match.
- getDescriptorCompatibleWith(Version) - Method in class org.elasticsearch.indices.SystemIndexDescriptor
-
Finds the descriptor that can be used within this cluster, by comparing the supplied minimum node version to this descriptor's minimum version and the prior descriptors minimum version.
- getDestination() - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Gets the target for this reindex request in the for of an
IndexRequest
- getDetailed() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
-
Should the detailed task information be returned.
- getDetailedErrorsEnabled() - Method in class org.elasticsearch.http.HttpHandlingSettings
- getDetailedMessage() - Method in exception org.elasticsearch.ElasticsearchException
-
Return the detail message, including the message from the nested exception if there is one.
- getDetails() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Builds a string representation of the message and the failure if exists.
- getDevicesStats() - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- getDictionary(String) - Method in class org.elasticsearch.indices.analysis.HunspellService
-
Returns the hunspell dictionary for the given locale.
- getDiffCount() - Method in class org.elasticsearch.cluster.coordination.ClusterStateSerializationStats
- getDiffs() - Method in class org.elasticsearch.cluster.DiffableUtils.MapDiff
-
Map entries that, when this diff is applied to a map, should be incrementally updated.
- getDiffs() - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap.DiffableStringMapDiff
- getDimensionalType() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Geometry
-
Returns the dimensional type of this geometry
- getDimensionalType() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getDirectMemoryMax() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- getDirectory() - Method in class org.elasticsearch.common.lucene.FilterIndexCommit
- getDirectoryFactories() - Method in interface org.elasticsearch.plugins.IndexStorePlugin
-
The
IndexStorePlugin.DirectoryFactory
mappings for this plugin. - getDirectoryReader() - Method in class org.elasticsearch.index.engine.Engine.Searcher
- getDirectoryReader() - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- getDiscount() - Method in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- getDiscovery() - Method in class org.elasticsearch.discovery.DiscoveryModule
- getDiscoveryNode() - Method in class org.elasticsearch.action.admin.cluster.node.liveness.LivenessResponse
- getDiscoveryNode() - Method in class org.elasticsearch.discovery.ProbeConnectionResult
- getDiscoveryNode() - Method in class org.elasticsearch.transport.TransportService.HandshakeResponse
- getDiscoverySettings() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- getDiscoveryStats() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getDisplayName() - Method in enum class org.elasticsearch.cluster.metadata.IndexAbstraction.Type
- getDistancePerDegree() - Method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Measures a longitude in this unit
- getDistanceString(LeafReaderContext, int) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- getDoc() - Method in class org.elasticsearch.script.DocBasedScript
-
The doc lookup for the Lucene segment this script was created for.
- getDoc() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- getDoc() - Method in class org.elasticsearch.script.TermsSetQueryScript
-
The doc lookup for the Lucene segment this script was created for.
- getDoc() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- getDocCount() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Field
-
Return the number of documents that have a value for this field.
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite.InternalBucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- getDocCount() - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.ParsedSingleBucketAggregation
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getDocCount() - Method in interface org.elasticsearch.search.aggregations.bucket.SingleBucketAggregation
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- getDocCount() - Method in class org.elasticsearch.search.aggregations.DelayedBucket
-
Count the documents in the buckets.
- getDocCount() - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- getDocCount(int) - Method in class org.elasticsearch.search.aggregations.bucket.DocCountProvider
- getDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms.AbstractTermsBucket
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms.ParsedBucket
- getDocCountError() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.Terms.Bucket
- getDocCountError() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.Terms
-
Get an upper bound of the error on document counts in this aggregation.
- getDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- getDocCountOfCommit(IndexCommit) - Method in class org.elasticsearch.index.engine.CombinedDeletionPolicy
- getDocCounts() - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
- getDocFreq() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Term
-
Return the number of documents that contain this term in the index.
- getDocs() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getDocs() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getDocs() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getDocTypes() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Deprecated.Types are in the process of being removed. Instead of using a type, prefer to filter on a field of the document.
- getDocTypes() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Deprecated.Types are in the process of being removed. Instead of using a type, prefer to filter on a field of the document.
- getDocumentFields() - Method in class org.elasticsearch.index.get.GetResult
- getDocumentFields() - Method in class org.elasticsearch.search.SearchHit
- getDocValueFields() - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Gets the docvalue fields.
- getDocValues() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- getDocValuesBytes() - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats.PerFieldDiskUsage
- getDocValuesFormatForField(String) - Method in class org.elasticsearch.index.codec.PerFieldMappingPostingFormatCodec
- getDocValuesMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the doc values memory usage by a segment.
- getDoneShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
-
Number of shards with completed snapshot
- getDoubleValues() - Method in class org.elasticsearch.index.fielddata.DoubleScriptFieldData.DoubleScriptLeafFieldData
- getDoubleValues() - Method in interface org.elasticsearch.index.fielddata.LeafNumericFieldData
-
Return a floating-point view of the values in this segment.
- getDoubleValues() - Method in class org.elasticsearch.index.fielddata.plain.LeafLongFieldData
- getDurability() - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
- getDurability() - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
- getDurability() - Method in exception org.elasticsearch.common.breaker.CircuitBreakingException
- getDurability() - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- getDurability() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
- getDynamicMappers() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Get dynamic mappers created while parsing.
- getDynamicRuntimeFields() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Get dynamic runtime fields created while parsing.
- getDynamicTemplates() - Method in class org.elasticsearch.action.index.IndexRequest
-
Returns a map from the full path of field names to the name of dynamic mapping templates.
- getEagerGlobalOrdinalsFields() - Method in class org.elasticsearch.index.mapper.MapperService
-
Returns all mapped field types.
- getEarliestLastModifiedAge() - Method in class org.elasticsearch.index.translog.TranslogStats
- getEarthCircumference() - Method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Measures the circumference of earth in this unit
- getEarthRadius() - Method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Measures the radius of earth in this unit
- getEditDistance() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
-
Returns the maximum number of edits
- getEffectiveMax(DoubleBounds) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DoubleBounds
-
returns bounds max if it is defined or NEGATIVE_INFINITY otherwise
- getEffectiveMin(DoubleBounds) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DoubleBounds
-
returns bounds min if it is defined or POSITIVE_INFINITY otherwise
- getElasticsearchDirectoryReader(DirectoryReader) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
-
Tries to unwrap the given reader until the first
ElasticsearchDirectoryReader
instance is found ornull
if no instance is found. - getElasticsearchException() - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse
- getElasticsearchLeafReader(LeafReader) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchLeafReader
- getElasticsearchVersion() - Method in class org.elasticsearch.plugins.PluginDescriptor
-
The version of Elasticsearch the plugin was built for.
- getElectionStrategies() - Method in interface org.elasticsearch.plugins.DiscoveryPlugin
-
Allows plugging in election strategies (see
ElectionStrategy
) that define a customized notion of an election quorum. - getElements() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- getElements() - Method in interface org.elasticsearch.common.inject.spi.PrivateElements
-
Returns the configuration information in this private environment.
- getElements(Iterable<? extends Module>) - Static method in class org.elasticsearch.common.inject.spi.Elements
-
Records the elements executed by
modules
. - getElements(Module...) - Static method in class org.elasticsearch.common.inject.spi.Elements
-
Records the elements executed by
modules
. - getElements(Stage, Iterable<? extends Module>) - Static method in class org.elasticsearch.common.inject.spi.Elements
-
Records the elements executed by
modules
. - getElementsMutable() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- getEmpty() - Method in interface org.elasticsearch.search.aggregations.support.ValuesSourceType
-
Called when an aggregation is operating over a known empty set (usually because the field isn't specified), this method allows for returning a no-op implementation.
- getEmptyBucketInfo() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- getEnabledRemoteClusters(Settings) - Static method in class org.elasticsearch.transport.RemoteClusterAware
-
Returns remote clusters that are enabled in these settings
- getEncodedId() - Method in class org.elasticsearch.search.builder.PointInTimeBuilder
-
Returns the encoded id of this point in time
- getEncodedX(int) - Method in class org.apache.lucene.geo.XTessellator.Triangle
-
get quantized x value for the given vertex
- getEncodedY(int) - Method in class org.apache.lucene.geo.XTessellator.Triangle
-
get quantized y value for the given vertex
- getEnd() - Method in class org.elasticsearch.index.query.IntervalFilterScript.Interval
- getEndOffset() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeToken
- getEndTimeMillis() - Method in class org.elasticsearch.repositories.RepositoryData.SnapshotDetails
- getEngineConfig() - Method in class org.elasticsearch.index.engine.Engine
- getEngineFactory() - Method in class org.elasticsearch.index.IndexService
- getEngineFactory(IndexSettings) - Method in interface org.elasticsearch.plugins.EnginePlugin
-
When an index is created this method is invoked for each engine plugin.
- getEngineOrNull() - Method in class org.elasticsearch.index.shard.IndexShard
-
NOTE: returns null if engine is not yet started (e.g.
- getEntries() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
-
Returns an unmodifiable list of snapshot deletion entries.
- getEntries() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- getEnvironment() - Method in class org.elasticsearch.node.Node
-
Returns the environment of the node
- getEphemeralId() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
The unique ephemeral id of the node.
- getEqualityPredicate() - Method in class org.elasticsearch.cluster.ClusterName
- getEra() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getError() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- getError() - Method in class org.elasticsearch.tasks.TaskResult
-
Get the error that finished this task.
- getErrorAsMap() - Method in class org.elasticsearch.tasks.TaskResult
-
Convert
TaskResult.getError()
from XContent to a Map for easy processing. - getErrorMessages() - Method in exception org.elasticsearch.common.inject.ConfigurationException
-
Returns messages for the errors that caused this exception.
- getErrorMessages() - Method in exception org.elasticsearch.common.inject.CreationException
-
Returns messages for the errors that caused this exception.
- getErrorMessages() - Method in exception org.elasticsearch.common.inject.ProvisionException
-
Returns messages for the errors that caused this exception.
- getErrors() - Method in exception org.elasticsearch.common.inject.internal.ErrorsException
- getErrorWriter() - Method in class org.elasticsearch.bootstrap.plugins.LoggerTerminal
- getESMessageFields() - Method in class org.elasticsearch.common.logging.ESJsonLayout.Builder
- getESReaderCacheHelper(DirectoryReader) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
-
Retrieves Elasticsearch's version of the reader cache helper (see
ESCacheHelper
) - getEstimated() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- getEstimatedMemoryFootprint() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- getEstimatedMemoryFootprint() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- getEstimatedSizeInBytes() - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
- getEventListener() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns a listener that should be called on engine failure
- getEvictions() - Method in class org.elasticsearch.common.cache.Cache.CacheStats
- getEvictions() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
The number of
DocIdSet
s that have been evicted from the cache. - getEvictions() - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- getEvictions() - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- getException() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.IndexInfo
- getException() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus
- getException() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.IndexResult
- getException() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockResult
- getException() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesFailure
- getException() - Method in class org.elasticsearch.action.search.CanMatchNodeResponse.ResponseOrFailure
- getException() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- getException() - Method in class org.elasticsearch.transport.InboundMessage
- getException() - Method in class org.elasticsearch.upgrades.SingleFeatureMigrationResult
-
Gets the exception that cause the migration failure, if the migration failed.
- getExceptionName() - Method in exception org.elasticsearch.common.io.stream.NotSerializableExceptionWrapper
- getExceptionName() - Method in exception org.elasticsearch.ElasticsearchException
- getExceptionName(Throwable) - Static method in exception org.elasticsearch.ElasticsearchException
-
Returns a underscore case name for the given exception.
- getExceptionTypes(Member) - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the resolved generic exception types thrown by
constructor
. - getExecutor() - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
- getExecutor() - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- getExecutor(ExplainRequest, ShardId) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- getExecutor(GetRequest, ShardId) - Method in class org.elasticsearch.action.get.TransportGetAction
- getExecutor(MultiGetShardRequest, ShardId) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- getExecutor(MultiTermVectorsShardRequest, ShardId) - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- getExecutor(TermVectorsRequest, ShardId) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- getExecutor(Request, ShardId) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- getExecutorBuilders(Settings) - Method in class org.elasticsearch.plugins.Plugin
-
Provides the list of this plugin's custom thread pools, empty if none.
- getExecutorBuilders(Settings) - Method in class org.elasticsearch.plugins.PluginsService
- getExecutorNode() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Assignment
- getExecutorNode() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- getExecutorSelector() - Method in class org.elasticsearch.indices.SystemIndices
-
Used to determine which executor should be used for operations on this index.
- getExistingShardsAllocators() - Method in interface org.elasticsearch.plugins.ClusterPlugin
-
Return
ExistingShardsAllocator
implementations added by this plugin; the index settingExistingShardsAllocator.EXISTING_SHARDS_ALLOCATOR_SETTING
sets the key of the allocator to use to allocate its shards. - getExistingSize() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- getExistsCount() - Method in class org.elasticsearch.index.get.GetStats
- getExistsTime() - Method in class org.elasticsearch.index.get.GetStats
- getExistsTimeInMillis() - Method in class org.elasticsearch.index.get.GetStats
- getExpandWildcards() - Method in class org.elasticsearch.action.support.IndicesOptions
- getExpectedResponseCount() - Method in class org.elasticsearch.action.support.NodeResponseTracker
- getExpectedShardSize() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns the expected shard size for
ShardRoutingState.RELOCATING
andShardRoutingState.INITIALIZING
shards. - getExpectedShardSize(ShardRouting, long, ClusterInfo, SnapshotShardSizeInfo, Metadata, RoutingTable) - Static method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
Returns the expected shard size for the given shard or the default value provided if not enough information are available to estimate the shards size.
- getExpectedShardSize(ShardRouting, RoutingAllocation) - Method in class org.elasticsearch.gateway.BaseGatewayShardAllocator
- getExplanation() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainResponse
-
Return the explanation for shard allocation in the cluster
- getExplanation() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- getExplanation() - Method in class org.elasticsearch.action.explain.ExplainResponse
- getExplanation() - Method in class org.elasticsearch.cluster.metadata.ShutdownShardMigrationStatus
- getExplanation() - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Gets the explanation for the decision.
- getExplanation() - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- getExplanation() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
-
Get the explanation for this decision.
- getExplanation() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- getExplanation() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
-
Returns the explanation string, fully formatted.
- getExplanation() - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
- getExplanation() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Assignment
- getExplanation() - Method in class org.elasticsearch.search.SearchHit
-
If enabled, the explanation of the search hit.
- getExplanations() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteResponse
- getExposedKeys() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- getExposedKeys() - Method in interface org.elasticsearch.common.inject.spi.PrivateElements
-
Returns the unique exposed keys for these private elements.
- getExposedSource(Key<?>) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- getExposedSource(Key<?>) - Method in interface org.elasticsearch.common.inject.spi.PrivateElements
-
Returns an arbitrary object containing information about the "place" where this key was exposed.
- getExt() - Method in class org.elasticsearch.index.engine.SegmentsStats.FileStats
- getExtendedPlugins() - Method in class org.elasticsearch.plugins.PluginDescriptor
-
Other plugins this plugin extends through SPI.
- getExtension() - Method in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- getExternalRefreshListener() - Method in class org.elasticsearch.index.engine.EngineConfig
-
The refresh listeners to add to Lucene for externally visible refreshes
- getExternalTotal() - Method in class org.elasticsearch.index.refresh.RefreshStats
- getExternalTotalTime() - Method in class org.elasticsearch.index.refresh.RefreshStats
-
The total time external refreshes have been executed.
- getExternalTotalTimeInMillis() - Method in class org.elasticsearch.index.refresh.RefreshStats
-
The total time spent executing external refreshes (in milliseconds).
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Bucket
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getFactory() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- getFailed() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- getFailedCommitElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getFailedCompletionElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getFailedComputationElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getFailedContextConstructionElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getFailedDeleteResult(Exception, long) - Method in class org.elasticsearch.index.shard.IndexShard
- getFailedIndexName() - Method in class org.elasticsearch.upgrades.SingleFeatureMigrationResult
-
Gets the name of the specific index where the migration failure occurred, if the migration failed.
- getFailedIndexResult(Exception, long) - Method in class org.elasticsearch.index.shard.IndexShard
- getFailedIndices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
-
Get the concrete list of indices that failed
- getFailedMasterApplyElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getFailedNodeIds() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
A set of nodeIds that failed to complete allocations for this shard.
- getFailedNodes() - Method in class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
returns a set of nodes for which publication has failed.
- getFailedNotificationElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getFailedPublicationElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getFailedShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
-
Number of shards with failed snapshot
- getFailedShards() - Method in class org.elasticsearch.action.search.SearchResponse
-
The failed number of shards the search was executed on.
- getFailedShards() - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
The failed shards this request was executed on.
- getFailure() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
-
Returns reason for snapshot failure
- getFailure() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The actual failure object if there was a failure.
- getFailure() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
-
The failure if relevant.
- getFailure() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
- getFailure() - Method in class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- getFailure() - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- getFailure() - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
- getFailure() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
-
The failure if relevant.
- getFailure() - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.TaskResult
- getFailure() - Method in class org.elasticsearch.cluster.routing.allocation.FailedShard
-
The exception, if present, causing the shard to fail.
- getFailure() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Returns additional failure exception details if exists.
- getFailure() - Method in class org.elasticsearch.index.engine.Engine.Result
-
get document failure while executing the operation
null
in case of no failure - getFailure() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getFailure() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- getFailureForRepository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotResponse
- getFailureMessage() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The failure message,
null
if it did not fail. - getFailureMessage() - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
-
The actual failure message, null if its not a failure.
- getFailures() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
-
Returns a map of repository name to
ElasticsearchException
for each unsuccessful response. - getFailures() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult
- getFailures() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult
- getFailures() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
-
Returns node
IndicesShardStoresResponse.Failure
s encountered while executing the request - getFailures() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
-
Get possible request failures keyed by index name
- getFailures() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- getFailures() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.Response
-
Where there any search failures?
- getFallbackPlan() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- getFaultyNodes() - Method in class org.elasticsearch.cluster.coordination.FollowersChecker
- getFeature() - Method in class org.elasticsearch.plugins.Plugin
-
A feature exposed by the plugin.
- getFeature(String) - Method in class org.elasticsearch.indices.SystemIndices
-
Get a feature by name.
- getFeatureCallbackMetadata() - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskState
-
Retrieves metadata stored by the pre-upgrade hook, intended for consumption by the post-migration hook.
- getFeatureDescription() - Method in interface org.elasticsearch.plugins.SystemIndexPlugin
- getFeatureName() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.FeatureUpgradeStatus
- getFeatureName() - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse.Feature
- getFeatureName() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse.SnapshottableFeature
- getFeatureName() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus
- getFeatureName() - Method in interface org.elasticsearch.plugins.SystemIndexPlugin
- getFeatureNames() - Method in class org.elasticsearch.indices.SystemIndices
-
Get a set of feature names.
- getFeatures() - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse
- getFeatures() - Method in class org.elasticsearch.common.io.stream.StreamOutput
- getFeatures() - Method in class org.elasticsearch.indices.SystemIndices
-
Get a collection of the Features this SystemIndices object is managing.
- getFeatures() - Method in class org.elasticsearch.transport.Header
- getFeatureStateResetStatuses() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse
- getFeatureStatuses() - Method in class org.elasticsearch.upgrades.FeatureMigrationResults
-
Gets a map of feature name to that feature's status.
- GetFeatureUpgradeStatusAction - Class in org.elasticsearch.action.admin.cluster.migration
-
Action for getting a feature upgrade status.
- getFeatureUpgradeStatuses() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse
- GetFeatureUpgradeStatusRequest - Class in org.elasticsearch.action.admin.cluster.migration
-
Request for whether system features need to be upgraded
- GetFeatureUpgradeStatusRequest() - Constructor for class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusRequest
- GetFeatureUpgradeStatusRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusRequest
- GetFeatureUpgradeStatusResponse - Class in org.elasticsearch.action.admin.cluster.migration
-
A response showing whether system features need to be upgraded and, feature by feature, which indices need to be upgraded.
- GetFeatureUpgradeStatusResponse(List<GetFeatureUpgradeStatusResponse.FeatureUpgradeStatus>, GetFeatureUpgradeStatusResponse.UpgradeStatus) - Constructor for class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse
- GetFeatureUpgradeStatusResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse
- GetFeatureUpgradeStatusResponse.FeatureUpgradeStatus - Class in org.elasticsearch.action.admin.cluster.migration
-
A class for a particular feature, showing whether it needs to be upgraded and the earliest Elasticsearch version used to create one of this feature's system indices.
- GetFeatureUpgradeStatusResponse.IndexInfo - Class in org.elasticsearch.action.admin.cluster.migration
-
A data class that holds an index name and the version of Elasticsearch with which that index was created
- GetFeatureUpgradeStatusResponse.UpgradeStatus - Enum Class in org.elasticsearch.action.admin.cluster.migration
- getFetchCount() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getFetchCurrent() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getFetchFields() - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Gets the fields to load and return as part of the search request.
- getFetchPhase() - Method in class org.elasticsearch.search.profile.SearchProfileShardResult
- getFetchPhase() - Method in class org.elasticsearch.search.SearchModule
- getFetchSourceContext() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getFetchSubPhases(SearchPlugin.FetchPhaseConstructionContext) - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
FetchSubPhase
s defined by this plugin. - getFetchTime() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getFetchTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getField() - Method in class org.apache.lucene.queries.SpanMatchNoDocsQuery
- getField() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
- getField() - Method in enum class org.elasticsearch.common.Rounding.DateTimeUnit
- getField() - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
-
Get the field to use for random number generation.
- getField() - Method in class org.elasticsearch.index.query.IntervalQueryBuilder
- getField() - Method in class org.elasticsearch.search.collapse.CollapseBuilder
-
The name of the field to collapse against
- getField() - Method in class org.elasticsearch.search.SearchHit.NestedIdentity
-
Returns the nested field in the source this hit originates from
- getField() - Method in class org.elasticsearch.search.slice.SliceBuilder
-
The name of the field to slice against.
- getField() - Method in class org.elasticsearch.search.slice.SliceQuery
- getField() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- getField() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getField(String) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
-
Get the field capabilities per type for the provided
field
. - getField(String) - Method in class org.elasticsearch.action.get.GetResponse
- getField(String) - Method in class org.elasticsearch.index.mapper.LuceneDocument
- getField(String, LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSource.NumericMultiValuesSource
- getField(FieldContext, AggregationScript.LeafFactory, AggregationContext) - Method in interface org.elasticsearch.search.aggregations.support.ValuesSourceType
-
Return a
ValuesSource
wrapping a field for the given type. - getFieldData() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getFieldData() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getFieldData() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getFieldFilter() - Method in class org.elasticsearch.index.mapper.MapperRegistry
-
Returns a function that given an index name, returns a predicate that fields must match in order to be returned by get mappings, get index, get field mappings and field capabilities API.
- getFieldFilter() - Method in class org.elasticsearch.indices.IndicesService
-
Returns a function which given an index name, returns a predicate which fields must match in order to be returned by get mappings, get index, get field mappings and field capabilities API.
- getFieldFilter() - Method in interface org.elasticsearch.plugins.MapperPlugin
-
Returns a function that given an index name returns a predicate which fields must match in order to be returned by get mappings, get index, get field mappings and field capabilities API.
- getFieldHighlighter(String, Query, Set<Term>, int) - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
- getFieldMappings(GetFieldMappingsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the mappings of specific fields
- getFieldMappings(GetFieldMappingsRequest, ActionListener<GetFieldMappingsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the mappings of specific fields
- GetFieldMappingsAction - Class in org.elasticsearch.action.admin.indices.mapping.get
- GetFieldMappingsIndexRequest - Class in org.elasticsearch.action.admin.indices.mapping.get
- GetFieldMappingsRequest - Class in org.elasticsearch.action.admin.indices.mapping.get
-
Request the mappings of specific fields Note: there is a new class with the same name for the Java HLRC that uses a typeless format.
- GetFieldMappingsRequest() - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- GetFieldMappingsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- GetFieldMappingsRequestBuilder - Class in org.elasticsearch.action.admin.indices.mapping.get
-
A helper class to build
GetFieldMappingsRequest
objects - GetFieldMappingsRequestBuilder(ElasticsearchClient, GetFieldMappingsAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
- GetFieldMappingsResponse - Class in org.elasticsearch.action.admin.indices.mapping.get
-
Response object for
GetFieldMappingsRequest
API Note: there is a new class with the same name for the Java HLRC that uses a typeless format. - GetFieldMappingsResponse(Map<String, Map<String, Map<String, GetFieldMappingsResponse.FieldMappingMetadata>>>) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
- GetFieldMappingsResponse.FieldMappingMetadata - Class in org.elasticsearch.action.admin.indices.mapping.get
- getFieldName() - Method in class org.elasticsearch.index.fielddata.BinaryScriptFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.BooleanScriptFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.DateScriptFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.DoubleScriptFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.GeoPointScriptFieldData
- getFieldName() - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
-
The field name.
- getFieldName() - Method in class org.elasticsearch.index.fielddata.IndexHistogramFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.LongScriptFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData.Consumer
- getFieldName() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointIndexFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData
- getFieldName() - Method in class org.elasticsearch.index.fielddata.plain.StringBinaryIndexFieldData
- getFieldName() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldData
- getFieldName() - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- getFieldName() - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- getFieldName() - Method in enum class org.elasticsearch.ingest.IngestDocument.Metadata
- getFieldName() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- getFieldName() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- getFieldName() - Method in class org.elasticsearch.search.collapse.CollapseContext
-
The requested field name to collapse on.
- getFieldName() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Returns the document field this sort should be based on.
- getFieldName() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
-
Name of the field to get contexts from at index-time
- getFieldName() - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- getFieldNames() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the field names that will be used when generating the 'More Like This' query.
- getFieldNames() - Method in class org.elasticsearch.index.fieldvisitor.CustomFieldsVisitor
- getFieldNames() - Method in class org.elasticsearch.index.fieldvisitor.FieldNamesProvidingStoredFieldsVisitor
- getFieldNames() - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- getFieldNames() - Method in class org.elasticsearch.search.internal.FilterFieldNamesProvidingStoredFieldsVisitor
- getFieldQuery(String, String, boolean) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getFieldQuery(String, String, int) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getFields() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexResponse
-
Get the field capabilities
- getFields() - Method in class org.elasticsearch.action.get.GetResponse
- getFields() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- getFields() - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- getFields() - Method in class org.elasticsearch.index.get.GetResult
- getFields() - Method in class org.elasticsearch.index.mapper.LuceneDocument
- getFields() - Method in class org.elasticsearch.search.SearchHit
-
A map of hit fields (from field name to hit fields) if additional fields were required to be loaded.
- getFields() - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- getFields(String) - Method in class org.elasticsearch.index.mapper.LuceneDocument
- getFields(IndexReader, int, String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.SourceScoreOrderFragmentsBuilder
- getFields(IndexReader, int, String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.SourceSimpleFragmentsBuilder
- getFieldType() - Method in class org.elasticsearch.search.collapse.CollapseContext
-
The field type used for collapsing
- getFieldType(Field) - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the resolved generic type of
field
. - getFieldType(String) - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Returns the mapped field type for the given field name.
- getFieldType(String) - Method in class org.elasticsearch.index.query.CoordinatorRewriteContext
- getFieldType(String) - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Returns the
MappedFieldType
for the provided field name. - getFieldType(String) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Lookup a
MappedFieldType
by path. - getFieldType(String) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- getFieldTypeStats() - Method in class org.elasticsearch.action.admin.cluster.stats.MappingStats
-
Return stats about field types.
- getFieldValue(String, Class<T>) - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the value contained in the document for the provided path
- getFieldValue(String, Class<T>, boolean) - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the value contained in the document for the provided path
- getFieldValue(TemplateScript.Factory, Class<T>) - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the value contained in the document with the provided templated path
- getFieldValueAsBytes(String) - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the value contained in the document for the provided path as a byte array.
- getFieldValueAsBytes(String, boolean) - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the value contained in the document for the provided path as a byte array.
- getFile(String) - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
- getFile(String) - Method in interface org.elasticsearch.common.settings.SecureSettings
-
Return a file setting.
- getFileDetails(String) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- getFileInfo() - Method in class org.elasticsearch.indices.recovery.RecoverySnapshotFileRequest
- getFilename(long) - Static method in class org.elasticsearch.index.translog.Translog
-
package private for testing
- getFileNames() - Method in class org.elasticsearch.common.lucene.FilterIndexCommit
- getFilePointer() - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- getFilePointer() - Method in class org.elasticsearch.common.lucene.store.FilterIndexOutput
- getFiles() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getFilesPresentInTarget() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- getFilesPresentInTargetNames() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- getFilesPresentInTargetSizes() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- getFileStore(Path) - Static method in class org.elasticsearch.env.Environment
- getFilesToRecoverNames() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- getFilesToRecoverSizes() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- getFilter() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- getFilter() - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
- getFilter() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- getFilter() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- getFilter() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- getFilter() - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
-
Returns a filter function that expects the source map as an input and returns the filtered map.
- getFilter() - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- getFilteredFields() - Method in class org.elasticsearch.rest.action.admin.cluster.RestReloadSecureSettingsAction
- getFilteredFields() - Method in interface org.elasticsearch.rest.RestRequestFilter
-
The list of fields that should be filtered.
- getFilteredRequest(RestRequest) - Method in interface org.elasticsearch.rest.RestRequestFilter
-
Wraps the RestRequest and returns a version that provides the filtered content
- getFinalizingShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
-
Number of shards with the snapshot in the finalizing stage
- getFinalPipeline() - Method in class org.elasticsearch.action.index.IndexRequest
-
Returns the final ingest pipeline to be executed before indexing the document.
- getFirst() - Method in class org.apache.lucene.util.CombinedBitSet
- getFirstAliasMetadata(Metadata, IndexAbstraction) - Static method in class org.elasticsearch.cluster.metadata.AliasMetadata
- getFirstDayOfWeek(Locale) - Method in class org.elasticsearch.common.time.IsoCalendarDataProvider
- getFirstOperationOffset() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- getFirstOrdinals() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Return a
PackedInts.Reader
instance mapping every doc ID to its first ordinal + 1 if it exists and 0 otherwise. - getFixedInterval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Returns the interval as a fixed time unit if and only if it was configured as a fixed interval originally.
- getFlags() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- getFlags() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- getFlagsValue() - Method in class org.elasticsearch.search.suggest.completion.RegexOptions
-
Returns internal regular expression syntax flag value see
RegexpFlag.value()
- getFlush() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getFlush() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getFlushAfterMergeThresholdSize() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the merge threshold size when to forcefully flush the index and free resources.
- getFlushMergesAfter() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns a
TimeValue
at what time interval after the last write modification to the engine finished merges should be automatically flushed. - getFlushThresholdSize() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the transaction log threshold size when to forcefully flush the index and clear the transaction log.
- getForceMergeUUID() - Method in class org.elasticsearch.index.engine.InternalEngine
-
returns the force merge uuid for the engine
- getForField(MappedFieldType) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- getForField(MappedFieldType) - Method in class org.elasticsearch.search.lookup.SearchLookup
- getForField(MappedFieldType, String, Supplier<SearchLookup>) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
-
Returns fielddata for the provided field type, given the provided fully qualified index name, while also making a
SearchLookup
supplier available that is required for runtime fields. - getFormat() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getFormat() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- getFormat() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- getFormat() - Method in class org.elasticsearch.search.sort.BucketedSort
-
The format to use when presenting the values.
- getFormat() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Returns the external format that is specified via
FieldSortBuilder.setFormat(String)
- getFormattedSortValues() - Method in class org.elasticsearch.search.SearchSortValues
-
Returns the formatted version of the values that sorting was performed against
- getFormattedSortValues() - Method in class org.elasticsearch.search.SearchSortValuesAndFormats
- getFormattedValues(DocValueFormat) - Method in interface org.elasticsearch.index.fielddata.LeafFieldData
-
Return a formatted representation of the values
- getFormattedValues(DocValueFormat) - Method in class org.elasticsearch.index.fielddata.plain.LeafDoubleFieldData
- getFormattedValues(DocValueFormat) - Method in class org.elasticsearch.index.fielddata.plain.LeafLongFieldData
- getFormattedValues(DocValueFormat) - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData.NanoSecondFieldData
- getFormatter() - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
- getFormatter() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- getFormatter() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- getFormatter() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- getFormatter() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- getFormatter(String) - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
- getFormatter(String) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
-
Gets the formatter by name.
- getFormatter(String) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointFieldType
- getFormatter(String) - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper.GeoShapeFieldType
- getFormatter(String, ZoneId) - Method in interface org.elasticsearch.search.aggregations.support.ValuesSourceType
-
This method provides a hook for specifying a type-specific formatter.
- getFormatter(String, Function<T, Geometry>) - Method in class org.elasticsearch.common.geo.GeoFormatterFactory
-
Returns a formatter by name The format can contain an optional parameters in parentheses such as "mvt(1/2/3)".
- getFormatter(String, Function<T, Geometry>) - Static method in class org.elasticsearch.common.geo.GeometryFormatterFactory
-
Returns a formatter by name
- getFormatterBuilder() - Method in interface org.elasticsearch.common.geo.GeoFormatterFactory.FormatterFactory
-
Generates a formatter builder that parses the formatter configuration and generates a formatter
- getFormatterBuilder() - Method in class org.elasticsearch.common.geo.SimpleVectorTileFormatter
- getFormatVersion() - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Get the metadata format version for the keystore
- getForUpdate(String, String, long, long) - Method in class org.elasticsearch.index.get.ShardGetService
- getFoundPeers() - Method in class org.elasticsearch.cluster.coordination.Coordinator
- getFoundPeers() - Method in class org.elasticsearch.discovery.PeerFinder
- getFpp() - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
-
Returns the false-positive rate used for the cuckoo filters.
- getFragments() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
-
The highlighted fragments.
- getFree() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- getFree() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- getFree() - Method in class org.elasticsearch.monitor.os.OsStats.Swap
- getFreeBytes() - Method in class org.elasticsearch.cluster.DiskUsage
- getFreeBytesThresholdFloodStage() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFreeBytesThresholdFrozenFloodStage(ByteSizeValue) - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFreeBytesThresholdHigh() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFreeBytesThresholdLow() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFreeDiskAsPercentage() - Method in class org.elasticsearch.cluster.DiskUsage
- getFreeDiskThresholdFloodStage() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFreeDiskThresholdHigh() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFreeDiskThresholdLow() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getFreePercent() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- getFreePhysicalMemorySize() - Method in class org.elasticsearch.monitor.os.OsProbe
-
Returns the amount of free physical memory in bytes.
- getFreeSwapSpaceSize() - Method in class org.elasticsearch.monitor.os.OsProbe
-
Returns the amount of free swap space in bytes.
- getFreq() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Doc
-
Return the number of occurrences of the term in the current document for the considered field.
- getFreq() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- getFrom() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Range
- getFrom() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Bucket
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder.Range
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedDateRange.ParsedBucket
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- getFrom() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
- getFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- getFromAllRepositories() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotRequest
- getFromAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getFromAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getFromAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- getFromAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- getFromAsString() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
- getFromAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- getFromContext(String) - Method in class org.elasticsearch.search.internal.ReaderContext
-
Returns the object or
null
if the given key does not have a value in the context - getFromSearcher(Engine.Get, Engine.Searcher, boolean) - Method in class org.elasticsearch.index.engine.Engine
- getFs() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
File system level stats.
- getFs() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- getFSInfo(NodeEnvironment.DataPath) - Static method in class org.elasticsearch.monitor.fs.FsProbe
- getFullClusterStateReceivedCount() - Method in class org.elasticsearch.discovery.zen.PublishClusterStateStats
- getFullStateCount() - Method in class org.elasticsearch.cluster.coordination.ClusterStateSerializationStats
- getFullyQualifiedIndex() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Returns the fully qualified index including a remote cluster alias if applicable, and the index uuid
- getFullyQualifiedIndexName() - Method in class org.elasticsearch.search.SearchShardTarget
-
Returns the fully qualified index name, including the index prefix that indicates which cluster results come from.
- getFunctionBytes() - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- getFunctions() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- getFuzzyMinLength() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
-
Returns the length of input prefix after which edits are applied
- getFuzzyOptions() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
- getFuzzyPrefixLength() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
-
Returns the minimum length of the input prefix required to apply any edits
- getFuzzyQuery(String, String, float) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getG1RegionSize() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getGaps() - Method in class org.elasticsearch.index.query.IntervalFilterScript.Interval
- getGb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getGbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getGc() - Method in class org.elasticsearch.monitor.jvm.JvmStats
- getGcCollectors() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getGcDeletesInMillis() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the GC deletes cycle in milliseconds.
- getGeneralStats() - Method in class org.elasticsearch.script.ScriptCacheStats
-
Get the general stats, null if using context cache
- getGeneration() - Method in class org.elasticsearch.cluster.metadata.DataStream
- getGeneration() - Method in class org.elasticsearch.common.lucene.FilterIndexCommit
- getGeneration() - Method in class org.elasticsearch.index.engine.CommitStats
- getGeneration() - Method in class org.elasticsearch.index.engine.Segment
- getGeneration() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- getGeneration() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the current generation of this translog.
- getGeneration() - Method in class org.elasticsearch.repositories.ShardSnapshotResult
- getGenerationThresholdSize() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the generation threshold size.
- getGenericComponentType() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
- getGenericSupertype(Type, Class<?>, Class<?>) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
Returns the generic supertype for
supertype
. - getGenId() - Method in class org.elasticsearch.repositories.RepositoryData
-
Gets the generational index file id from which this instance was read.
- getGens(IndexId) - Method in class org.elasticsearch.repositories.ShardGenerations
- getGeohash() - Method in class org.elasticsearch.common.geo.GeoPoint
- getGeoJsonName(Geometry) - Static method in class org.elasticsearch.common.geo.GeoJson
- getGeoPoint() - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
-
Returns the geo point of the context
- getGeoPointValues() - Method in interface org.elasticsearch.index.fielddata.LeafGeoPointFieldData
-
Return geo-point values.
- getGet() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getGet() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getGetResult() - Method in class org.elasticsearch.action.explain.ExplainResponse
- getGetResult() - Method in class org.elasticsearch.action.update.UpdateResponse
- getGiga() - Method in class org.elasticsearch.common.unit.SizeValue
- getGigaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- getGlobalCheckpoint() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteReplicaRequest
- getGlobalCheckpoint() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
- getGlobalCheckpoint() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Returns the in-memory global checkpoint for the shard.
- getGlobalCheckpoint() - Method in class org.elasticsearch.index.seqno.SeqNoStats
- getGlobalCheckpoint() - Method in class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- getGlobalCheckpointSupplier() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the global checkpoint tracker
- getGlobalGeneration() - Method in class org.elasticsearch.cluster.metadata.Manifest
-
Returns global metadata generation.
- getGlobalText() - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
Gets the global suggest text
- getGroups() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- getGroups(String) - Method in class org.elasticsearch.common.settings.Settings
-
Returns group settings for the given setting prefix.
- getGroups(String, boolean) - Method in class org.elasticsearch.common.settings.Settings
-
Returns group settings for the given setting prefix.
- getGroupStats() - Method in class org.elasticsearch.index.search.stats.SearchStats
- getGuiceServiceClasses() - Method in class org.elasticsearch.plugins.Plugin
-
Node level services that will be automatically started/stopped/closed.
- getGuiceServiceClasses() - Method in class org.elasticsearch.plugins.PluginsService
-
Returns all classes injected into guice by plugins which extend
LifecycleComponent
. - getHandler() - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- getHandler(String) - Method in class org.elasticsearch.transport.Transport.RequestHandlers
- getHandshakeTimeout() - Method in class org.elasticsearch.transport.ConnectionProfile
-
Returns the handshake timeout or
null
if no explicit timeout is set on this profile. - getHeader() - Method in class org.elasticsearch.transport.InboundMessage
- getHeader(String) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Returns the header for the given key or
null
if not present - getHeader(String) - Method in exception org.elasticsearch.ElasticsearchException
-
Returns the list of header values for the given key or
null
if no header for the given key exists. - getHeader(String) - Method in class org.elasticsearch.tasks.Task
-
Returns stored task header associated with the task
- getHeaderKeys() - Method in exception org.elasticsearch.ElasticsearchException
-
Returns a set of all header keys on this exception
- getHeaderMap() - Method in class org.elasticsearch.common.Table
- getHeaders() - Method in class org.elasticsearch.common.Table
- getHeaders() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Returns all of the request headers from the thread's context.
Be advised, headers might contain credentials. In order to avoid storing, and erroneously exposing, such headers, it is recommended to instead store security headers that prove the credentials have been verified successfully, and which are internal to the system, in the sense that they cannot be sent by the clients. - getHeaders() - Method in exception org.elasticsearch.ElasticsearchException
- getHeaders() - Method in class org.elasticsearch.http.HttpPipelinedRequest
- getHeaders() - Method in interface org.elasticsearch.http.HttpRequest
-
Get all of the headers and values associated with the headers.
- getHeaders() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getHeaders() - Method in class org.elasticsearch.rest.RestRequest
-
Get all of the headers and values associated with the headers.
- getHeaders() - Method in class org.elasticsearch.rest.RestResponse
-
Returns custom headers that have been added.
- getHeaders() - Method in class org.elasticsearch.tasks.TaskInfo
-
Returns the task headers
- getHealth() - Method in class org.elasticsearch.monitor.fs.FsHealthService
- getHealth() - Method in interface org.elasticsearch.monitor.NodeHealthService
- getHeapCommitted() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
- getHeapInit() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- getHeapMax() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
-
Maximum total heap available to the cluster
- getHeapMax() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- getHeapMax() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
-
returns the maximum heap size.
- getHeapUsed() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
-
Total heap used in the cluster
- getHeapUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
- getHeapUsedPercent() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
-
returns the heap usage in percent.
- getHighFreqMinimumNumberShouldMatchSpec() - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
-
Deprecated.
- getHighlightBuilder() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getHighlighted() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- getHighlighters() - Method in class org.elasticsearch.plugins.SearchPlugin.FetchPhaseConstructionContext
- getHighlighters() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
Get the
Highlighter
s defined by this plugin. - getHighlighters() - Method in class org.elasticsearch.search.SearchModule
-
Returns the
Highlighter
registry - getHighlightFields() - Method in class org.elasticsearch.search.SearchHit
-
A map of highlighted fields.
- getHighlightMaxAnalyzedOffset() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum number of chars that will be analyzed in a highlight request
- getHighWatermarkRaw() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
-
Gets the raw (uninterpreted) high watermark value as found in the settings.
- getHistogramValues() - Method in interface org.elasticsearch.index.fielddata.LeafHistogramFieldData
-
Return Histogram values.
- getHistoryOperations(String, Engine.HistorySource, long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Creates a new history snapshot for reading operations since the provided starting seqno (inclusive).
- getHistoryUUID() - Method in class org.elasticsearch.index.engine.Engine
-
returns the history uuid for the engine
- getHistoryUUID() - Method in class org.elasticsearch.index.engine.InternalEngine
- getHistoryUUID() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getHistoryUUID() - Method in class org.elasticsearch.index.shard.IndexShard
- getHistoryUUID() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
returns the history uuid the store points at, or null if nonexistent.
- getHit() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- getHitCount() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
The number of successful lookups in the cache.
- getHitCount() - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- getHits() - Method in class org.elasticsearch.action.search.SearchResponse
-
The search hits.
- getHits() - Method in class org.elasticsearch.common.cache.Cache.CacheStats
- getHits() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.Response
-
The documents returned in this batch.
- getHits() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTopHits
- getHits() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTopHits
- getHits() - Method in interface org.elasticsearch.search.aggregations.metrics.TopHits
- getHits() - Method in class org.elasticsearch.search.SearchHits
-
The hits of the search request (based on the search type, and from / size provided).
- getHost() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getHostAddress() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- getHostname() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
System's hostname.
- getHostname() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getHostName() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- getHotThreads() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodeHotThreads
- getHour() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getHourOfDay() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getHttp() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getHttpChannel() - Method in class org.elasticsearch.rest.RestRequest
- getHttpRequest() - Method in class org.elasticsearch.rest.RestRequest
- getHttpServerTransportSupplier() - Method in class org.elasticsearch.common.network.NetworkModule
- getHttpTransports(Settings, ThreadPool, BigArrays, PageCacheRecycler, CircuitBreakerService, NamedXContentRegistry, NetworkService, HttpServerTransport.Dispatcher, ClusterSettings) - Method in interface org.elasticsearch.plugins.NetworkPlugin
-
Returns a map of
HttpServerTransport
suppliers. - getHunspellDictionaries() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional hunspell
Dictionary
s. - getHyperLogLog(long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
-
Get HyperLogLog algorithm
- getHyperLogLog(long) - Method in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- getId() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- getId() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult
- getId() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult
- getId() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The id of the action.
- getId() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The id of the action.
- getId() - Method in enum class org.elasticsearch.action.DocWriteRequest.OpType
- getId() - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- getId() - Method in class org.elasticsearch.action.DocWriteResponse
-
The id of the document changed.
- getId() - Method in class org.elasticsearch.action.explain.ExplainResponse
- getId() - Method in class org.elasticsearch.action.get.GetResponse
-
The id of the document.
- getId() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
-
The id of the document.
- getId() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
-
The id of the action.
- getId() - Method in class org.elasticsearch.action.ingest.DeletePipelineRequest
- getId() - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- getId() - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- getId() - Method in exception org.elasticsearch.action.RoutingMissingException
- getId() - Method in class org.elasticsearch.action.search.ClosePointInTimeRequest
- getId() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
-
The id of the document.
- getId() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
-
The id of the action.
- getId() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- getId() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
The unique id of the node.
- getId() - Method in class org.elasticsearch.cluster.routing.AllocationId
-
The allocation id uniquely identifying an allocation, note, if it is relocation the
AllocationId.getRelocationId()
need to be taken into account as well. - getId() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard id.
- getId() - Method in enum class org.elasticsearch.common.Rounding.DateTimeUnit
- getId() - Method in class org.elasticsearch.index.engine.CommitStats
-
base64 version of the commit id (see
SegmentInfos.getId()
- getId() - Method in class org.elasticsearch.index.get.GetResult
-
The id of the document.
- getId() - Method in class org.elasticsearch.index.merge.OnGoingMerge
-
A unique id for the merge.
- getId() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getId() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The document id of the hit.
- getId() - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.RemoveRequest
- getId() - Method in class org.elasticsearch.index.shard.ShardId
- getId() - Method in class org.elasticsearch.ingest.Pipeline
-
The unique id of this pipeline
- getId() - Method in class org.elasticsearch.ingest.PipelineConfiguration
- getId() - Method in class org.elasticsearch.monitor.process.ProcessInfo
-
The process id.
- getId() - Method in enum class org.elasticsearch.persistent.decider.AssignmentDecision.Type
- getId() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- getId() - Method in class org.elasticsearch.repositories.IndexId
-
The unique ID for the index within the repository.
- getId() - Method in enum class org.elasticsearch.script.ScriptType
- getId() - Method in class org.elasticsearch.search.internal.ShardSearchContextId
- getId() - Method in class org.elasticsearch.search.SearchHit
-
The id of the document.
- getId() - Method in class org.elasticsearch.search.slice.SliceBuilder
-
The id of the slice.
- getId() - Method in class org.elasticsearch.search.slice.SliceQuery
- getId() - Method in class org.elasticsearch.tasks.Task
-
Returns task id
- getId() - Method in class org.elasticsearch.tasks.TaskId
- getId() - Method in class org.elasticsearch.tasks.TaskInfo
- getId(int) - Method in class org.elasticsearch.search.RescoreDocIds
- getId(Class<? extends ElasticsearchException>) - Static method in exception org.elasticsearch.ElasticsearchException
-
Returns the serialization id the given exception.
- getIdOrCode() - Method in class org.elasticsearch.script.Script
- getIds() - Method in class org.elasticsearch.action.ingest.GetPipelineRequest
- getIfPrimaryTerm() - Method in class org.elasticsearch.index.engine.Engine.Delete
- getIfPrimaryTerm() - Method in class org.elasticsearch.index.engine.Engine.Get
- getIfPrimaryTerm() - Method in class org.elasticsearch.index.engine.Engine.Index
- getIfSeqNo() - Method in class org.elasticsearch.index.engine.Engine.Delete
- getIfSeqNo() - Method in class org.elasticsearch.index.engine.Engine.Get
- getIfSeqNo() - Method in class org.elasticsearch.index.engine.Engine.Index
- getIgnoredFields() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Return the collection of fields that have been ignored so far.
- getIgnoredValues() - Method in class org.elasticsearch.common.document.DocumentField
-
The field's ignored values as an immutable list.
- getIgnoredValuesWriter() - Method in class org.elasticsearch.common.document.DocumentField
- getIgnoreMalformed() - Method in class org.elasticsearch.index.mapper.DateFieldMapper
- getIgnoreNodes(ShardId) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- getInactivePrimaryHealth(ShardRouting) - Static method in class org.elasticsearch.cluster.health.ClusterShardHealth
-
Checks if an inactive primary shard should cause the cluster health to go RED.
- getInboundException() - Method in class org.elasticsearch.http.HttpPipelinedRequest
- getInboundException() - Method in interface org.elasticsearch.http.HttpRequest
- getIncomingRecoveries(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- getIncompatibleClusterStateDiffReceivedCount() - Method in class org.elasticsearch.discovery.zen.PublishClusterStateStats
- getIncrementalFileCount() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns incremental file count of the snapshot
- getIncrementalFileCount() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getIncrementalSize() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Return incremental files size of the snapshot
- getIncrementalSize() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getIndex() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Returns the index name of the shard to explain, or
null
to use any unassigned shard (seeClusterAllocationExplainRequest.useAnyUnassignedShard()
). - getIndex() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
-
Returns the index name
- getIndex() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.IndexResult
- getIndex() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockResult
- getIndex() - Method in class org.elasticsearch.action.admin.indices.segments.IndexSegments
- getIndex() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- getIndex() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexUpgradeStatus
- getIndex() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- getIndex() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The index name of the action.
- getIndex() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The index name of the action.
- getIndex() - Method in class org.elasticsearch.action.DocWriteResponse
-
The index the document was changed in.
- getIndex() - Method in class org.elasticsearch.action.explain.ExplainResponse
- getIndex() - Method in class org.elasticsearch.action.get.GetResponse
-
The index the document was fetched from.
- getIndex() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
-
The index name of the document.
- getIndex() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
-
The index name of the action.
- getIndex() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardResponse
- getIndex() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
-
The index name of the document.
- getIndex() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
-
The index name of the action.
- getIndex() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- getIndex() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getIndex() - Method in class org.elasticsearch.cluster.metadata.AliasAction
-
Get the index on which the operation should act.
- getIndex() - Method in class org.elasticsearch.cluster.metadata.DataStreamAction
- getIndex() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Tombstone
-
The deleted index.
- getIndex() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getIndex() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Return the index id
- getIndex() - Method in exception org.elasticsearch.ElasticsearchException
- getIndex() - Method in class org.elasticsearch.index.get.GetResult
-
The index the document was fetched from.
- getIndex() - Method in class org.elasticsearch.index.IndexModule
-
Returns the index this module is associated with
- getIndex() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the index this settings object belongs to
- getIndex() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getIndex() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The index in which the hit is stored.
- getIndex() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- getIndex() - Method in class org.elasticsearch.index.shard.ShardId
- getIndex() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getIndex() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.IndexBoost
- getIndex() - Method in class org.elasticsearch.search.SearchHit
-
The index of the hit.
- getIndex() - Method in class org.elasticsearch.search.SearchShardTarget
- getIndex(String) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- getIndex(GetIndexRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get index metadata for particular indices.
- getIndex(GetIndexRequest, ActionListener<GetIndexResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get index metadata for particular indices.
- GetIndexAction - Class in org.elasticsearch.action.admin.indices.get
- getIndexAnalyzer() - Method in class org.elasticsearch.index.mapper.TextParams.Analyzers
- getIndexAnalyzer(Function<String, NamedAnalyzer>) - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Return the index-time analyzer for the current index
- getIndexAnalyzer(Function<String, NamedAnalyzer>) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Return the index-time analyzer for the current index
- getIndexAnalyzer(Function<String, NamedAnalyzer>) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- getIndexAnalyzers() - Method in class org.elasticsearch.index.IndexService
- getIndexAnalyzers() - Method in class org.elasticsearch.index.mapper.MapperService
- getIndexAnalyzers() - Method in class org.elasticsearch.index.mapper.MappingParserContext
- getIndexAnalyzers() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- getIndexBalance() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
Returns the index related weight factor.
- getIndexBlockWithId(String, int) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- getIndexBufferRAMBytesUsed() - Method in class org.elasticsearch.index.engine.Engine
-
How much heap is used that would be freed by a refresh.
- getIndexBufferRAMBytesUsed() - Method in class org.elasticsearch.index.engine.InternalEngine
- getIndexBufferRAMBytesUsed() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getIndexBufferRAMBytesUsed() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns number of heap bytes used by the indexing buffer for this shard, or 0 if the shard is closed
- getIndexBufferRAMBytesUsed(IndexShard) - Method in class org.elasticsearch.indices.IndexingMemoryController
-
returns how much heap this shard is using for its indexing buffer
- getIndexCommit() - Method in class org.elasticsearch.common.lucene.FilterIndexCommit
- getIndexCommit() - Method in class org.elasticsearch.index.engine.Engine.IndexCommitRef
- getIndexCommit(SegmentInfos, Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Returns an index commit for the given
SegmentInfos
in the given directory. - getIndexCount() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getIndexCount() - Method in class org.elasticsearch.action.admin.cluster.stats.IndexFeatureStats
-
Return the number of indices that use this feature across the cluster.
- getIndexCount() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
The total number of indexing operations
- getIndexCurrent() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
Returns the currently in-flight indexing operations.
- getIndexDescriptors() - Method in class org.elasticsearch.indices.SystemIndices.Feature
- getIndexEventListener() - Method in class org.elasticsearch.index.IndexService
- getIndexEventListener() - Method in class org.elasticsearch.index.shard.IndexShard
- getIndexFailedCount() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
The number of failed indexing operations
- getIndexFoldersDeletionListeners() - Method in interface org.elasticsearch.plugins.IndexStorePlugin
-
The
IndexStorePlugin.IndexFoldersDeletionListener
listeners for this plugin. - getIndexFormat() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getIndexGenerations() - Method in class org.elasticsearch.cluster.metadata.Manifest
-
Returns map from
Index
to index metadata generation. - getIndexId() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan.SnapshotFilesToRecover
- getIndexId() - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshot
- getIndexId() - Method in class org.elasticsearch.indices.recovery.RecoverySnapshotFileRequest
- getIndexId() - Method in class org.elasticsearch.repositories.ShardSnapshotInfo
- getIndexing() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getIndexing() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getIndexingBufferSize() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the initial index buffer size.
- getIndexingPressureStats() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getIndexMetaBlobId(String) - Method in class org.elasticsearch.repositories.IndexMetaDataGenerations
-
Gets the blob id by the identifier of
IndexMetadata
(computed viaIndexMetaDataGenerations.buildUniqueIdentifier(org.elasticsearch.cluster.metadata.IndexMetadata)
) ornull
if none is tracked for the identifier. - getIndexMetadata() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the current IndexMetadata for this index
- getIndexMetadataIdentifier() - Method in class org.elasticsearch.repositories.ShardSnapshotInfo
- getIndexName() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.IndexInfo
- getIndexName() - Method in class org.elasticsearch.action.admin.indices.dangling.DanglingIndexInfo
- getIndexName() - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateRequest
- getIndexName() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexResponse
-
Get the index name
- getIndexName() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The index name.
- getIndexName() - Method in class org.elasticsearch.index.shard.ShardId
- getIndexName() - Method in class org.elasticsearch.search.fetch.FetchContext
-
The name of the index that documents are being fetched from
- getIndexNameExpressionResolver() - Method in class org.elasticsearch.cluster.ClusterModule
- getIndexPattern() - Method in class org.elasticsearch.indices.AssociatedIndexDescriptor
- getIndexPattern() - Method in interface org.elasticsearch.indices.IndexPatternMatcher
- getIndexPattern() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getIndexReader() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Return the current
IndexReader
, ornull
if no index reader is available, for instance if this rewrite context is used to index queries (percolation). - GetIndexRequest - Class in org.elasticsearch.action.admin.indices.get
-
A request to retrieve information about an index.
- GetIndexRequest() - Constructor for class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- GetIndexRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- GetIndexRequest.Feature - Enum Class in org.elasticsearch.action.admin.indices.get
- GetIndexRequestBuilder - Class in org.elasticsearch.action.admin.indices.get
- GetIndexRequestBuilder(ElasticsearchClient, GetIndexAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.get.GetIndexRequestBuilder
- GetIndexResponse - Class in org.elasticsearch.action.admin.indices.get
-
A response for a get index action.
- GetIndexResponse(String[], ImmutableOpenMap<String, ImmutableOpenMap<String, MappingMetadata>>, ImmutableOpenMap<String, List<AliasMetadata>>, ImmutableOpenMap<String, Settings>, ImmutableOpenMap<String, Settings>, ImmutableOpenMap<String, String>) - Constructor for class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- getIndexRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- getIndexSafe(Index) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Returns the
IndexMetadata
for this index. - getIndexScopedSettings() - Method in class org.elasticsearch.common.settings.SettingsModule
- getIndexSettings() - Method in class org.elasticsearch.index.AbstractIndexComponent
- getIndexSettings() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the index settings for this index.
- getIndexSettings() - Method in class org.elasticsearch.index.IndexService
- getIndexSettings() - Method in class org.elasticsearch.index.mapper.MappingParserContext
- getIndexSettings() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Returns the index settings for this context.
- getIndexSettings() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns the index indexSettings
- getIndexSettings() - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndex
-
Returns the index settings of this index.
- getIndexSettings() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
The settings for the index against which this search is running.
- getIndexSettings() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- getIndexShards() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- getIndexSort() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Return the sort order of this index, or null if the index has no sort.
- getIndexSort() - Method in class org.elasticsearch.index.shard.IndexShard
-
Return the sort order of this index, or null if the index has no sort.
- getIndexSortConfig() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the index sort config that should be used for this index.
- getIndexSortSupplier() - Method in class org.elasticsearch.index.IndexService
- getIndexTemplateMetadataUpgrader() - Method in class org.elasticsearch.plugins.Plugin
-
Provides a function to modify index template meta data on startup.
- getIndexTemplateRequest() - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateRequest
- getIndexTemplateRequest() - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction.Request
- getIndexTemplates() - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesResponse
- GetIndexTemplatesAction - Class in org.elasticsearch.action.admin.indices.template.get
- GetIndexTemplatesAction() - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesAction
- GetIndexTemplatesRequest - Class in org.elasticsearch.action.admin.indices.template.get
-
Request that allows to retrieve index templates
- GetIndexTemplatesRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
- GetIndexTemplatesRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
- GetIndexTemplatesRequestBuilder - Class in org.elasticsearch.action.admin.indices.template.get
- GetIndexTemplatesRequestBuilder(ElasticsearchClient, GetIndexTemplatesAction) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequestBuilder
- GetIndexTemplatesRequestBuilder(ElasticsearchClient, GetIndexTemplatesAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequestBuilder
- GetIndexTemplatesResponse - Class in org.elasticsearch.action.admin.indices.template.get
- GetIndexTemplatesResponse(List<IndexTemplateMetadata>) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesResponse
- GetIndexTemplatesResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesResponse
- getIndexThrottleTimeInMillis() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the number of milliseconds this engine was under index throttling.
- getIndexThrottleTimeInMillis() - Method in class org.elasticsearch.index.engine.InternalEngine
- getIndexThrottleTimeInMillis() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getIndexTime() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
The total amount of time spend on executing index operations.
- getIndexToDefaultSettings() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
-
If the originating
GetSettingsRequest
object was configured to include defaults, this will contain a mapping of index name toSettings
objects. - getIndexToSettings() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
-
Returns a map of index name to
Settings
object. - getIndexType() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getIndexUUID() - Method in class org.elasticsearch.action.admin.indices.dangling.DanglingIndexInfo
- getIndexUUID() - Method in class org.elasticsearch.action.admin.indices.dangling.delete.DeleteDanglingIndexRequest
- getIndexUUID() - Method in class org.elasticsearch.action.admin.indices.dangling.find.FindDanglingIndexRequest
- getIndexUUID() - Method in class org.elasticsearch.action.admin.indices.dangling.find.NodeFindDanglingIndexRequest
- getIndexUUID() - Method in class org.elasticsearch.action.admin.indices.dangling.import_index.ImportDanglingIndexRequest
- getIndexUUID() - Method in class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesRequest
- getIndexUUID() - Method in class org.elasticsearch.action.admin.indices.dangling.list.NodeListDanglingIndicesRequest
- getIndexUUID() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getIndexVersion() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getIndexVersionCreated() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the version the index was created on.
- getIndexVersions() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.FeatureUpgradeStatus
- getIndexWriteRequest(DocWriteRequest<?>) - Static method in class org.elasticsearch.action.bulk.TransportBulkAction
-
Retrieves the
IndexRequest
from the providedDocWriteRequest
for index or upsert actions. - getIndexWriterMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getIndexWriterMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the memory usage by index writer
- getIndices() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getIndices() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
Indices level stats.
- getIndices() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Returns list of snapshot indices
- getIndices() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
number of indices in the cluster
- getIndices() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse
- getIndices() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- getIndices() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse
- getIndices() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedAlias
- getIndices() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Response
- getIndices() - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentResponse
- getIndices() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- getIndices() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusResponse
- getIndices() - Method in class org.elasticsearch.action.bulk.BulkRequest
- getIndices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesFailure
- getIndices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
-
Get the concrete list of indices that were requested and returned a response.
- getIndices() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getIndices() - Method in class org.elasticsearch.cluster.metadata.DataStream
- getIndices() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- getIndices() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.ConcreteIndex
- getIndices() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- getIndices() - Method in interface org.elasticsearch.cluster.metadata.IndexAbstraction
- getIndices() - Method in class org.elasticsearch.cluster.metadata.ItemUsage
- getIndices() - Method in class org.elasticsearch.cluster.metadata.Metadata
- getIndices() - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns an unmodifiable map of the index names to
IndexId
in the repository. - getIndices() - Method in class org.elasticsearch.snapshots.SnapshotFeatureInfo
- getIndicesAndFilters() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- getIndicesFieldDataCache() - Method in class org.elasticsearch.indices.IndicesService
- getIndicesLookup() - Method in class org.elasticsearch.cluster.metadata.Metadata
- getIndicesQueryCache() - Method in class org.elasticsearch.indices.IndicesService
- getIndicesRouting() - Method in class org.elasticsearch.cluster.routing.RoutingTable
- getIndicesService() - Method in class org.elasticsearch.search.SearchService
- getIndicesStats() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- getInflightBreaker() - Method in class org.elasticsearch.transport.TcpTransport
- getInflightOpsCount(ShardId, ClusterState, IndexShardRoutingTable, ActionListener<SyncedFlushService.InFlightOpsResponse>) - Method in class org.elasticsearch.indices.flush.SyncedFlushService
-
returns the number of in flight operations on primary.
- getInfo() - Method in class org.elasticsearch.monitor.StatusInfo
- getInfo(Class<T>) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
Get a particular info object, e.g.
- getInfos() - Method in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoResponse
- getIngestCount() - Method in class org.elasticsearch.ingest.IngestStats.Stats
- getIngestCurrent() - Method in class org.elasticsearch.ingest.IngestStats.Stats
- getIngestDocument() - Method in class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- getIngestDocument() - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- getIngestFailedCount() - Method in class org.elasticsearch.ingest.IngestStats.Stats
- getIngestMetadata() - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the available ingest metadata fields, by default only timestamp, but it is possible to set additional ones.
- getIngestNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
- getIngestService() - Method in class org.elasticsearch.node.NodeService
- getIngestStats() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getIngestTimeInMillis() - Method in class org.elasticsearch.ingest.IngestStats.Stats
- getIngestTook() - Method in class org.elasticsearch.action.bulk.BulkResponse
-
If ingest is enabled returns the bulk ingest preprocessing time, otherwise 0 is returned.
- getIngestTookInMillis() - Method in class org.elasticsearch.action.bulk.BulkResponse
-
If ingest is enabled returns the bulk ingest preprocessing time.
- getInitialBuffer() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- getInitialConnectionTimeout() - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- getInitializingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getInitializingShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
-
Number of shards with the snapshot in the initializing stage
- getInitializingShards() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getInitializingShards() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- getInitializingShards() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getInitialRecoveryFilters() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getInjectableMembers() - Method in interface org.elasticsearch.common.inject.spi.ConstructorBinding
-
Returns all instance method and field injection points on
type
. - getInjectionPoint() - Method in class org.elasticsearch.common.inject.spi.Dependency
-
Returns the injection point to which this dependency belongs, or null if this dependency isn't attached to a particular injection point.
- getInjectionPoints() - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- getInjectionPoints() - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- getInjectionPoints() - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
-
Returns the instance methods and fields of
instance
that will be injected to fulfill this request. - getInjectionPoints() - Method in interface org.elasticsearch.common.inject.spi.InstanceBinding
-
Returns the field and method injection points of the instance, injected at injector-creation time only.
- getInjectionPoints() - Method in interface org.elasticsearch.common.inject.spi.ProviderInstanceBinding
-
Returns the field and method injection points of the provider, injected at injector-creation time only.
- getInjectionPoints() - Method in class org.elasticsearch.common.inject.spi.StaticInjectionRequest
-
Returns the static methods and fields of
type
that will be injected to fulfill this request. - getInjector() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- getInjector() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- getInjector() - Method in interface org.elasticsearch.common.inject.spi.PrivateElements
-
Returns the child injector that hosts these private elements, or null if the elements haven't been used to create an injector.
- getInnerCollapseBuilder() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getInnerFactory() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory
- getInnerHit() - Method in class org.elasticsearch.search.collapse.CollapseContext
-
The inner hit options to expand the collapsed results
- getInnerHitQueryWeight() - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- getInnerHits() - Method in class org.elasticsearch.search.collapse.CollapseBuilder
-
The inner hit options to expand the collapsed results
- getInnerHits() - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext
- getInnerHits() - Method in class org.elasticsearch.search.SearchHit
- getInnerProcessor() - Method in class org.elasticsearch.ingest.ConditionalProcessor
- getInnerProcessor() - Method in interface org.elasticsearch.ingest.WrappingProcessor
-
Method for retrieving the inner processor from a wrapped processor.
- getInnerQuery() - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
- getInputArguments() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getInputStreamForSnapshotFile(String, IndexId, ShardId, BlobStoreIndexShardSnapshot.FileInfo, LongConsumer) - Method in class org.elasticsearch.indices.recovery.SnapshotFilesProvider
- getInsertOrder() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- getInstance() - Static method in class org.elasticsearch.cluster.DiffableUtils.StringSetValueSerializer
- getInstance() - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- getInstance() - Method in class org.elasticsearch.common.inject.internal.ProviderMethod
- getInstance() - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
- getInstance() - Method in interface org.elasticsearch.common.inject.spi.InstanceBinding
-
Returns the user-supplied instance.
- getInstance() - Static method in class org.elasticsearch.monitor.os.OsProbe
- getInstance() - Static method in class org.elasticsearch.monitor.process.ProcessProbe
- getInstance(Class<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the appropriate instance for the given injection type; equivalent to
getProvider(type).get()
. - getInstance(Key<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the appropriate instance for the given injection key; equivalent to
getProvider(key).get()
. - getInSyncAllocationIds() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getInSyncAllocationIds() - Method in class org.elasticsearch.index.shard.ReplicationGroup
- getInSyncAllocationIds(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- getInSyncGlobalCheckpoints() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Get the local knowledge of the persisted global checkpoints for all in-sync allocation IDs.
- getInSyncGlobalCheckpoints() - Method in class org.elasticsearch.index.shard.IndexShard
-
Get the local knowledge of the global checkpoints for all in-sync allocation IDs.
- getInt(int) - Method in class org.elasticsearch.common.bytes.AbstractBytesReference
- getInt(int) - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Returns the integer read from the 4 bytes (BE) starting at the given index.
- getInt(int) - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- getInternalFactory() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- getInternalRefreshListener() - Method in class org.elasticsearch.index.engine.EngineConfig
-
The refresh listeners to add to Lucene for internally visible refreshes.
- getInternalRepositories(Environment, NamedXContentRegistry, ClusterService, RecoverySettings) - Method in interface org.elasticsearch.plugins.RepositoryPlugin
-
Returns internal repository types added by this plugin.
- getInternalResponse() - Method in class org.elasticsearch.action.search.SearchResponse
- getInternalValues() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- getInterval() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- getInterval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- getInterval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram
- getIntervalAsCalendar() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Return the interval as a date time unit if applicable, regardless of how it was configured.
- getIntervalAsFixed() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Get the interval as a
TimeValue
, regardless of how it was configured. - getIntervalsSourceProviderNamedWritables() - Static method in class org.elasticsearch.search.SearchModule
- getIntervalType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- getIntKeySerializer() - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Returns a map key serializer for Integer keys.
- getInvertedIndexBytes() - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats.PerFieldDiskUsage
- getIoBuffer() - Static method in class org.elasticsearch.common.io.DiskIoBufferPool
- getIoStats() - Method in class org.elasticsearch.monitor.fs.FsInfo
- getItemId() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The numeric order of the item matching the same request order in the bulk request.
- getItems() - Method in class org.elasticsearch.action.bulk.BulkResponse
-
The items representing each action performed in the bulk operation (in the same order!).
- getItems() - Method in class org.elasticsearch.action.get.MultiGetRequest
- getIterator() - Method in class org.elasticsearch.search.aggregations.bucket.IteratorAndCurrent
- getJavaOpts() - Method in class org.elasticsearch.plugins.PluginDescriptor
-
Returns any additional JVM command-line options that this plugin adds.
- getJavaVersion() - Method in class org.elasticsearch.plugins.PluginDescriptor
-
The version of Java the plugin was built with.
- getJoin() - Method in class org.elasticsearch.cluster.coordination.PublishWithJoinResponse
- getJoins() - Method in class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- getJoinValidator() - Method in interface org.elasticsearch.plugins.DiscoveryPlugin
-
Returns a consumer that validate the initial join cluster state.
- getJvm() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
JVM level statistics.
- getJvm() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- getKb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getKbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getKeepAlive() - Method in class org.elasticsearch.search.builder.PointInTimeBuilder
- getKeepAlive() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- getKey() - Method in class org.elasticsearch.common.cache.RemovalNotification
- getKey() - Method in interface org.elasticsearch.common.inject.Binding
-
Returns the key for this binding.
- getKey() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- getKey() - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- getKey() - Method in class org.elasticsearch.common.inject.internal.ProviderMethod
- getKey() - Method in class org.elasticsearch.common.inject.spi.Dependency
-
Returns the key to the binding that satisfies this dependency.
- getKey() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
- getKey() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup.ProviderImpl
- getKey() - Method in class org.elasticsearch.common.settings.Setting
-
Returns the settings key or a prefix if this setting is a group setting.
- getKey() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldData
- getKey() - Method in interface org.elasticsearch.indices.ESCacheHelper
-
Get a key that the resource can be cached on.
- getKey() - Method in class org.elasticsearch.indices.ESCacheHelper.Wrapper
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.ParsedAdjacencyMatrix.ParsedBucket
- getKey() - Method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite.InternalBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGridBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoTileGridBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoHashGridBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoTileGridBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
-
Buckets are compared using their centroids.
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram.ParsedBucket
- getKey() - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder.Range
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongRareTerms.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantLongTerms.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantStringTerms.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringRareTerms.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms.ParsedBucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms.Bucket
- getKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- getKey() - Method in class org.elasticsearch.search.sort.SortValue
-
The java object representing the sort value.
- getKey(Input) - Method in class org.elasticsearch.common.util.CancellableSingleObjectCache
-
Compute the key for the given input value.
- getKey(String) - Method in interface org.elasticsearch.common.settings.SettingUpgrader
-
The logic to upgrade the setting key, for example by mapping the old setting key to the new setting key.
- getKey(TypeLiteral<?>, Member, Annotation[], Errors) - Static method in class org.elasticsearch.common.inject.internal.Annotations
-
Gets a key for the given type, member and annotations.
- getKey(MultiBucketsAggregation.Bucket) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.HistogramFactory
-
Get the key for the given bucket.
- getKey(MultiBucketsAggregation.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- getKey(MultiBucketsAggregation.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- getKey(MultiBucketsAggregation.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- getKey(MultiBucketsAggregation.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- getKey1(long) - Method in class org.elasticsearch.common.util.LongLongHash
-
Return the first key at
0 <= index <= capacity()
. - getKey2(long) - Method in class org.elasticsearch.common.util.LongLongHash
-
Return the second key at
0 <= index <= capacity()
. - getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms.Bucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms.ParsedBucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongRareTerms.ParsedBucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms.ParsedBucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantLongTerms.ParsedBucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantStringTerms.ParsedBucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringRareTerms.ParsedBucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms.ParsedBucket
- getKeyAsNumber() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.RareTerms.Bucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms.Bucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms.Bucket
- getKeyAsNumber() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.SignificantTerms.Bucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms.Bucket
- getKeyAsNumber() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- getKeyAsNumber() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.Terms.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.ParsedAdjacencyMatrix.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite.InternalBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGridBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoTileGridBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoHashGridBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoTileGridBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram.ParsedBucket
- getKeyAsString() - Method in interface org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongRareTerms.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantLongTerms.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantStringTerms.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringRareTerms.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms.ParsedBucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- getKeyAsString() - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- getKeyed() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- getKeyed() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- getKeyed() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getKeyed() - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
-
Get whether the XContent should be keyed
- getKeys() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
-
Return the keys (percentiles) requested.
- getKeys() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
-
Return the keys (percentiles) requested.
- getKeyStore() - Method in class org.elasticsearch.common.settings.BaseKeyStoreCommand
- getKeyStorePassword() - Method in class org.elasticsearch.common.settings.BaseKeyStoreCommand
- getKilo() - Method in class org.elasticsearch.common.unit.SizeValue
- getKiloFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- getKnownPeers() - Method in class org.elasticsearch.cluster.coordination.PeersResponse
- getKnownPeers() - Method in class org.elasticsearch.discovery.PeersRequest
- getLang() - Method in class org.elasticsearch.script.Script
- getLang() - Method in exception org.elasticsearch.script.ScriptException
-
Returns the language of the script.
- getLang() - Method in class org.elasticsearch.script.StoredScriptSource
- getLargest() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- getLargestNonClientNodeVersion() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns the version of the node with the youngest version in the cluster that is not a client node.
- getLastAcceptedConfiguration() - Method in class org.elasticsearch.cluster.ClusterState
- getLastAcceptedConfiguration() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- getLastAcceptedConfiguration() - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- getLastAcceptedState() - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- getLastAcceptedState() - Method in interface org.elasticsearch.cluster.coordination.CoordinationState.PersistedState
-
Returns the last accepted cluster state
- getLastAcceptedState() - Method in class org.elasticsearch.cluster.coordination.Coordinator
- getLastAcceptedState() - Method in class org.elasticsearch.cluster.coordination.InMemoryPersistedState
- getLastAcceptedTerm() - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- getLastAcceptedTerm() - Method in class org.elasticsearch.cluster.coordination.Join
- getLastAcceptedTerm() - Method in class org.elasticsearch.cluster.coordination.PreVoteResponse
- getLastAcceptedVersion() - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- getLastAcceptedVersion() - Method in class org.elasticsearch.cluster.coordination.Join
- getLastAcceptedVersion() - Method in class org.elasticsearch.cluster.coordination.PreVoteResponse
- getLastAllocatedNodeId() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Gets the ID of the node this shard was last allocated to, or null if unavailable.
- getLastAllocationId() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Builder
- getLastAllocationStatus() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Get the status for the last allocation attempt for this shard.
- getLastCommittedConfiguration() - Method in class org.elasticsearch.cluster.ClusterState
- getLastCommittedConfiguration() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- getLastCommittedConfiguration() - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- getLastCommittedSegmentInfos() - Method in class org.elasticsearch.index.engine.Engine
- getLastCommittedSegmentInfos() - Method in class org.elasticsearch.index.engine.InternalEngine
- getLastCommittedSegmentInfos() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getLastEmittedDocPerShard(SearchPhaseController.ReducedQueryPhase, int) - Method in class org.elasticsearch.action.search.SearchPhaseController
- getLastKnownGlobalCheckpoint() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the global checkpoint for the shard.
- getLastModifiedTime() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- getLastPublishedVersion() - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- getLastResolvedAddresses() - Method in class org.elasticsearch.discovery.PeerFinder
- getLastSyncedGlobalCheckpoint() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the latest global checkpoint value that has been persisted in the underlying storage (i.e.
- getLastSyncedGlobalCheckpoint() - Method in class org.elasticsearch.index.engine.InternalEngine
- getLastSyncedGlobalCheckpoint() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getLastSyncedGlobalCheckpoint() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the latest global checkpoint value that has been persisted in the underlying storage (i.e.
- getLastSyncedGlobalCheckpoint() - Method in class org.elasticsearch.index.translog.Translog
-
The last synced checkpoint for this translog.
- getLastWriteLocation() - Method in class org.elasticsearch.index.translog.Translog
-
The a Translog.Location that will sort after the Translog.Location returned by the last write but before any locations which can be returned by the next write.
- getLastWriteNanos() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the timestamp of the last write in nanoseconds.
- getLat() - Method in class org.elasticsearch.common.geo.GeoPoint
- getLat() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getLatestShardSnapshot() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotResponse
- getLatestSuccessfulSnapshotForShard(String, ShardId, ActionListener<Optional<ShardSnapshotInfo>>) - Method in class org.elasticsearch.repositories.IndexSnapshotsService
- getLats() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getLeader() - Method in class org.elasticsearch.discovery.PeerFinder
- getLeaderState() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Returns the object that tracks the state of sliced subtasks.
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.FilteredCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Collect results for this leaf.
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.BucketCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.MultiBucketCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.profile.query.InternalProfileCollector
- getLeafCollector(LeafReaderContext) - Method in class org.elasticsearch.search.query.EarlyTerminatingCollector
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Collect results for this leaf.
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterByFilterAggregator
-
Instead of returning a
LeafBucketCollector
we do the collection ourselves by running the filters directly. - getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.NumericHistogramAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.RangeHistogramAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTermsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.terms.NumericTermsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTermsAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.GlobalOrdCardinalityAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.MinAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.SumAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregator
- getLeafCollector(LeafReaderContext, LeafBucketCollector) - Method in class org.elasticsearch.search.aggregations.NonCollectingAggregator
- getLeafCollector(IncludeExclude.StringFilter, LeafReaderContext, LeafBucketCollector, LongConsumer, MapStringTermsAggregator.CollectConsumer) - Method in interface org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator.CollectorSource
-
Build the collector.
- getLeafCollector(IncludeExclude.StringFilter, LeafReaderContext, LeafBucketCollector, LongConsumer, MapStringTermsAggregator.CollectConsumer) - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator.ValuesSourceCollectorSource
- getLeafNestedDocuments(LeafReaderContext) - Method in class org.elasticsearch.search.NestedDocuments
-
Returns a LeafNestedDocuments for an index segment
- getLeafReaderContext() - Method in class org.elasticsearch.script.DocValuesDocReader
- getLeafReaderContext() - Method in interface org.elasticsearch.script.LeafReaderContextSupplier
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.FilterScoreFunction
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.RandomScoreFunction
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- getLeafScoreFunction(LeafReaderContext) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- getLeafSearchLookup(LeafReaderContext) - Method in class org.elasticsearch.search.lookup.SearchLookup
- getLeafSorter() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns how segments should be sorted for reading or @null if no sorting should be applied.
- getLegacyDefaultBackingIndexName(String, long) - Static method in class org.elasticsearch.cluster.metadata.DataStream
- getLength() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Doc
-
Return the number of tokens that the current document has in the considered field.
- getLength() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- getLikeFields() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getLikeText() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getLikeTexts() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getLimit() - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
- getLimit() - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
- getLimit() - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- getLimit() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
- getLimit() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- getLimit() - Method in class org.elasticsearch.search.aggregations.MultiBucketConsumerService.MultiBucketConsumer
- getLinearCounting(long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
-
Get linear counting algorithm
- getLinearCounting(long) - Method in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- getLineNumber() - Method in exception org.elasticsearch.common.ParsingException
-
Line number of the location of the error
- getLineNumber() - Method in exception org.elasticsearch.search.SearchParseException
-
Line number of the location of the error
- getLinkedKey() - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- getLinkedKey() - Method in interface org.elasticsearch.common.inject.spi.LinkedKeyBinding
-
Returns the linked key used to resolve injections.
- getListener() - Method in class org.elasticsearch.common.inject.spi.TypeListenerBinding
-
Returns the registered listener.
- getListeners() - Method in class org.elasticsearch.index.refresh.RefreshStats
-
The number of waiting refresh listeners.
- getListValue(List<String>) - Method in interface org.elasticsearch.common.settings.SettingUpgrader
- getLiveDocs() - Method in class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazySoftDeletesFilterCodecReader
- getLiveDocs() - Method in class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazySoftDeletesFilterLeafReader
- getLoadAndScaleToPercent(Method, OperatingSystemMXBean) - Static method in class org.elasticsearch.monitor.Probes
- getLoadAverage() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
- getLoadedClassCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Classes
- getLocalAddress() - Method in interface org.elasticsearch.http.HttpChannel
-
Returns the local address for this channel.
- getLocalAddress() - Method in interface org.elasticsearch.http.HttpServerChannel
-
Returns the local address for this channel.
- getLocalAddress() - Method in interface org.elasticsearch.transport.TcpChannel
-
Returns the local address for this channel.
- getLocalAddress() - Method in interface org.elasticsearch.transport.TcpServerChannel
-
Returns the local address for this channel.
- getLocalCheckpoint() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
- getLocalCheckpoint() - Method in class org.elasticsearch.index.seqno.SeqNoStats
-
the maximum sequence number for which all previous operations (including) have been persisted
- getLocalCheckpoint() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the persisted local checkpoint for the shard.
- getLocalCheckpointOfSafeCommit() - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
-
Returns the local checkpoint of the safe commit.
- getLocalNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get the local node
- getLocalNode() - Method in class org.elasticsearch.transport.RemoteClusterService
- getLocalNode() - Method in class org.elasticsearch.transport.TransportService
- getLocalNodeConnection() - Method in class org.elasticsearch.transport.TransportService
- getLocalNodeId() - Method in class org.elasticsearch.client.node.NodeClient
-
The id of the local
DiscoveryNode
. - getLocalNodeId() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get the id of the local node
- getLocation(String) - Method in class org.elasticsearch.action.DocWriteResponse
-
Return the relative URI for the location of the document suitable for use in the
Location
header. - getLogger() - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- getLogger() - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- getLogger(Class<?>) - Static method in class org.elasticsearch.common.logging.DeprecationLogger
-
Creates a new deprecation logger for the supplied class.
- getLogger(Class<?>, String...) - Static method in class org.elasticsearch.common.logging.Loggers
- getLogger(Class<?>, Index, String...) - Static method in class org.elasticsearch.common.logging.Loggers
- getLogger(Class<?>, ShardId, String...) - Static method in class org.elasticsearch.common.logging.Loggers
- getLogger(String) - Static method in class org.elasticsearch.bootstrap.plugins.LoggerTerminal
- getLogger(String) - Static method in class org.elasticsearch.common.logging.DeprecationLogger
-
Creates a new deprecation logger based on the parent logger.
- getLogger(String, ShardId) - Static method in class org.elasticsearch.common.logging.Loggers
-
Just like
Loggers.getLogger(Class, ShardId, String...)
but String loggerName instead of Class and no extra prefixes. - getLogger(Logger, String) - Static method in class org.elasticsearch.common.logging.Loggers
- getLon() - Method in class org.elasticsearch.common.geo.GeoPoint
- getLon() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getLong(TemporalField) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getLongValues() - Method in class org.elasticsearch.index.fielddata.BooleanScriptFieldData.BooleanScriptLeafFieldData
- getLongValues() - Method in class org.elasticsearch.index.fielddata.DateScriptFieldData.DateScriptLeafFieldData
- getLongValues() - Method in interface org.elasticsearch.index.fielddata.LeafNumericFieldData
-
Get an integer view of the values of this segment.
- getLongValues() - Method in class org.elasticsearch.index.fielddata.LongScriptFieldData.LongScriptLeafFieldData
- getLongValues() - Method in class org.elasticsearch.index.fielddata.plain.LeafDoubleFieldData
- getLongValues() - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData.NanoSecondFieldData
- getLongValuesAsNanos() - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData.NanoSecondFieldData
- getLons() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getLowerBounds() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
- getLowercase() - Method in enum class org.elasticsearch.action.DocWriteRequest.OpType
- getLowercase() - Method in enum class org.elasticsearch.action.DocWriteResponse.Result
- getLowercase() - Method in enum class org.elasticsearch.index.engine.Engine.Operation.TYPE
- getLowFreqMinimumNumberShouldMatchSpec() - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
-
Deprecated.
- getLowWatermarkRaw() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
-
Gets the raw (uninterpreted) low watermark value as found in the settings.
- getLuceneDescription() - Method in class org.elasticsearch.search.profile.ProfileResult
-
Retrieve the lucene description of this query (e.g.
- getLuceneRelation() - Method in enum class org.elasticsearch.common.geo.ShapeRelation
-
Maps ShapeRelation to Lucene's LatLonShapeRelation
- getMapper(String) - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Returns the leaf mapper associated with this field name.
- getMapper(String) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- getMapperParsers() - Method in class org.elasticsearch.index.mapper.MapperRegistry
-
Return a map of the mappers that have been registered.
- getMapperRegistry() - Method in class org.elasticsearch.indices.IndicesModule
-
A registry for all field mappers.
- getMappers() - Method in interface org.elasticsearch.plugins.MapperPlugin
-
Returns additional mapper implementations added by this plugin.
- getMappers(List<MapperPlugin>) - Static method in class org.elasticsearch.indices.IndicesModule
- getMapping() - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Returns the mapping source that this lookup originated from
- getMappingDepthLimit() - Method in class org.elasticsearch.index.IndexSettings
- getMappingDimensionFieldsLimit() - Method in class org.elasticsearch.index.IndexSettings
- getMappingFieldNameLengthLimit() - Method in class org.elasticsearch.index.IndexSettings
- getMappingNestedDocsLimit() - Method in class org.elasticsearch.index.IndexSettings
- getMappingNestedFieldsLimit() - Method in class org.elasticsearch.index.IndexSettings
- getMappings() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getMappings() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- getMappings() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- getMappings() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Deprecated.Use
IndexMetadata.mapping()
instead now that indices have a single type - getMappings() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- getMappings() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getMappings(GetMappingsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the complete mappings of one or more types
- getMappings(GetMappingsRequest, ActionListener<GetMappingsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the complete mappings of one or more types
- GetMappingsAction - Class in org.elasticsearch.action.admin.indices.mapping.get
- GetMappingsRequest - Class in org.elasticsearch.action.admin.indices.mapping.get
- GetMappingsRequest() - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsRequest
- GetMappingsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsRequest
- GetMappingsRequestBuilder - Class in org.elasticsearch.action.admin.indices.mapping.get
- GetMappingsRequestBuilder(ElasticsearchClient, GetMappingsAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsRequestBuilder
- GetMappingsResponse - Class in org.elasticsearch.action.admin.indices.mapping.get
- GetMappingsResponse(ImmutableOpenMap<String, ImmutableOpenMap<String, MappingMetadata>>) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- getMappingTotalFieldsLimit() - Method in class org.elasticsearch.index.IndexSettings
- getMappingVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getMappingVersion() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getMasterActionName(DiscoveryNode) - Method in class org.elasticsearch.action.admin.indices.shrink.TransportResizeAction
- getMasterActionName(DiscoveryNode) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
-
Allows to conditionally return a different master node action name in the case an action gets renamed.
- getMasterAndDataNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get a
Map
of the discovered master and data nodes arranged by their ids - getMasterApplyElapsedMillis() - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- getMasterNode() - Method in class org.elasticsearch.cluster.coordination.PeersResponse
- getMasterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns the master node, or
null
if there is no master node - getMasterNodeId() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get the id of the master node
- getMasterNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get a
Map
of the discovered master nodes arranged by their ids - getMasterService() - Method in class org.elasticsearch.cluster.service.ClusterService
- getMatchedQueries() - Method in class org.elasticsearch.search.SearchHit
-
The set of query and filter names the query matched with.
- getMatchingBytes() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
-
Gets the number of matching bytes the shard copy has with the primary shard.
- getMatchingFieldNames(String) - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Returns a set of field names that match a regex-like pattern All field names in the returned set are guaranteed to resolve to a field
- getMatchingFieldNames(String) - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Returns the names of all mapped fields that match a given pattern All names returned by this method are guaranteed to resolve to a MappedFieldType if passed to
SearchExecutionContext.getFieldType(String)
- getMatchingFieldNames(String) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Returns a set of field names that match a regex-like pattern All field names in the returned set are guaranteed to resolve to a field
- getMatchingFieldNames(String) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- getMatchingIndices(Metadata) - Method in class org.elasticsearch.indices.AssociatedIndexDescriptor
-
Retrieves a list of all indices which match this descriptor's pattern.
- getMatchingIndices(Metadata) - Method in interface org.elasticsearch.indices.IndexPatternMatcher
-
Retrieves a list of all indices which match this descriptor's pattern.
- getMatchingIndices(Metadata) - Method in class org.elasticsearch.indices.SystemIndexDescriptor
-
Retrieves a list of all indices which match this descriptor's pattern.
- getMax() - Method in class org.elasticsearch.index.engine.SegmentsStats.FileStats
- getMax() - Method in class org.elasticsearch.index.shard.IndexLongFieldRange
- getMax() - Method in class org.elasticsearch.index.shard.ShardLongFieldRange
- getMax() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- getMax() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DoubleBounds
- getMax() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.LongBounds
- getMax() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram.ParsedBucket
- getMax() - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- getMax() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- getMax() - Method in interface org.elasticsearch.search.aggregations.metrics.Stats
- getMax() - Method in class org.elasticsearch.search.slice.SliceBuilder
-
The maximum number of slices.
- getMax() - Method in class org.elasticsearch.search.slice.SliceQuery
- getMax() - Method in class org.elasticsearch.search.sort.MinAndMax
-
Return the maximum value.
- getMax() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- getMaxAdjacencyMatrixFilters() - Method in class org.elasticsearch.index.IndexSettings
-
Deprecated.This setting will be removed in 8.0
- getMaxAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram.ParsedBucket
- getMaxAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- getMaxAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- getMaxAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.Stats
- getMaxBuckets() - Method in exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
- getMaxChildren() - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- getMaxChunkSize() - Method in class org.elasticsearch.http.HttpHandlingSettings
- getMaxConcurrentFileChunks() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- getMaxConcurrentGroupRequests() - Method in class org.elasticsearch.search.collapse.CollapseBuilder
-
Returns the amount of group requests that are allowed to be ran concurrently in the inner_hits phase.
- getMaxConcurrentOperations() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- getMaxConcurrentResolvers(Settings) - Static method in class org.elasticsearch.discovery.SeedHostsResolver
- getMaxConcurrentShardRequests() - Method in class org.elasticsearch.action.search.SearchRequest
-
Returns the number of shard requests that should be executed concurrently on a single node.
- getMaxConcurrentSnapshotFileDownloads() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- getMaxConnectionsPerCluster() - Method in class org.elasticsearch.transport.SniffConnectionStrategy.SniffModeInfo
- getMaxContentLength() - Method in class org.elasticsearch.http.HttpHandlingSettings
- getMaxContentLength() - Method in class org.elasticsearch.http.HttpInfo
- getMaxDeterminizedStates() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
-
Returns the maximum automaton states allowed for fuzzy expansion
- getMaxDeterminizedStates() - Method in class org.elasticsearch.search.suggest.completion.RegexOptions
-
Returns the maximum automaton states allowed for fuzzy expansion
- getMaxDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- getMaxDocFreq() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMaxDocFreq() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMaxDocFreq() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the maximum frequency in which words may still appear.
- getMaxDocs() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Maximum number of processed documents.
- getMaxDocvalueFields() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum number of allowed docvalue_fields to retrieve in a search request
- getMaxExpansions() - Method in class org.elasticsearch.common.lucene.search.SpanBooleanQueryRewriteWithMaxClause
- getMaxFileDescriptorCount() - Method in class org.elasticsearch.monitor.process.ProcessProbe
-
Returns the maximum number of file descriptors allowed on the system, or -1 if not supported.
- getMaxFileDescriptors() - Method in class org.elasticsearch.monitor.process.ProcessStats
- getMaxHeaderSize() - Method in class org.elasticsearch.http.HttpHandlingSettings
- getMaximumInnerInterval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- getMaximumRoughEstimateDurationMillis() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- getMaxIndexPrimaryShards() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
the maximum number of primary shards an index has
- getMaxIndexReplication() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
maximum replication factor across the indices.
- getMaxIndexShards() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
the maximum number of shards (primary+replicas) an index has
- getMaxInitialLineLength() - Method in class org.elasticsearch.http.HttpHandlingSettings
- getMaxInnerResultWindow() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the max result window for an individual inner hit definition or top hits aggregation.
- getMaxMergeCount() - Method in class org.elasticsearch.index.MergeSchedulerConfig
-
Returns
maxMergeCount
. - getMaxNgramDiff() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum allowed difference between max and min length of ngram
- getMaxNodeVersion() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns the version of the node with the youngest version in the cluster
- getMaxNumTerms() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMaxNumTokensParsed() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
- getMaxOpenFileDescriptors() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
- getMaxPrimaryShardSize() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
Returns the max primary shard size of the target index
- getMaxQueryTerms() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMaxQueryTerms() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the maximum number of query terms that will be included in any generated query.
- getMaxRefreshListeners() - Method in class org.elasticsearch.index.IndexSettings
-
The maximum number of refresh listeners allows on this shard.
- getMaxRegexLength() - Method in class org.elasticsearch.index.IndexSettings
-
The maximum length of regex string allowed in a regexp query.
- getMaxRescoreWindow() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum rescore window for search requests.
- getMaxResultWindow() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the max result window for search requests, describing the maximum value of from + size on a query.
- getMaxRetries() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Total number of retries attempted for rejections.
- getMaxScore() - Method in class org.elasticsearch.action.search.MaxScoreCollector
-
Get the maximum score.
- getMaxScore() - Method in class org.elasticsearch.search.query.QuerySearchResult
- getMaxScore() - Method in class org.elasticsearch.search.SearchHits
-
The maximum score of this query.
- getMaxScriptFields() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum number of allowed script_fields to retrieve in a search request
- getMaxSeenAutoIdTimestamp() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the maximum auto_id_timestamp of all append-only index requests have been processed by this engine or the auto_id_timestamp received from its primary shard via
Engine.updateMaxUnsafeAutoIdTimestamp(long)
. - getMaxSeenAutoIdTimestamp() - Method in class org.elasticsearch.index.engine.InternalEngine
- getMaxSeenAutoIdTimestamp() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the maximum auto_id_timestamp of all append-only requests have been processed by this shard or the auto_id_timestamp received from the primary via
IndexShard.updateMaxUnsafeAutoIdTimestamp(long)
at the beginning of a peer-recovery or a primary-replica resync. - getMaxSeenAutoIdTimestampOnPrimary() - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- getMaxSegmentsPerShard() - Method in class org.elasticsearch.snapshots.SnapshotInfo.IndexSnapshotDetails
- getMaxSeqNo() - Method in class org.elasticsearch.index.engine.Engine
- getMaxSeqNo() - Method in class org.elasticsearch.index.engine.InternalEngine
- getMaxSeqNo() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getMaxSeqNo() - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
The maximum sequence number issued so far.
- getMaxSeqNo() - Method in class org.elasticsearch.index.seqno.SeqNoStats
-
the maximum sequence number seen so far
- getMaxSeqNo() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the max seq_no of translog operations found in this translog.
- getMaxSeqNoOfUpdatesOrDeletes() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteReplicaRequest
- getMaxSeqNoOfUpdatesOrDeletes() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the maximum sequence number of either update or delete operations have been processed in this engine or the sequence number from
Engine.advanceMaxSeqNoOfUpdatesOrDeletes(long)
. - getMaxSeqNoOfUpdatesOrDeletes() - Method in class org.elasticsearch.index.engine.InternalEngine
- getMaxSeqNoOfUpdatesOrDeletes() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getMaxSeqNoOfUpdatesOrDeletes() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the maximum sequence number of either update or delete operations have been processed in this shard or the sequence number from
IndexShard.advanceMaxSeqNoOfUpdatesOrDeletes(long)
. - getMaxShingleDiff() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum allowed difference between max and min shingle_size
- getMaxShingleSize() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
- getMaxSlicesPerScroll() - Method in class org.elasticsearch.index.IndexSettings
-
The maximum number of slices allowed in a scroll request.
- getMaxSocketConnections() - Method in class org.elasticsearch.transport.ProxyConnectionStrategy.ProxyModeInfo
- getMaxTaskWaitTime() - Method in class org.elasticsearch.cluster.service.MasterService
-
Returns the maximum wait time for tasks in the queue
- getMaxTaskWaitTime() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
-
Returns the waiting time of the first task in the queue
- getMaxTermFreq() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMaxTermFrequency() - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
-
Deprecated.
- getMaxTermsCount() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum number of terms that can be used in a Terms Query request
- getMaxThreadCount() - Method in class org.elasticsearch.index.MergeSchedulerConfig
-
Returns
maxThreadCount
. - getMaxTokenCount() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum number of tokens that can be produced
- getMaxUnsafeAutoIdTimestamp() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Returns the max timestamp that is used to de-optimize documents with auto-generated IDs in the engine.
- getMaxUpTime() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
-
The maximum uptime of a node in the cluster
- getMaxWordLen() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMaxWordLen() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the maximum word length above which words will be ignored.
- getMaxWordLength() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getMbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getMbPerSec(Thread, MergePolicy.OneMerge) - Static method in class org.apache.lucene.index.OneMergeHelper
-
The current MB per second rate limit for this merge.
- getMBPerSec() - Method in class org.elasticsearch.common.util.CombinedRateLimiter
- getMedianAbsoluteDeviation() - Method in class org.elasticsearch.search.aggregations.metrics.InternalMedianAbsoluteDeviation
- getMedianAbsoluteDeviation() - Method in interface org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviation
-
Returns the median absolute deviation statistic computed for this aggregation
- getMedianAbsoluteDeviation() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedMedianAbsoluteDeviation
- getMega() - Method in class org.elasticsearch.common.unit.SizeValue
- getMegaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- getMem() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
- getMem() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getMem() - Method in class org.elasticsearch.monitor.jvm.JvmStats
- getMem() - Method in class org.elasticsearch.monitor.os.OsStats
- getMem() - Method in class org.elasticsearch.monitor.process.ProcessStats
- getMember() - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns the injected constructor, field, or method.
- getMembersInjector() - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
-
Returns the looked up members injector.
- getMembersInjector(Class<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- getMembersInjector(Class<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
Returns the members injector used to inject dependencies into methods and fields on instances of the given type
T
. - getMembersInjector(Class<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the members injector used to inject dependencies into methods and fields on instances of the given type
T
. - getMembersInjector(Class<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- getMembersInjector(Class<T>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Returns the members injector used to inject dependencies into methods and fields on instances of the given type
T
. - getMembersInjector(TypeLiteral<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- getMembersInjector(TypeLiteral<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
Returns the members injector used to inject dependencies into methods and fields on instances of the given type
T
. - getMembersInjector(TypeLiteral<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the members injector used to inject dependencies into methods and fields on instances of the given type
T
. - getMembersInjector(TypeLiteral<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- getMembersInjector(TypeLiteral<T>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Returns the members injector used to inject dependencies into methods and fields on instances of the given type
T
. - getMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getMemoryControlGroup() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
-
The control group for the
memory
subsystem. - getMemoryInBytes() - Method in class org.elasticsearch.index.engine.Segment
-
Estimation of the memory usage used by a segment.
- getMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the memory usage used by a segment.
- getMemoryLimitInBytes() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
-
The maximum amount of user memory (including file cache).
- getMemoryPools() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getMemorySize() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- getMemorySize() - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- getMemorySize() - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- getMemorySizeInBytes() - Method in class org.elasticsearch.index.cache.bitset.ShardBitsetFilterCache
- getMemorySizeInBytes() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- getMemorySizeInBytes() - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- getMemorySizeInBytes() - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- getMemoryUsageInBytes() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
-
The total current memory usage by processes in the cgroup (in bytes).
- getMercatorHeight() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Geometry
-
Returns the height of the bounding box diagonal in the spherical Mercator projection (meters)
- getMercatorHeight() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getMercatorWidth() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Geometry
-
Returns the width of the bounding box diagonal in the spherical Mercator projection (meters)
- getMercatorWidth() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getMerge() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getMerge() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.AllFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.DateFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.FieldMapper
-
Returns a
FieldMapper.Builder
to be used for merging and serialization Implement as follows:return new MyBuilder(simpleName()).init(this);
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.IpFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- getMergeBuilder() - Method in class org.elasticsearch.index.mapper.TextFieldMapper
- getMergedSegments() - Method in class org.elasticsearch.index.merge.OnGoingMerge
-
The list of segments that are being merged.
- getMergeId() - Method in class org.elasticsearch.index.engine.Segment
-
If set, a string representing that the segment is part of a merge, with the value representing the group of segments that represent this merge.
- getMergePolicy() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the
MergePolicy
for the enginesIndexWriter
- getMergePolicy() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the merge policy that should be used for this index.
- getMergeSchedulerConfig() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the
MergeSchedulerConfig
- getMergeStats() - Method in class org.elasticsearch.index.engine.Engine
- getMergeStats() - Method in class org.elasticsearch.index.engine.InternalEngine
- getMessage() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The failure message.
- getMessage() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
-
The failure message.
- getMessage() - Method in class org.elasticsearch.bootstrap.BootstrapCheck.BootstrapCheckResult
- getMessage() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
- getMessage() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
- getMessage() - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand
-
Returns any feedback the command wants to provide for logging.
- getMessage() - Method in class org.elasticsearch.cluster.routing.allocation.FailedShard
-
The failure message, if available, explaining why the shard failed.
- getMessage() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Returns optional details explaining the reasons.
- getMessage() - Method in exception org.elasticsearch.common.inject.ConfigurationException
- getMessage() - Method in exception org.elasticsearch.common.inject.CreationException
- getMessage() - Method in exception org.elasticsearch.common.inject.ProvisionException
- getMessage() - Method in class org.elasticsearch.common.inject.spi.Message
-
Gets the error message text.
- getMessage() - Method in exception org.elasticsearch.common.ValidationException
- getMessage() - Method in enum class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
- getMessagePattern() - Method in class org.elasticsearch.common.logging.ESLogMessage
- getMessages() - Method in class org.elasticsearch.common.inject.internal.Errors
- getMessagesFromThrowable(Throwable) - Static method in class org.elasticsearch.common.inject.internal.Errors
- getMessagesReceived() - Method in class org.elasticsearch.transport.StatsTracker
- getMessagesSent() - Method in class org.elasticsearch.transport.StatsTracker
- getMeta() - Method in class org.elasticsearch.index.mapper.Mapping
-
Returns the meta section for the current mapping
- getMetadata() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction.RepositoriesResult
- getMetadata() - Method in class org.elasticsearch.cluster.ClusterState
- getMetadata() - Method in class org.elasticsearch.cluster.metadata.DataStream
- getMetadata() - Method in exception org.elasticsearch.ElasticsearchException
- getMetadata() - Method in class org.elasticsearch.gateway.GatewayMetaState
- getMetadata() - Method in class org.elasticsearch.index.IndexService
- getMetadata() - Method in class org.elasticsearch.ingest.IngestDocument
-
Does the same thing as
IngestDocument.extractMetadata()
but does not mutate the map. - getMetadata() - Method in class org.elasticsearch.ingest.Pipeline
- getMetadata() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getMetadata() - Method in class org.elasticsearch.repositories.FilterRepository
- getMetadata() - Method in interface org.elasticsearch.repositories.Repository
-
Returns metadata about this repository.
- getMetadata() - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- getMetadata() - Method in interface org.elasticsearch.search.aggregations.Aggregation
-
Get the optional byte array metadata that was set on the aggregation
- getMetadata() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Return any associated metadata with this
AggregationBuilder
. - getMetadata() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- getMetadata() - Method in class org.elasticsearch.search.aggregations.ParsedAggregation
- getMetadata(String) - Method in exception org.elasticsearch.ElasticsearchException
-
Returns the list of metadata values for the given key or
null
if no metadata for the given key exists. - getMetadata(IndexCommit) - Method in class org.elasticsearch.index.store.Store
-
Returns a new MetadataSnapshot for the given commit.
- getMetadata(IndexCommit, boolean) - Method in class org.elasticsearch.index.store.Store
-
Returns a new MetadataSnapshot for the given commit.
- getMetadata(Index) - Method in class org.elasticsearch.gateway.PriorityComparator
- getMetadataDeleteIndexService() - Method in class org.elasticsearch.cluster.ClusterModule
- getMetadataFields() - Method in class org.elasticsearch.index.get.GetResult
- getMetadataFields() - Method in class org.elasticsearch.search.SearchHit
- getMetadataFields(Version) - Method in class org.elasticsearch.indices.IndicesService
-
Returns the registered metadata field names for the provided compatible
Version
. - getMetadataKeys() - Method in exception org.elasticsearch.ElasticsearchException
-
Returns a set of all metadata keys on this exception
- getMetadataMapper(String) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- getMetadataMapperByClass(Class<T>) - Method in class org.elasticsearch.index.mapper.Mapping
-
Get the metadata mapper with the given class.
- getMetadataMapperParsers(Version) - Method in class org.elasticsearch.index.mapper.MapperRegistry
-
Return a map of the meta mappers that have been registered.
- getMetadataMappers() - Method in interface org.elasticsearch.plugins.MapperPlugin
-
Returns additional metadata mapper implementations added by this plugin.
- getMetadataMappers(List<MapperPlugin>) - Static method in class org.elasticsearch.indices.IndicesModule
- getMetadataSnapshot() - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshot
- getMetConditions() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- getMethod() - Method in class org.elasticsearch.common.inject.internal.ProviderMethod
- getMethod() - Method in class org.elasticsearch.rest.RestHandler.Route
- getMethod() - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig
- getMetrics() - Method in class org.elasticsearch.ingest.Pipeline
-
The metrics associated with this pipeline.
- getMetricType() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
-
If field is a time series metric field, returns its metric type
- getMillis() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getMillisOfDay() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getMillisOfSecond() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getMin() - Method in class org.elasticsearch.index.engine.SegmentsStats.FileStats
- getMin() - Method in class org.elasticsearch.index.shard.IndexLongFieldRange
- getMin() - Method in class org.elasticsearch.index.shard.ShardLongFieldRange
- getMin() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DoubleBounds
- getMin() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.LongBounds
- getMin() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram.ParsedBucket
- getMin() - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- getMin() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- getMin() - Method in interface org.elasticsearch.search.aggregations.metrics.Stats
- getMin() - Method in class org.elasticsearch.search.sort.MinAndMax
-
Return the minimum value.
- getMin() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- getMinAsString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram.ParsedBucket
- getMinAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- getMinAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- getMinAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.Stats
- getMinDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- getMinDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- getMinDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
-
The minimum numbers of documents a bucket must have in order to survive the final reduction.
- getMinDocFreq() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMinDocFreq() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMinDocFreq() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the frequency at which words will be ignored which do not occur in at least this many docs.
- getMinFileGeneration() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the minimum file generation referenced by the translog
- getMinGenerationForSeqNo(long) - Method in class org.elasticsearch.index.translog.Translog
-
Gets the minimum generation that could contain any sequence number after the specified sequence number, or the current generation if there is no generation that could any such sequence number.
- getMinimalDaysInFirstWeek(Locale) - Method in class org.elasticsearch.common.time.IsoCalendarDataProvider
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownMetadataCustom
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.IndexGraveyardDiff
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata.NodeShutdownMetadataDiff
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
- getMinimalSupportedVersion() - Method in interface org.elasticsearch.cluster.NamedDiff
-
The minimal version of the recipient this custom object can be sent to
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.RepositoryCleanupInProgress
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.RestoreInProgress
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- getMinimalSupportedVersion() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- getMinimalSupportedVersion() - Method in interface org.elasticsearch.common.io.stream.VersionedNamedWriteable
-
The minimal version of the recipient this object can be sent to
- getMinimalSupportedVersion() - Method in class org.elasticsearch.ingest.IngestMetadata
- getMinimalSupportedVersion() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- getMinimalSupportedVersion() - Method in class org.elasticsearch.script.ScriptMetadata
- getMinimalSupportedVersion() - Method in class org.elasticsearch.upgrades.FeatureMigrationResults
- getMinimalSupportedVersion() - Method in class org.elasticsearch.upgrades.FeatureMigrationResults.ResultsDiff
- getMinimalSupportedVersion() - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskParams
- getMinimumIndexVersion() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.FeatureUpgradeStatus
- getMinimumIntervalExpression() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- getMinimumMasterNodesOnPublishingMaster() - Method in class org.elasticsearch.cluster.ClusterState
-
The node-level `discovery.zen.minimum_master_nodes` setting on the master node that published this cluster state, for use in rolling upgrades from 6.x to 7.x.
- getMinimumNodeVersion() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getMinimumNodeVersionMessage(String) - Method in class org.elasticsearch.indices.SystemIndexDescriptor
-
Gets a standardized message when the node contains a data or master node whose version is less than that of the minimum supported version of this descriptor and its prior descriptors.
- getMinimumShouldMatch() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
Number of terms that must match the generated query expressed in the common syntax for minimum should match.
- getMinimumShouldMatchField() - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- getMinimumShouldMatchScript() - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- getMinimumTerm() - Method in class org.elasticsearch.cluster.coordination.JoinRequest
- getMinIndexPrimaryShards() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
the minimum number of primary shards an index has
- getMinIndexReplication() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
minimum replication factor across the indices.
- getMinIndexShards() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
the minimum number of shards (primary+replicas) an index has
- getMinMaxOrNull(SearchExecutionContext, FieldSortBuilder) - Static method in class org.elasticsearch.search.sort.FieldSortBuilder
- getMinNodeVersion() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns the version of the node with the oldest version in the cluster.
- getMinOpenFileDescriptors() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
- getMinRetainedSeqNo() - Method in class org.elasticsearch.index.engine.Engine
-
Gets the minimum retained sequence number for this engine.
- getMinRetainedSeqNo() - Method in class org.elasticsearch.index.engine.InternalEngine
-
Returns the minimum seqno that is retained in the Lucene index.
- getMinRetainedSeqNo() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getMinRetainedSeqNo() - Method in class org.elasticsearch.index.shard.IndexShard
-
Gets the minimum retained sequence number for this engine.
- getMinScore() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- getMinScore() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- getMinScore() - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- getMinShingleSize() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
- getMinTermFreq() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMinTermFreq() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the frequency below which terms will be ignored in the source doc.
- getMinTermFrequency() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMinute() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getMinuteOfDay() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getMinuteOfHour() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getMinWordLen() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMinWordLen() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns the minimum word length below which words will be ignored.
- getMinWordLength() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getMissCount() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
The number of lookups in the cache that failed to retrieve a
DocIdSet
. - getMissCount() - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- getMisses() - Method in class org.elasticsearch.common.cache.Cache.CacheStats
- getMissing() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction.RepositoriesResult
- getMissing() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- getMissing() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- getMissingCount() - Method in class org.elasticsearch.index.get.GetStats
- getMissingTime() - Method in class org.elasticsearch.index.get.GetStats
- getMissingTimeInMillis() - Method in class org.elasticsearch.index.get.GetStats
- getModeInfo() - Method in class org.elasticsearch.transport.ProxyConnectionStrategy
- getModeInfo() - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- getModeInfo() - Method in class org.elasticsearch.transport.RemoteConnectionStrategy
- getModeInfo() - Method in class org.elasticsearch.transport.SniffConnectionStrategy
- getModifiers() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
- getModule(Iterable<? extends Element>) - Static method in class org.elasticsearch.common.inject.spi.Elements
-
Returns the module composed of
elements
. - getModuleBundles(Path) - Static method in class org.elasticsearch.plugins.PluginsService
-
Get bundles for plugins installed in the given modules directory.
- getModuleInfos() - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
-
Returns an ordered list based on modules name
- getModulePolicyInfo(Path, Path) - Static method in class org.elasticsearch.bootstrap.PolicyUtil
-
Return info about the security policy for a module.
- getMonitorService() - Method in class org.elasticsearch.node.NodeService
- getMonth() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getMonthOfYear() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getMonthValue() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getMoreLikeFields() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getMount() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- getMoveDecision() - Method in class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
-
Gets the move decision for the shard.
- getMovingAverageModelParserRegistry() - Method in class org.elasticsearch.search.SearchModule
-
The registry of
MovAvgModel
s. - getMovingAverageModels() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
MovAvgModel
s defined by this plugin. - getMultiTermComponent(Version) - Method in enum class org.elasticsearch.indices.analysis.PreBuiltTokenizers
- getMultiValueMode() - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- getName() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- getName() - Method in class org.elasticsearch.action.admin.cluster.stats.IndexFeatureStats
-
Return the name of the field type.
- getName() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeTokenList
- getName() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.CharFilteredText
- getName() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedIndexAbstraction
- getName() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
The name of the field.
- getName() - Method in class org.elasticsearch.action.fieldcaps.IndexFieldCapabilities
- getName() - Method in class org.elasticsearch.action.search.RestClosePointInTimeAction
- getName() - Method in class org.elasticsearch.action.search.RestOpenPointInTimeAction
- getName() - Method in class org.elasticsearch.cluster.metadata.DataStream
- getName() - Method in class org.elasticsearch.cluster.metadata.DataStream.TimestampField
- getName() - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
-
Returns the name of this data stream alias.
- getName() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- getName() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.ConcreteIndex
- getName() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- getName() - Method in interface org.elasticsearch.cluster.metadata.IndexAbstraction
- getName() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- getName() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
The name of the node.
- getName() - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
- getName() - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
- getName() - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- getName() - Method in class org.elasticsearch.common.document.DocumentField
-
The name of the field.
- getName() - Method in interface org.elasticsearch.common.geo.GeoFormatterFactory.FormatterFactory
-
Format name
- getName() - Method in class org.elasticsearch.common.geo.SimpleVectorTileFormatter
- getName() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
- getName() - Method in class org.elasticsearch.index.analysis.PreConfiguredAnalysisComponent
-
The name of the analysis component in the API.
- getName() - Method in class org.elasticsearch.index.engine.Segment
- getName() - Method in class org.elasticsearch.index.Index
- getName() - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.ExponentialDecayFunctionBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.GaussDecayFunctionBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
The name of this score function.
- getName() - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- getName() - Method in class org.elasticsearch.index.query.functionscore.WeightBuilder
- getName() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getName() - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Returns the name that identifies uniquely the query
- getName() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- getName() - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- getName() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
- getName() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- getName() - Method in class org.elasticsearch.indices.SystemIndices.Feature
- getName() - Method in class org.elasticsearch.ingest.IngestStats.ProcessorStat
- getName() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
- getName() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
- getName() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- getName() - Method in class org.elasticsearch.monitor.os.OsInfo
- getName() - Method in class org.elasticsearch.plugins.PluginDescriptor
-
The name of the plugin.
- getName() - Method in class org.elasticsearch.plugins.SearchPlugin.SearchExtensionSpec
-
The name of the thing being specified as a
ParseField
. - getName() - Method in class org.elasticsearch.repositories.IndexId
-
The name of the index.
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.dangling.RestDeleteDanglingIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.dangling.RestImportDanglingIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.dangling.RestListDanglingIndicesAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestAddVotingConfigExclusionAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestCancelTasksAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestCleanupRepositoryAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClearVotingConfigExclusionsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestCloneSnapshotAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterAllocationExplainAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterGetSettingsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterHealthAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterRerouteAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterSearchShardsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStatsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterUpdateSettingsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestCreateSnapshotAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteRepositoryAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteSnapshotAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteStoredScriptAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetFeatureUpgradeStatusAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetRepositoriesAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetScriptContextAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetScriptLanguageAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetSnapshotsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetStoredScriptAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetTaskAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestListTasksAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesHotThreadsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesInfoAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesStatsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesUsageAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestPendingClusterTasksAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestPostFeatureUpgradeAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestPutRepositoryAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestPutStoredScriptAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestReloadSecureSettingsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestRemoteClusterInfoAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestResetFeatureStateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestRestoreSnapshotAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestSnapshotsStatusAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestSnapshottableFeaturesAction
- getName() - Method in class org.elasticsearch.rest.action.admin.cluster.RestVerifyRepositoryAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestAddIndexBlockAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeIndexDiskUsageAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestClearIndicesCacheAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestCloseIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestCreateIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteComponentTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteComposableIndexTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestFieldUsageStatsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestFlushAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestForceMergeAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetAliasesAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetComponentTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetComposableIndexTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetFieldMappingAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndexTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndicesAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetMappingAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetSettingsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndexDeleteAliasesAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndexPutAliasAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesAliasesAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesSegmentsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesShardStoresAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesStatsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestOpenIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestPutComponentTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestPutComposableIndexTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestPutIndexTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestPutMappingAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestRecoveryAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestRefreshAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestCloneIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestShrinkIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestSplitIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestResolveIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestRolloverIndexAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestSimulateIndexTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestSimulateTemplateAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestSyncedFlushAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestUpdateSettingsAction
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestUpgradeActionDeprecated
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestUpgradeStatusActionDeprecated
- getName() - Method in class org.elasticsearch.rest.action.admin.indices.RestValidateQueryAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestAliasAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestAllocationAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestCatAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestCatRecoveryAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestCountAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestFielddataAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestHealthAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestIndicesAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestMasterAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestNodeAttrsAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestNodesAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestPendingClusterTasksAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestPluginsAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestRepositoriesAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestSegmentsAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestShardsAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestSnapshotAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestTasksAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestTemplatesAction
- getName() - Method in class org.elasticsearch.rest.action.cat.RestThreadPoolAction
- getName() - Method in class org.elasticsearch.rest.action.datastreams.RestModifyDataStreamsAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestBulkAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestDeleteAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestGetAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestGetSourceAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestIndexAction.AutoIdHandler
- getName() - Method in class org.elasticsearch.rest.action.document.RestIndexAction.CreateHandler
- getName() - Method in class org.elasticsearch.rest.action.document.RestIndexAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestMultiGetAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestMultiTermVectorsAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestTermVectorsAction
- getName() - Method in class org.elasticsearch.rest.action.document.RestUpdateAction
- getName() - Method in class org.elasticsearch.rest.action.ingest.RestDeletePipelineAction
- getName() - Method in class org.elasticsearch.rest.action.ingest.RestGetPipelineAction
- getName() - Method in class org.elasticsearch.rest.action.ingest.RestPutPipelineAction
- getName() - Method in class org.elasticsearch.rest.action.ingest.RestSimulatePipelineAction
- getName() - Method in class org.elasticsearch.rest.action.RestFieldCapabilitiesAction
- getName() - Method in class org.elasticsearch.rest.action.RestMainAction
- getName() - Method in class org.elasticsearch.rest.action.search.RestClearScrollAction
- getName() - Method in class org.elasticsearch.rest.action.search.RestCountAction
- getName() - Method in class org.elasticsearch.rest.action.search.RestExplainAction
- getName() - Method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
- getName() - Method in class org.elasticsearch.rest.action.search.RestSearchAction
- getName() - Method in class org.elasticsearch.rest.action.search.RestSearchScrollAction
- getName() - Method in class org.elasticsearch.rest.BaseRestHandler
- getName() - Method in class org.elasticsearch.rest.BaseRestHandler.Wrapper
- getName() - Method in class org.elasticsearch.rest.RestHeaderDefinition
- getName() - Method in class org.elasticsearch.script.field.EmptyField
- getName() - Method in interface org.elasticsearch.script.field.Field
-
Returns the name of this field.
- getName() - Method in class org.elasticsearch.script.ScriptContextInfo
- getName() - Method in enum class org.elasticsearch.script.ScriptType
- getName() - Method in interface org.elasticsearch.search.aggregations.Aggregation
- getName() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Return this aggregation's name.
- getName() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- getName() - Method in class org.elasticsearch.search.aggregations.ParsedAggregation
- getName() - Method in enum class org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Return the english-formatted name of the GapPolicy
- getName() - Method in enum class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.SeasonalityType
-
Return the english-formatted name of the SeasonalityType
- getName() - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
-
Return this aggregation's name.
- getName() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry.RegistryKey
- getName() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
-
The name of the field highlighted.
- getName() - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- getName() - Method in class org.elasticsearch.search.profile.query.CollectorResult
- getName() - Method in class org.elasticsearch.search.profile.query.InternalProfileCollector
- getName() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- getName() - Method in class org.elasticsearch.snapshots.SnapshotId
-
Returns snapshot name
- getName() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- getName() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- getNamedAnalyzer(String) - Method in class org.elasticsearch.index.mapper.MapperService
- getNamedAnalyzer(String) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Returns an existing registered analyzer that should NOT be closed when finished being used.
- getNamedAnalyzer(String) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- getNamedContexts(List<CharSequence>) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
-
Maps an output context list to a map of context mapping names and their values see
ContextMappings.TypedContextField
- getNamedWriteableRegistry() - Method in class org.elasticsearch.action.search.SearchTransportService
- getNamedWriteableRegistry() - Method in class org.elasticsearch.client.node.NodeClient
- getNamedWriteables() - Static method in class org.elasticsearch.cluster.ClusterModule
- getNamedWriteables() - Static method in class org.elasticsearch.common.network.NetworkModule
- getNamedWriteables() - Method in class org.elasticsearch.indices.IndicesModule
- getNamedWriteables() - Method in class org.elasticsearch.plugins.Plugin
-
Returns parsers for
NamedWriteable
this plugin will use over the transport protocol. - getNamedWriteables() - Method in class org.elasticsearch.search.SearchModule
- getNamedWriteables() - Static method in class org.elasticsearch.upgrades.SystemIndexMigrationExecutor
- getNamedXContent() - Method in class org.elasticsearch.plugins.Plugin
-
Returns parsers for named objects this plugin will parse from
XContentParser.namedObject(Class, String, Object)
. - getNamedXContentParsers() - Method in interface org.elasticsearch.plugins.spi.NamedXContentProvider
- getNamedXContentParsers() - Static method in class org.elasticsearch.upgrades.SystemIndexMigrationExecutor
- getNamedXContents() - Static method in class org.elasticsearch.common.network.NetworkModule
- getNamedXContents() - Static method in class org.elasticsearch.indices.IndicesModule
- getNamedXContents() - Method in class org.elasticsearch.search.SearchModule
- getNamedXWriteables() - Static method in class org.elasticsearch.cluster.ClusterModule
- getNameResolvedAt() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
The instant at which the name provided by the user was resolved
- getNames() - Method in class org.elasticsearch.common.xcontent.ParseFieldRegistry
-
All the names under which values are registered.
- getNamespace(Setting<T>) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
-
Returns the namespace for a concrete setting.
- getNamespaces(Settings) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
-
Returns distinct namespaces for the given settings
- getNano() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getNeighbours() - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
-
Returns the precision levels at which geohash cells neighbours are considered
- getNestedDocuments() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- getNestedFilter() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Deprecated.set nested sort with
FieldSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withFieldSortBuilder.getNestedSort()
- getNestedFilter() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Deprecated.set nested sort with
GeoDistanceSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withGeoDistanceSortBuilder.getNestedSort()
- getNestedFilter() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Deprecated.set nested sort with
ScriptSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withScriptSortBuilder.getNestedSort()
- getNestedIdentity() - Method in class org.elasticsearch.search.SearchHit
-
If this is a nested hit then nested reference information is returned otherwise
null
is returned. - getNestedMappers() - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Returns all nested object mappers
- getNestedParent(String) - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Given a nested object path, returns the path to its nested parent In particular, if a nested field `foo` contains an object field `bar.baz`, then calling this method with `foo.bar.baz` will return the path `foo`, skipping over the object-but-not-nested `foo.bar`
- getNestedParent(String) - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Given a nested object path, returns the path to its nested parent In particular, if a nested field `foo` contains an object field `bar.baz`, then calling this method with `foo.bar.baz` will return the path `foo`, skipping over the object-but-not-nested `foo.bar`
- getNestedParentMappers() - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Returns all nested object mappers which contain further nested object mappers Used by BitSetProducerWarmer
- getNestedPath() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Deprecated.set nested sort with
FieldSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withFieldSortBuilder.getNestedSort()
- getNestedPath() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Deprecated.set nested sort with
GeoDistanceSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withGeoDistanceSortBuilder.getNestedSort()
- getNestedPath() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Deprecated.set nested sort with
ScriptSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withScriptSortBuilder.getNestedSort()
- getNestedScope(String) - Method in class org.elasticsearch.index.mapper.MappingLookup
- getNestedSort() - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
- getNestedSort() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Returns the
NestedSortBuilder
- getNestedSort() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns the
NestedSortBuilder
- getNestedSort() - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- getNestedSort() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Returns the
NestedSortBuilder
- getNetNewSystemIndexPredicate() - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- getNetworkMessageSize() - Method in class org.elasticsearch.transport.Header
- getNewIndex() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
-
Returns the name of the index that the request alias currently points to
- getNewIndexName() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- getNewState() - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- getNextClusterStateToProcess() - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
Gets the next committed state to process.
- getNextGatherOffset(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForDoubles
- getNextGatherOffset(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForFloats
- getNextGatherOffset(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForLongs
- getNextGatherOffset(long) - Method in class org.elasticsearch.search.sort.BucketedSort
-
Get the next index that should be "gathered" for a bucket rooted at
rootIndex
. - getNode() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
-
Node the store belongs to
- getNode() - Method in class org.elasticsearch.action.search.SearchContextIdForNode
- getNode() - Method in class org.elasticsearch.action.support.nodes.BaseNodeResponse
-
The node this information relates to.
- getNode() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
-
Get the node that this decision is for.
- getNode() - Method in class org.elasticsearch.discovery.zen.ElectMasterService.MasterCandidate
- getNode() - Method in class org.elasticsearch.discovery.zen.MembershipAction.JoinRequest
- getNode() - Method in class org.elasticsearch.transport.TcpTransport.NodeChannels
- getNode() - Method in interface org.elasticsearch.transport.Transport.Connection
-
The node this connection is associated with
- getNodeDecision() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
-
Gets the
AllocationDecision
for allocating to this node. - getNodeDecisions() - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Gets the sorted list of individual node-level decisions that went into making the ultimate decision whether to allocate or move the shard.
- getNodeDescriptions() - Method in class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
- getNodeEnvironment() - Method in class org.elasticsearch.node.Node
-
Returns the
NodeEnvironment
instance of this node - getNodeFailures() - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
-
The list of node failures exception.
- getNodeId() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- getNodeId() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
-
Returns node id of the node where snapshot is currently running
- getNodeId() - Method in exception org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult.Failure
- getNodeId() - Method in class org.elasticsearch.action.admin.indices.dangling.DanglingIndexInfo
- getNodeId() - Method in exception org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult.Failure
- getNodeId() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- getNodeId() - Method in class org.elasticsearch.action.TaskOperationFailure
- getNodeId() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfigExclusion
- getNodeId() - Method in class org.elasticsearch.cluster.DiskUsage
- getNodeId() - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- getNodeId() - Method in class org.elasticsearch.gateway.PersistedClusterStateService
- getNodeId() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- getNodeId() - Method in class org.elasticsearch.search.SearchShardTarget
- getNodeId() - Method in class org.elasticsearch.tasks.TaskId
- getNodeIds() - Method in class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
- getNodeIds() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfiguration
- getNodeIdText() - Method in class org.elasticsearch.search.SearchShardTarget
- getNodeLeastAvailableDiskUsages() - Method in class org.elasticsearch.cluster.ClusterInfo
-
Returns a node id to disk usage mapping for the path that has the least available space on the node.
- getNodeLockId() - Method in class org.elasticsearch.env.NodeEnvironment
- getNodeMostAvailableDiskUsages() - Method in class org.elasticsearch.cluster.ClusterInfo
-
Returns a node id to disk usage mapping for the path that has the most available space on the node.
- getNodeName() - Method in class org.elasticsearch.action.main.MainResponse
- getNodeName() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfigExclusion
- getNodeName() - Method in class org.elasticsearch.cluster.DiskUsage
- getNodeName() - Method in class org.elasticsearch.cluster.service.ClusterService
-
The name of this node.
- getNodeName() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the current node name
- getNodeNames() - Method in class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
- getNodeResponseTracker() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- getNodes() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- getNodes() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- getNodes() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
Get the successful node responses.
- getNodes() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- getNodes() - Method in class org.elasticsearch.cluster.ClusterState
- getNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get a
Map
of the discovered nodes arranged by their ids - getNodes() - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
-
Gets the current set of nodes involved in node fault detection.
- getNodesAllocatedByDepth() - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
- getNodeSeen() - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- getNodeSettings() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the node settings.
- getNodesMap() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
Lazily build and get a map of Node ID to node response.
- getNodesResizedByDepth() - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
- getNodesStats() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- getNodeStatistics(String) - Method in class org.elasticsearch.node.ResponseCollectorService
-
Optionally return a
NodeStatistics
for the given nodeid, if response information exists for the given node. - getNoMasterBlock() - Method in class org.elasticsearch.cluster.coordination.NoMasterBlockService
- getNonHeapCommitted() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
- getNonHeapInit() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- getNonHeapMax() - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- getNonHeapUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
- getNoops() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getNoops() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Number of noops (skipped bulk items) as part of this request.
- getNoopUpdateCount() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
- getNoRefresh() - Method in class org.elasticsearch.common.util.SingleObjectCache
-
Return the potentially stale cached entry.
- getNormalizer(String) - Method in class org.elasticsearch.index.analysis.IndexAnalyzers
-
Returns a normalizer mapped to the given name or
null
if not present - getNorms() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- getNormsBytes() - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats.PerFieldDiskUsage
- getNormsMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the norms memory usage by a segment.
- getNullValue() - Method in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper
- getNullValue() - Method in class org.elasticsearch.index.mapper.DateFieldMapper
- getNumberOfCommitted() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- getNumberOfDataNodes() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getNumberOfDataNodes() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getNumberOfDelayedUnassigned(ClusterState) - Static method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Returns the number of shards that are unassigned and currently being delayed.
- getNumberOfElapsedPeriods() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup.CpuStat
-
The number of elapsed periods.
- getNumberOfInFlightFetch() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getNumberOfInFlightFetches() - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
- getNumberOfInFlightFetches() - Method in interface org.elasticsearch.cluster.routing.allocation.ExistingShardsAllocator
- getNumberOfInFlightFetches() - Method in class org.elasticsearch.gateway.AsyncShardFetch
-
Returns the number of async fetches that are currently ongoing.
- getNumberOfInFlightFetches() - Method in class org.elasticsearch.gateway.GatewayAllocator
- getNumberOfNodes() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getNumberOfNodes() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getNumberOfPendingTasks() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getNumberOfPendingTasks() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- getNumberOfReplicas() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getNumberOfReplicas() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getNumberOfReplicas() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the number of replicas this index has.
- getNumberOfSearch() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- getNumberOfShards() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getNumberOfShards() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the number of shards this index has.
- getNumberOfSignificantValueDigits() - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.Hdr
- getNumberOfTasksOnNode(String, String) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- getNumberOfTimesThrottled() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup.CpuStat
-
The number of times tasks in the control group have been throttled.
- getNumBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- getNumBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- getNumChannels() - Static method in class org.elasticsearch.rest.action.RestCancellableNodeClient
-
Returns the number of channels tracked globally.
- getNumConnections() - Method in class org.elasticsearch.transport.ConnectionProfile
-
Returns the total number of connections for this profile
- getNumConnectionsPerType(TransportRequestOptions.Type) - Method in class org.elasticsearch.transport.ConnectionProfile
-
Returns the number of connections per type for this profile.
- getNumDocs() - Method in class org.elasticsearch.index.engine.CommitStats
-
Returns the number of documents in the in this commit
- getNumDocs() - Method in class org.elasticsearch.index.engine.Segment
- getNumDocs() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns the number of documents in this store snapshot
- getNumDocs(SegmentInfos) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Returns the number of documents in the index referenced by this
SegmentInfos
- getNumericType() - Method in class org.elasticsearch.index.fielddata.BooleanScriptFieldData
- getNumericType() - Method in class org.elasticsearch.index.fielddata.DateScriptFieldData
- getNumericType() - Method in class org.elasticsearch.index.fielddata.DoubleScriptFieldData
- getNumericType() - Method in class org.elasticsearch.index.fielddata.IndexNumericFieldData
-
The numeric type of this number.
- getNumericType() - Method in class org.elasticsearch.index.fielddata.LongScriptFieldData
- getNumericType() - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData
- getNumericType() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Returns the numeric type that values should translated to or null if the original numeric type should be preserved.
- getNumericValue(String) - Method in class org.elasticsearch.index.mapper.LuceneDocument
- getNumFailedAllocations() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Returns the number of previously failed allocations of this shard.
- getNumFreed() - Method in class org.elasticsearch.action.search.ClearScrollResponse
- getNumIgnoredPrimaries() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Returns the number of temporarily marked as ignored unassigned primaries
- getNumMultiValuesDocs() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns the number distinct of document IDs associated with two or more values.
- getNumNodesConnected() - Method in class org.elasticsearch.transport.SniffConnectionStrategy.SniffModeInfo
- getNumPrimaries() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Returns the number of non-ignored unassigned primaries
- getNumPriorUsesInASequence() - Method in interface org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttribute
- getNumPriorUsesInASequence() - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- getNumPurged() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
-
Get the number of tombstones that were purged.
- getNumReducePhases() - Method in class org.elasticsearch.action.search.QueryPhaseResultConsumer
- getNumReducePhases() - Method in class org.elasticsearch.action.search.SearchResponse
-
Returns the number of reduce phases applied to obtain this search response
- getNumReducePhases() - Method in class org.elasticsearch.action.search.SearchResponseSections
-
Returns the number of reduce phases applied to obtain this search response
- getNumSocketsConnected() - Method in class org.elasticsearch.transport.ProxyConnectionStrategy.ProxyModeInfo
- getObjectMapper() - Method in class org.elasticsearch.index.query.support.NestedScope
- getObjectMapper(String) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- getObjectMapper(String) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- getObjectMapper(String) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Find an
ObjectMapper
. - getObjectMapper(String) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- getOffset() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getOffset() - Method in class org.elasticsearch.search.SearchHit.NestedIdentity
-
Returns the offset in the nested array of objects in the source this hit
- getOffset() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- getOffsetGap(String) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- getOffsetGap(String) - Method in class org.elasticsearch.index.analysis.ReloadableCustomAnalyzer
- getOffsets() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- getOffsetSource(String) - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
-
Forces the offset source for this highlighter
- getOffsetSource(MappedFieldType) - Method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- getOldIndex() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
-
Returns the name of the index that the request alias was pointing to
- getOldState() - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- getOnFailureProcessors() - Method in class org.elasticsearch.ingest.CompoundProcessor
- getOnFailureProcessors() - Method in class org.elasticsearch.ingest.Pipeline
-
Unmodifiable list containing each on_failure processor that operates on the data in case of exception thrown in pipeline processors
- getOnJoinValidators() - Method in class org.elasticsearch.cluster.coordination.Coordinator
- getOnJoinValidators() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- getOnlyCause(Collection<Message>) - Static method in class org.elasticsearch.common.inject.internal.Errors
-
Returns the cause throwable if there is exactly one cause in
messages
. - getOp() - Method in enum class org.elasticsearch.action.DocWriteResponse.Result
- getOpenContexts() - Method in class org.elasticsearch.index.search.stats.SearchStats
- getOpenFileDescriptorCount() - Method in class org.elasticsearch.monitor.process.ProcessProbe
-
Returns the number of opened file descriptors associated with the current process, or -1 if not supported.
- getOpenFileDescriptors() - Method in class org.elasticsearch.monitor.process.ProcessStats
- getOpenIndexOutput(String) - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
- getOpenScrollContexts() - Method in class org.elasticsearch.search.SearchService
-
Returns the number of scroll contexts opened on the node
- getOperationPrimaryTerm() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Returns the current operation primary term.
- getOperationPrimaryTerm() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the primary term that is currently being used to assign to operations
- getOperations() - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- getOperationType() - Method in class org.elasticsearch.index.engine.Engine.Result
- getOptionalJoin() - Method in class org.elasticsearch.cluster.coordination.JoinRequest
- getOptions() - Method in class org.elasticsearch.action.support.IndicesOptions
- getOptions() - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.Context
- getOptions() - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.ResolverContext
- getOptions() - Method in class org.elasticsearch.script.Script
- getOptions() - Method in class org.elasticsearch.script.StoredScriptSource
- getOptions() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- getOptions() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- getOpType() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The operation type ("index", "create" or "delete").
- getOrCompute() - Method in class org.elasticsearch.common.util.LazyInitializable
-
Returns a value that was created by
supplier
. - getOrConnect(DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.PingingRound
- getOrDefault(int, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- getOrDefault(Object, V) - Method in class org.elasticsearch.common.util.LazyMap
- getOrDefault(String, PreBuiltAnalyzers) - Static method in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
-
Get a pre built Analyzer by its name or fallback to the default one
- getOrDefault(KType, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- getOrDefault(KType, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- getOrder() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- getOrder() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- getOrder() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- getOrder() - Method in class org.elasticsearch.search.sort.BucketedSort
-
The order of the sort.
- getOrderValue() - Method in enum class org.elasticsearch.monitor.jvm.HotThreads.SortOrder
- getOrdinalMap() - Method in interface org.elasticsearch.index.fielddata.IndexOrdinalsFieldData
-
Returns the underlying
OrdinalMap
for this fielddata or null if global ordinals are not needed (constant value or single segment). - getOrdinalMap() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData.Consumer
- getOrdinalMap() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- getOrdinalMap() - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- getOrdinalMap() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData
- getOrdinalMap() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldData
- getOrdinalsValues() - Method in interface org.elasticsearch.index.fielddata.LeafOrdinalsFieldData
-
Return the ordinals values for the current atomic reader.
- getOrdinalsValues() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesLeafFieldData
- getOrdinalsValues() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetBytesLeafFieldData
- getOrdinalsValues() - Method in class org.elasticsearch.index.mapper.flattened.KeyedFlattenedLeafFieldData
- getOrigin() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getOriginalAliases() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
-
Returns the aliases as was originally specified by the user
- getOriginalAliases() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- getOriginalAliases() - Method in interface org.elasticsearch.action.AliasesRequest
-
Returns the aliases as they were originally requested, before any potential name resolution
- getOriginalFrom() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- getOriginalIndices() - Method in class org.elasticsearch.action.search.CanMatchNodeRequest.Shard
- getOriginalIndices() - Method in class org.elasticsearch.action.search.SearchShardIterator
-
Returns the original indices associated with this shard iterator, specifically with the cluster that this shard belongs to.
- getOriginalString() - Method in class org.elasticsearch.common.lucene.RegExp
- getOriginalTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- getOrRefresh() - Method in class org.elasticsearch.common.util.SingleObjectCache
-
Returns the currently cached object and potentially refreshes the cache before returning.
- getOs() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
Operating System level statistics.
- getOs() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- getOutgoingConnections() - Method in class org.elasticsearch.node.AdaptiveSelectionStats
-
Returns a map of node id to the outgoing search requests to that node
- getOutgoingRecoveries(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- getOutputFieldNames() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Return the field names this aggregation creates.
- getOutputFieldNames() - Method in class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- getOutputStream() - Method in class org.elasticsearch.bootstrap.plugins.LoggerTerminal
- getOutputUnigrams() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
- getOutputUnigramsIfNoShingles() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
- getOverhead() - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
- getOverhead() - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
- getOverhead() - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- getOverhead() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
- getOverhead() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- getOwnerType() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- getPackageName(Class<?>) - Static method in class org.elasticsearch.common.Classes
-
Determine the name of the package of the given class: e.g.
- getParameterIndex() - Method in class org.elasticsearch.common.inject.spi.Dependency
-
Returns the index of this dependency in the injection point's parameter list, or
-1
if this dependency does not belong to a parameter list. - getParameters() - Method in class org.elasticsearch.index.mapper.AllFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.DateFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.IpFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.RuntimeField.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.SourceFieldMapper.Builder
- getParameters() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- getParameterTypes(Member) - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the resolved generic parameter types of
methodOrConstructor
. - getParams() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- getParams() - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- getParams() - Method in class org.elasticsearch.rest.action.DispatchingRestToXContentListener
- getParams() - Method in class org.elasticsearch.script.AbstractFieldScript
-
Expose the
params
of the script to the script itself. - getParams() - Method in class org.elasticsearch.script.StringSortScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.AggregationScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.BucketAggregationScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.BucketAggregationSelectorScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.FieldScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.FilterScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.IngestConditionalScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.IngestScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.ScoreScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.Script
- getParams() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.CombineScript
- getParams() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.InitScript
- getParams() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- getParams() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.ReduceScript
- getParams() - Method in class org.elasticsearch.script.TemplateScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.TermsSetQueryScript
-
Return the parameters for this script.
- getParams() - Method in class org.elasticsearch.script.UpdateScript
-
Return the parameters for this script.
- getParent() - Method in class org.elasticsearch.index.mapper.LuceneDocument
-
Return the parent document, or null if this is the root document.
- getParent() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
- getParentDataStream() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- getParentDataStream() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.ConcreteIndex
- getParentDataStream() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- getParentDataStream() - Method in interface org.elasticsearch.cluster.metadata.IndexAbstraction
- getParentLimit() - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- getParentTask() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- getParentTask() - Method in interface org.elasticsearch.tasks.TaskAwareRequest
-
Get a reference to the task that created this request.
- getParentTask() - Method in class org.elasticsearch.transport.TransportRequest
-
Get a reference to the task that created this request.
- getParentTaskId() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
Returns the parent task id that tasks should be filtered by
- getParentTaskId() - Method in class org.elasticsearch.tasks.Task
-
Returns id of the parent task or NO_PARENT_ID if the task doesn't have any parent tasks
- getParentTaskId() - Method in class org.elasticsearch.tasks.TaskInfo
-
Returns the parent task id
- getParseField() - Method in enum class org.elasticsearch.script.ScriptType
- getParseField() - Method in enum class org.elasticsearch.search.aggregations.metrics.PercentilesMethod
- getParser() - Method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- getParser() - Static method in class org.elasticsearch.ingest.PipelineConfiguration
- getParser() - Method in class org.elasticsearch.plugins.SearchPlugin.SearchExtensionSpec
-
The parser responsible for converting
XContent
into the behavior. - getPartialValue() - Method in exception org.elasticsearch.common.inject.ConfigurationException
-
Returns a value that was only partially computed due to this exception.
- getPassageFormatter(FetchSubPhase.HitContext, SearchHighlightContext.Field, Encoder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- getPassword() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getPath() - Method in class org.elasticsearch.cluster.DiskUsage
- getPath() - Method in class org.elasticsearch.common.PidFile
-
Returns the process id file path
- getPath() - Method in class org.elasticsearch.index.mapper.LuceneDocument
-
Return the path associated with this document.
- getPath() - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
-
Return the path of results of this query, or
null
if matches are at the root level. - getPath() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- getPath() - Method in class org.elasticsearch.rest.RestHandler.Route
- getPath() - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- getPath(String) - Method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- getPathElements() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
- getPathElementsAsStringList() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
- getPathPrefix() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getPatterns() - Method in class org.elasticsearch.common.settings.SettingsFilter
-
Returns a set of patterns
- getPayloads() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- getPb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getPbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getPeakCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
- getPeakMax() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- getPeakUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- getPeerRecoveryRetentionLeaseId(String) - Static method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Id for a peer recovery retention lease for the given node.
- getPeerRecoveryRetentionLeaseId(ShardRouting) - Static method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Id for a peer recovery retention lease for the given
ShardRouting
. - getPeerRecoveryRetentionLeaseRetainingSeqNo(DiscoveryNode) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
-
Returns the retaining sequence number of the peer recovery retention lease for a given node if exists; otherwise, returns -1.
- getPeerRecoveryRetentionLeases() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Returns a list of peer recovery retention leases installed in this replication group
- getPeerRecoveryRetentionLeases() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns a list of retention leases for peer recovery installed in this shard copy.
- getPending() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- getPending() - Method in class org.elasticsearch.discovery.zen.PendingClusterStateStats
- getPendingPrimaryTerm() - Method in class org.elasticsearch.index.shard.IndexShard
-
USE THIS METHOD WITH CARE! Returns the primary term the index shard is supposed to be on.
- getPendingReplicationActions() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Returns the pending replication actions on the primary shard
- getPendingReplicationActions() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the pending replication actions for the shard.
- getPendingSearchRequests() - Method in class org.elasticsearch.action.search.SearchTransportService
-
Return a map of nodeId to pending number of search requests.
- getPendingTasks() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
-
The pending cluster tasks
- getPercent() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
- getPercent() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
-
Get the Process cpu usage.
- getPercent() - Method in class org.elasticsearch.search.aggregations.metrics.Percentile
- getPercentile(double) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedPercentiles
- getPercentileAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedPercentiles
- getPercents() - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
-
Get the percentages to calculate percentiles for in this aggregation
- getPeriodic() - Method in class org.elasticsearch.index.flush.FlushStats
-
The number of flushes that were periodically triggered when translog exceeded the flush threshold.
- getPerNodeTasks() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
Returns the list of tasks by node
- getPersistedCheckpoint() - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
The current persisted checkpoint which can be advanced by
LocalCheckpointTracker.markSeqNoAsPersisted(long)
. - getPersistedLocalCheckpoint() - Method in class org.elasticsearch.index.engine.Engine
- getPersistedLocalCheckpoint() - Method in class org.elasticsearch.index.engine.InternalEngine
- getPersistedLocalCheckpoint() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getPersistedState() - Method in class org.elasticsearch.gateway.GatewayMetaState
- getPersistentSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
-
Returns the persistent settings for the cluster
- getPersistentSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- getPersistentTaskExecutorSafe(String) - Method in class org.elasticsearch.persistent.PersistentTasksExecutorRegistry
- getPersistentTaskId() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- getPersistentTasksCustomMetadata(ClusterState) - Static method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- getPersistentTasksExecutor(ClusterService, ThreadPool, Client, SettingsModule, IndexNameExpressionResolver) - Method in interface org.elasticsearch.plugins.PersistentTaskPlugin
-
Returns additional persistent tasks executors added by this plugin.
- getPeta() - Method in class org.elasticsearch.common.unit.SizeValue
- getPetaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- getPhase() - Method in class org.elasticsearch.action.support.replication.ReplicationTask
-
Get the current phase of the task.
- getPhase() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
-
Get the current phase of the task.
- getPhaseName() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- getPid() - Method in class org.elasticsearch.common.PidFile
-
Returns the current process id
- getPid() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
-
The process id.
- getPingInterval() - Method in class org.elasticsearch.transport.ConnectionProfile
-
Returns the ping interval or
null
if no explicit ping interval is set on this profile. - getPingResponseHandler(UnicastZenPing.PingingRound, DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
- getPipeline() - Method in class org.elasticsearch.action.index.IndexRequest
-
Returns the ingest pipeline to be executed before indexing the document
- getPipeline() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Ingest pipeline to set on index requests made by this action.
- getPipeline(String) - Method in class org.elasticsearch.ingest.IngestService
-
Returns the pipeline by the specified id
- getPipeline(GetPipelineRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a stored ingest pipeline
- getPipeline(GetPipelineRequest, ActionListener<GetPipelineResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a stored ingest pipeline
- GetPipelineAction - Class in org.elasticsearch.action.ingest
- GetPipelineAction() - Constructor for class org.elasticsearch.action.ingest.GetPipelineAction
- getPipelineAggregations() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
PipelineAggregator
s added by this plugin. - getPipelineAggregations() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Return the configured set of pipeline aggregations
- getPipelineAggregatorFactories() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- getPipelineId() - Method in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- getPipelineId() - Method in class org.elasticsearch.ingest.IngestStats.PipelineStat
- GetPipelineRequest - Class in org.elasticsearch.action.ingest
- GetPipelineRequest(boolean, String...) - Constructor for class org.elasticsearch.action.ingest.GetPipelineRequest
- GetPipelineRequest(String...) - Constructor for class org.elasticsearch.action.ingest.GetPipelineRequest
- GetPipelineRequest(StreamInput) - Constructor for class org.elasticsearch.action.ingest.GetPipelineRequest
- GetPipelineRequestBuilder - Class in org.elasticsearch.action.ingest
- GetPipelineRequestBuilder(ElasticsearchClient, GetPipelineAction) - Constructor for class org.elasticsearch.action.ingest.GetPipelineRequestBuilder
- GetPipelineRequestBuilder(ElasticsearchClient, GetPipelineAction, String[]) - Constructor for class org.elasticsearch.action.ingest.GetPipelineRequestBuilder
- GetPipelineResponse - Class in org.elasticsearch.action.ingest
- GetPipelineResponse(List<PipelineConfiguration>) - Constructor for class org.elasticsearch.action.ingest.GetPipelineResponse
- GetPipelineResponse(List<PipelineConfiguration>, boolean) - Constructor for class org.elasticsearch.action.ingest.GetPipelineResponse
- GetPipelineResponse(StreamInput) - Constructor for class org.elasticsearch.action.ingest.GetPipelineResponse
- getPipelines() - Method in class org.elasticsearch.ingest.IngestMetadata
- getPipelines(ClusterState, String...) - Static method in class org.elasticsearch.ingest.IngestService
- getPipelineStats() - Method in class org.elasticsearch.ingest.IngestStats
- GetPipelineTransportAction - Class in org.elasticsearch.action.ingest
- GetPipelineTransportAction(ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.ingest.GetPipelineTransportAction
- getPipeliningMaxEvents() - Method in class org.elasticsearch.http.HttpHandlingSettings
- getPluginBundles(Path) - Static method in class org.elasticsearch.plugins.PluginsService
-
Get bundles for plugins installed in the given plugins directory.
- getPluginInfos() - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
-
Returns an ordered list based on plugins name
- getPluginName() - Method in class org.elasticsearch.snapshots.SnapshotFeatureInfo
- getPluginPolicyInfo(Path, Path) - Static method in class org.elasticsearch.bootstrap.PolicyUtil
-
Return info about the security policy for a plugin.
- getPlugins() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- getPluginSettings() - Method in class org.elasticsearch.plugins.PluginsService
- getPluginSettingsFilter() - Method in class org.elasticsearch.plugins.PluginsService
- getPluginsService() - Method in class org.elasticsearch.node.Node
-
The
PluginsService
used to build this node's components. - getPointInTimeId() - Method in class org.elasticsearch.action.search.OpenPointInTimeResponse
- getPointReaderOrNull() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
This method is used when an aggregation can optimize by using the indexed data instead of the doc values.
- getPoints() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- getPointsBytes() - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats.PerFieldDiskUsage
- getPointsMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the points memory usage by a segment.
- getPolicyPermissions(URL, Policy, Path) - Static method in class org.elasticsearch.bootstrap.PolicyUtil
-
Return permissions for a policy that apply to a jar.
- getPort() - Method in class org.elasticsearch.common.transport.TransportAddress
-
Returns the addresses port
- getPort() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getPortRangeString() - Method in class org.elasticsearch.common.transport.PortsRange
- getPos() - Method in exception org.elasticsearch.script.ScriptException
-
Returns the position of the error.
- getPosition() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeToken
- getPosition() - Method in class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- getPositionIncrementGap(String) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- getPositionIncrementGap(String) - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
- getPositionIncrementGap(String) - Method in class org.elasticsearch.index.analysis.ReloadableCustomAnalyzer
- getPositionLength() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeToken
- getPositions() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Returns the relative positions of terms in this phrase.
- getPositions() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- getPossibleRoleNames() - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
- getPossibleRoles() - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
- getPostings() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- getPostingsFormat(String) - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Gets the postings format for a particular field
- getPostingsFormatForField(String) - Method in class org.elasticsearch.index.codec.PerFieldMappingPostingFormatCodec
- getPostMigrationFunction() - Method in class org.elasticsearch.indices.SystemIndices.Feature
- getPreBuiltAnalyzerProviderFactories() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional pre-configured
Analyzer
s. - getPrecision() - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
-
Get the current false positive rate for individual cuckoo filters.
- getPrecision() - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- getPrecision() - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
-
Returns the precision (length) for the geohash
- getPreConfiguredCharFilters() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional pre-configured
CharFilter
s. - getPreConfiguredTokenFilters() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional pre-configured
TokenFilter
s. - getPreConfiguredTokenizers() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional pre-configured
Tokenizer
. - getPreferredName() - Method in enum class org.elasticsearch.search.aggregations.support.ValueType
- getPreferredTargetNode() - Method in interface org.elasticsearch.transport.RemoteClusterAwareRequest
-
Returns the preferred discovery node for this request.
- getPreferredTiersConfiguration(String) - Static method in class org.elasticsearch.cluster.routing.allocation.DataTier
-
Based on the provided target tier it will return a comma separated list of preferred tiers.
- getPreferredTiersConfigurationSettings(String) - Static method in class org.elasticsearch.cluster.routing.allocation.DataTier
- getPreFilterShardSize() - Method in class org.elasticsearch.action.search.SearchRequest
-
Returns a threshold that enforces a pre-filter roundtrip to pre-filter search shards based on query rewriting if the number of shards the search request expands to exceeds the threshold, or
null
if the threshold is unspecified. - getPrefix() - Method in class org.elasticsearch.gateway.MetadataStateFormat
- getPrefix() - Method in class org.elasticsearch.index.mapper.LuceneDocument
-
Return a prefix that all fields in this document should have.
- getPrefix() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getPrefixFieldType() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- getPrefixQuery(String, String) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getPreMigrationFunction() - Method in class org.elasticsearch.indices.SystemIndices.Feature
- getPrettyName() - Method in class org.elasticsearch.monitor.os.OsInfo
- getPrimaries() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
total number of primary shards in the cluster
- getPrimaries() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- getPrimaries() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- getPrimary() - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- getPrimary() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getPrimaryFieldSortOrNull(SearchSourceBuilder) - Static method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Return the
FieldSortBuilder
if the primary sort in the providedsource
is an instance of this class, null otherwise. - getPrimaryIndex() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getPrimaryRejections() - Method in class org.elasticsearch.index.stats.IndexingPressureStats
- getPrimaryTerm() - Method in class org.elasticsearch.action.DocWriteResponse
-
The primary term for this change.
- getPrimaryTerm() - Method in class org.elasticsearch.action.get.GetResponse
-
The primary term of the last primary that has changed this document, if found.
- getPrimaryTerm() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- getPrimaryTerm() - Method in class org.elasticsearch.index.get.GetResult
-
The primary term of the last primary that has changed this document, if found.
- getPrimaryTerm() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getPrimaryTerm() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The primary term of the match or
SequenceNumbers.UNASSIGNED_PRIMARY_TERM
if sequence numbers weren't requested. - getPrimaryTerm() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
-
Returns the primary term associated with this translog reader.
- getPrimaryTerm() - Method in class org.elasticsearch.search.SearchHit
-
returns the primary term of the last modification to the document, or
SequenceNumbers.UNASSIGNED_PRIMARY_TERM
if not requested. - getPrimaryTermSupplier() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns a supplier that supplies the latest primary term value of the associated shard.
- getPriority() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- getPriorityQueueSlotSize() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- getPrivateElements() - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- getPrivateElements() - Method in interface org.elasticsearch.common.inject.spi.ExposedBinding
-
Returns the enclosed environment that holds the original binding.
- getProcess() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
Process level statistics.
- getProcess() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- getProcessCpuPercent() - Method in class org.elasticsearch.monitor.process.ProcessProbe
-
Returns the process CPU usage in percent
- getProcessCpuTotalTime() - Method in class org.elasticsearch.monitor.process.ProcessProbe
-
Returns the CPU time (in milliseconds) used by the process on which the Java virtual machine is running, or -1 if not supported.
- getProcessedCheckpoint() - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
The current checkpoint which can be advanced by
LocalCheckpointTracker.markSeqNoAsProcessed(long)
. - getProcessedFileCount() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns number of files in the snapshot that were processed so far
- getProcessedFileCount() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getProcessedLocalCheckpoint() - Method in class org.elasticsearch.index.engine.Engine
- getProcessedLocalCheckpoint() - Method in class org.elasticsearch.index.engine.InternalEngine
- getProcessedLocalCheckpoint() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getProcessedSize() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns total size of files in the snapshot that were processed so far
- getProcessedSize() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getProcessor(FetchContext) - Method in interface org.elasticsearch.search.fetch.FetchSubPhase
-
Returns a
FetchSubPhaseProcessor
for this sub phase. - getProcessor(FetchContext) - Method in class org.elasticsearch.search.fetch.subphase.ExplainPhase
- getProcessor(FetchContext) - Method in class org.elasticsearch.search.fetch.subphase.FetchDocValuesPhase
- getProcessor(FetchContext) - Method in class org.elasticsearch.search.fetch.subphase.FetchFieldsPhase
- getProcessor(FetchContext) - Method in class org.elasticsearch.search.fetch.subphase.FetchScorePhase
- getProcessor(FetchContext) - Method in class org.elasticsearch.search.fetch.subphase.FetchSourcePhase
- getProcessor(FetchContext) - Method in class org.elasticsearch.search.fetch.subphase.FetchVersionPhase
- getProcessor(FetchContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightPhase
- getProcessor(FetchContext) - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsPhase
- getProcessor(FetchContext) - Method in class org.elasticsearch.search.fetch.subphase.MatchedQueriesPhase
- getProcessor(FetchContext) - Method in class org.elasticsearch.search.fetch.subphase.ScriptFieldsPhase
- getProcessor(FetchContext) - Method in class org.elasticsearch.search.fetch.subphase.SeqNoPrimaryTermPhase
- getProcessor(FetchContext, SearchHighlightContext, Query) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightPhase
- getProcessorFactories() - Method in class org.elasticsearch.ingest.IngestService
- getProcessorResults() - Method in class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
- getProcessors() - Method in class org.elasticsearch.ingest.CompoundProcessor
- getProcessors() - Method in class org.elasticsearch.ingest.IngestInfo
- getProcessors() - Method in class org.elasticsearch.ingest.Pipeline
-
Unmodifiable list containing each processor that operates on the data.
- getProcessors(Processor.Parameters) - Method in interface org.elasticsearch.plugins.IngestPlugin
-
Returns additional ingest processor types added by this plugin.
- getProcessorsInPipeline(String, Class<P>) - Method in class org.elasticsearch.ingest.IngestService
-
Gets all the Processors of the given type from within a Pipeline.
- getProcessorStats() - Method in class org.elasticsearch.ingest.IngestStats
- getProcessorTag() - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- getProductOrigin() - Static method in class org.elasticsearch.common.logging.HeaderWarning
- getProductOrigin() - Static method in class org.elasticsearch.common.logging.ProductOriginConverter
- getProductSystemIndexMetadataPredicate(ThreadContext) - Method in class org.elasticsearch.indices.SystemIndices
-
Builds a predicate that tests if a system index should be accessible based on the provided product name contained in headers.
- getProductSystemIndexNamePredicate(ThreadContext) - Method in class org.elasticsearch.indices.SystemIndices
-
Builds a predicate that tests if a system index name should be accessible based on the provided product name contained in headers.
- getProfile() - Method in interface org.elasticsearch.transport.TcpChannel
-
This returns the profile for this channel.
- getProfileAddresses() - Method in class org.elasticsearch.transport.TransportInfo
- getProfileBreakdown(E) - Method in class org.elasticsearch.search.profile.AbstractInternalProfileTree
-
Returns a
QueryProfileBreakdown
for a scoring query. - getProfiledChildren() - Method in class org.elasticsearch.search.profile.ProfileResult
-
Returns a list of all profiled children queries
- getProfiledChildren() - Method in class org.elasticsearch.search.profile.query.CollectorResult
- getProfileName() - Method in class org.elasticsearch.transport.TaskTransportChannel
- getProfileName() - Method in class org.elasticsearch.transport.TcpTransportChannel
- getProfileName() - Method in interface org.elasticsearch.transport.TransportChannel
- getProfileResults() - Method in class org.elasticsearch.action.search.SearchResponse
-
If profiling was enabled, this returns an object containing the profile results from each shard.
- getProfileResults() - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- getProfilers() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- getProfilers() - Method in class org.elasticsearch.search.internal.SearchContext
-
Return a handle over the profilers for the current search request, or
null
if profiling is not enabled. - getProfileSettings(Settings) - Static method in class org.elasticsearch.transport.TcpTransport
-
Returns all profile settings for the given settings object
- getProgressListener() - Method in class org.elasticsearch.action.search.SearchTask
-
Return the
SearchProgressListener
attached to this task. - getProperties() - Method in class org.elasticsearch.common.settings.Setting
-
Returns the setting properties
- getProperty(String) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Get the value of specified path in the aggregation.
- getProperty(String, List<String>) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation.InternalBucket
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalScriptedMetric
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTopHits
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalBucketMetricValue
- getProperty(List<String>) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalDerivative
- getProvidedKey() - Method in interface org.elasticsearch.common.inject.spi.ProviderBinding
-
Returns the key whose binding is used to
provide instances
. - getProvidedName() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
The name that was provided by the user.
- getProvider() - Method in interface org.elasticsearch.common.inject.Binding
-
Returns the scoped provider guice uses to fulfill requests for this binding.
- getProvider() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- getProvider() - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- getProvider() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
-
Returns the looked up provider.
- getProvider(Class<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- getProvider(Class<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
Returns the provider used to obtain instances for the given injection type.
- getProvider(Class<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the provider used to obtain instances for the given type.
- getProvider(Class<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- getProvider(Class<T>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Returns the provider used to obtain instances for the given injection type.
- getProvider(Key<T>) - Method in class org.elasticsearch.common.inject.AbstractModule
- getProvider(Key<T>) - Method in interface org.elasticsearch.common.inject.Binder
-
Returns the provider used to obtain instances for the given injection key.
- getProvider(Key<T>) - Method in interface org.elasticsearch.common.inject.Injector
-
Returns the provider used to obtain instances for the given injection key.
- getProvider(Key<T>) - Method in class org.elasticsearch.common.inject.PrivateModule
- getProvider(Key<T>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Returns the provider used to obtain instances for the given injection key.
- getProviderInstance() - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- getProviderInstance() - Method in interface org.elasticsearch.common.inject.spi.ProviderInstanceBinding
-
Returns the user-supplied, unscoped provider.
- getProviderKey() - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- getProviderKey() - Method in interface org.elasticsearch.common.inject.spi.ProviderKeyBinding
-
Returns the key used to resolve the provider's binding.
- getProviderMethods(Binder) - Method in class org.elasticsearch.common.inject.internal.ProviderMethodsModule
- getProximity() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- getProxyAction(String) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Returns the corresponding proxy action for the given action
- getPublicationCommitElapsedMillis() - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- getPublicationCompletionElapsedMillis() - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- getPublicationContextConstructionElapsedMillis() - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- getPublicationFailureCount() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getPublicationStartTimeMillis() - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- getPublicationSuccessCount() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getPublishDiff() - Method in class org.elasticsearch.discovery.DiscoverySettings
- getPublishResponse() - Method in class org.elasticsearch.cluster.coordination.PublishWithJoinResponse
- getPublishStats() - Method in class org.elasticsearch.discovery.DiscoveryStats
- getPublishTimeout() - Method in class org.elasticsearch.discovery.DiscoverySettings
-
Returns the current publish timeout
- getQualifiedVersion() - Method in class org.elasticsearch.Build
-
Get the version as considered at build time Offers a way to get the fully qualified version as configured by the build.
- getQueries() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
Query
s defined by this plugin. - getQueries() - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- getQueries() - Method in class org.elasticsearch.search.rescore.RescoreContext
-
Returns queries associated with the rescorer
- getQuery() - Method in class org.elasticsearch.index.query.DateRangeIncludingNowQuery
- getQuery() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getQueryBreakdown(E) - Method in class org.elasticsearch.search.profile.AbstractProfiler
-
Get the
AbstractProfileBreakdown
for the given element in the tree, potentially creating it if it did not exist. - getQueryBreakdown(Aggregator) - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfiler
- getQueryBuilder() - Method in class org.elasticsearch.search.internal.AliasFilter
-
Returns the alias filter
QueryBuilder
ornull
if there is no such filter - getQueryCache() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getQueryCache() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getQueryCache() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Return the cache to use for queries.
- getQueryCache() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getQueryCachingPolicy() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Return the policy to use when caching queries.
- getQueryCachingPolicy() - Method in class org.elasticsearch.index.shard.IndexShard
- getQueryContent(String, XContentParser) - Static method in class org.elasticsearch.rest.action.RestActions
- getQueryContent(XContentParser) - Static method in class org.elasticsearch.rest.action.RestActions
- getQueryContexts() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
- getQueryCount() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getQueryCurrent() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getQueryExplanation() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
-
The list of query explanations.
- getQueryName() - Method in class org.elasticsearch.search.profile.ProfileResult
-
Retrieve the name of the entry (e.g.
- getQueryPhase() - Method in class org.elasticsearch.search.profile.SearchProfileShardResult
- getQueryProfileResults() - Method in class org.elasticsearch.search.profile.SearchProfileQueryPhaseResult
- getQueryProfileResults() - Method in class org.elasticsearch.search.profile.SearchProfileShardResult
- getQueryProfilers() - Method in class org.elasticsearch.search.profile.Profilers
-
The list of all
QueryProfiler
s created so far. - getQueryResults() - Method in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- getQueryTime() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getQueryTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getQueryWeight() - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Gets the original query weight for rescoring.
- getQueue() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- getQueueSize() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- getQueueStats() - Method in class org.elasticsearch.discovery.DiscoveryStats
- getRangeField(String, RangeFieldMapper.Range) - Method in enum class org.elasticsearch.index.mapper.RangeType
- getRangeQuery(String, String, String, boolean, boolean) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getRanges() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
-
Get the current list or ranges that are configured on this aggregation.
- getRanks() - Method in class org.elasticsearch.node.AdaptiveSelectionStats
-
Returns a map of node id to the ranking of the nodes based on the adaptive replica formula
- getRatio() - Method in class org.elasticsearch.common.unit.RelativeByteSizeValue
- getRawCommitId() - Method in class org.elasticsearch.index.engine.CommitStats
-
A raw version of the commit id (see
SegmentInfos.getId()
- getRawDoubleValues() - Method in class org.elasticsearch.index.fielddata.NumericDoubleValues
-
Returns numeric docvalues view of raw double bits
- getRawFieldRange(String) - Method in class org.elasticsearch.index.engine.Engine
- getRawFieldRange(String) - Method in class org.elasticsearch.index.engine.InternalEngine
- getRawFieldRange(String) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getRawFloatValues() - Method in class org.elasticsearch.index.fielddata.NumericDoubleValues
-
Returns numeric docvalues view of raw float bits
- getRawKey() - Method in class org.elasticsearch.common.settings.Setting
-
Returns the original representation of a setting key.
- getRawSortValues() - Method in class org.elasticsearch.search.SearchHit
-
An array of the (raw) sort values used.
- getRawSortValues() - Method in class org.elasticsearch.search.SearchSortValues
-
Returns the raw version of the values that sorting was performed against
- getRawSortValues() - Method in class org.elasticsearch.search.SearchSortValuesAndFormats
- getRawType() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- getRawType() - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the raw (non-generic) type for this type.
- getRawType(Type) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
- getReadableName() - Method in enum class org.elasticsearch.index.analysis.AnalysisMode
- getReadBufferSizeInBytes() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getReader() - Method in class org.elasticsearch.plugins.SearchPlugin.SearchExtensionSpec
-
The reader responsible for reading the behavior from the internode protocol.
- getReader(Class<T>, String) - Method in class org.elasticsearch.common.io.stream.NamedWriteableRegistry
-
Returns a reader for a
NamedWriteable
object identified by the name provided as argument and its category. - getReaderCacheHelper() - Method in class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper
- getReaderCacheHelper() - Method in class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazySoftDeletesFilterCodecReader
- getReaderCacheHelper() - Method in class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazySoftDeletesFilterLeafReader
- getReaderCacheHelper() - Method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
- getReaderCacheHelper() - Method in class org.elasticsearch.common.lucene.index.ElasticsearchLeafReader
- getReaderCacheHelper() - Method in class org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader
- getReaderFromFile(Environment, Settings, String) - Static method in class org.elasticsearch.index.analysis.Analysis
- getReadSnapshotFileBufferSizeForRepo(String) - Method in class org.elasticsearch.indices.recovery.SnapshotFilesProvider
- getReadTimeoutMillis() - Method in class org.elasticsearch.http.HttpHandlingSettings
- getReason() - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse
- getReason() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
-
The reason for canceling the task.
- getReason() - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- getReason() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
The reason why the shard is unassigned.
- getReason() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- getReason() - Method in class org.elasticsearch.persistent.decider.AssignmentDecision
- getReason() - Method in class org.elasticsearch.search.profile.query.CollectorResult
- getReason() - Method in class org.elasticsearch.search.profile.query.InternalProfileCollector
- getReasonCancelled() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
-
The reason that the request was canceled or null if it hasn't been.
- getReasonCancelled() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
The reason that the request was canceled or null if it hasn't been.
- getReasonCancelled() - Method in class org.elasticsearch.tasks.CancellableTask
-
The reason the task was cancelled or null if it hasn't been cancelled.
- getRecordings() - Method in class org.elasticsearch.cluster.service.ClusterApplierRecordingService.Stats
- getRecovery(long) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
gets the
RecoveryTarget
for a given id. - getRecoveryId() - Method in class org.elasticsearch.indices.recovery.RecoverySnapshotFileRequest
- getRecoverySafe(long, ShardId) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
Similar to
RecoveriesCollection.getRecovery(long)
but throws an exception if no recovery is found - getRecoverySource() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getRecoveryStateFactories() - Method in interface org.elasticsearch.plugins.IndexStorePlugin
-
The
IndexStorePlugin.RecoveryStateFactory
mappings for this plugin. - getRecoveryStats() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getRecoveryStats() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getRecoveryTarget(long) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
- getReduceOrder() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- getReduceOrder() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- getReferenceManager(Engine.SearcherScope) - Method in class org.elasticsearch.index.engine.Engine
- getReferenceManager(Engine.SearcherScope) - Method in class org.elasticsearch.index.engine.InternalEngine
- getReferenceManager(Engine.SearcherScope) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getRefresh() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getRefresh() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getRefreshInterval() - Method in class org.elasticsearch.index.IndexSettings
-
Returns this interval in which the shards of this index are asynchronously refreshed.
- getRefreshInterval() - Method in class org.elasticsearch.monitor.os.OsInfo
- getRefreshInterval() - Method in class org.elasticsearch.monitor.process.ProcessInfo
- getRefreshPolicy() - Method in class org.elasticsearch.action.bulk.BulkRequest
- getRefreshPolicy() - Method in class org.elasticsearch.action.support.replication.ReplicatedWriteRequest
- getRefreshPolicy() - Method in interface org.elasticsearch.action.support.WriteRequest
-
Should this request trigger a refresh (WriteRequest.RefreshPolicy.IMMEDIATE), wait for a refresh ( WriteRequest.RefreshPolicy.WAIT_UNTIL), or proceed ignore refreshes entirely (WriteRequest.RefreshPolicy.NONE, the default).
- getRefreshPolicy() - Method in class org.elasticsearch.action.update.UpdateRequest
- getRegex() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getRegexOptions() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
- getRegexpQuery(String, String) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getRegisteredRemoteClusterNames() - Method in class org.elasticsearch.transport.RemoteClusterService
-
Returns the registered remote cluster names.
- getRegisteredSettings() - Method in class org.elasticsearch.threadpool.AutoQueueAdjustingExecutorBuilder
- getRegisteredSettings() - Method in class org.elasticsearch.threadpool.ExecutorBuilder
-
The list of settings this builder will register.
- getRegisteredSettings() - Method in class org.elasticsearch.threadpool.FixedExecutorBuilder
- getRegisteredSettings() - Method in class org.elasticsearch.threadpool.ScalingExecutorBuilder
- getRegistry() - Method in class org.elasticsearch.common.NamedRegistry
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.metrics.PercentileRanksAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- getRegistryKey() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- getRejected() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- getRelation(QueryRewriteContext) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- getRelationByName(String) - Static method in enum class org.elasticsearch.common.geo.ShapeRelation
- getRelationName() - Method in enum class org.elasticsearch.common.geo.ShapeRelation
- getRelativeTimeInMillis() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
How many millis have passed since we started the search?
- getRelativeTimeInMillis() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- getRelativeTimeInMillis() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- getRelativeTimeInMillis() - Method in class org.elasticsearch.search.internal.SearchContext
-
Returns time in milliseconds that can be used for relative time calculations.
- getRelativeTimeInMillis() - Method in class org.elasticsearch.search.internal.SubSearchContext
- getRelocatingShardCount() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- getRelocatingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getRelocatingShards() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getRelocatingShards() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- getRelocatingShards() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getRelocationId() - Method in class org.elasticsearch.cluster.routing.AllocationId
-
The transient relocation id holding the unique id that is used for relocation.
- getRelocationTargetNode() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
Returns the relocating target node, or
null
if the shard is not in theShardRoutingState.RELOCATING
state. - getRemainingDelay(long, Settings, Map<String, SingleNodeShutdownMetadata>) - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Calculates the delay left based on current time (in nanoseconds) and the delay defined by the index settings.
- getRemainingDelayInMillis() - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Gets the remaining delay for allocating the replica shard when a node holding the replica left the cluster and the deciders are waiting to see if the node returns before allocating the replica elsewhere.
- getRemoteAddress() - Method in interface org.elasticsearch.http.HttpChannel
-
Returns the remote address for this channel.
- getRemoteAddress() - Method in interface org.elasticsearch.transport.TcpChannel
-
Returns the remote address for this channel.
- getRemoteClusterClient(String) - Method in interface org.elasticsearch.client.Client
-
Returns a client to a remote cluster with the given cluster alias.
- getRemoteClusterClient(String) - Method in class org.elasticsearch.client.FilterClient
- getRemoteClusterClient(String) - Method in class org.elasticsearch.client.node.NodeClient
- getRemoteClusterClient(ThreadPool, String) - Method in class org.elasticsearch.transport.RemoteClusterService
-
Returns a client to the remote cluster if the given cluster alias exists.
- getRemoteClusterClient(ThreadPool, String, boolean) - Method in class org.elasticsearch.transport.RemoteClusterService
-
Returns a client to the remote cluster if the given cluster alias exists.
- getRemoteClusterService() - Method in class org.elasticsearch.action.search.SearchTransportService
- getRemoteClusterService() - Method in class org.elasticsearch.transport.TransportService
- getRemoteConnectionInfos() - Method in class org.elasticsearch.transport.RemoteClusterService
- getRemoteInfo() - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Get the
RemoteInfo
if it was set for this request. - getRemovalReason() - Method in class org.elasticsearch.common.cache.RemovalNotification
- getRemovedCount() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.IndexGraveyardDiff
-
The number of index tombstones that were removed between two states
- getReplacedRoute() - Method in class org.elasticsearch.rest.RestHandler.Route
- getReplicaRejections() - Method in class org.elasticsearch.index.stats.IndexingPressureStats
- getReplication() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
returns how many *redundant* copies of the data the cluster holds - running with no replicas will return 0
- getReplicationGroup() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Returns the current replication group on the primary shard
- getReplicationGroup() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Returns the current replication group for the shard.
- getReplicationGroup() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the current replication group for the shard.
- getReplicationTargets() - Method in class org.elasticsearch.index.shard.ReplicationGroup
-
Returns the subset of shards in the routing table that should be replicated to.
- getRepositories() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotRequest
- getRepositories() - Method in class org.elasticsearch.repositories.RepositoriesService
- getRepositories(GetRepositoriesRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Gets repositories.
- getRepositories(GetRepositoriesRequest, ActionListener<GetRepositoriesResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Gets repositories.
- getRepositories(ClusterState, String[]) - Static method in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
-
Get repository metadata for given repository names from given cluster state.
- getRepositories(Environment, NamedXContentRegistry, ClusterService, BigArrays, RecoverySettings) - Method in interface org.elasticsearch.plugins.RepositoryPlugin
-
Returns repository types added by this plugin.
- GetRepositoriesAction - Class in org.elasticsearch.action.admin.cluster.repositories.get
-
Get repositories action
- GetRepositoriesRequest - Class in org.elasticsearch.action.admin.cluster.repositories.get
-
Get repository request
- GetRepositoriesRequest() - Constructor for class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
- GetRepositoriesRequest(String[]) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
-
Constructs a new get repositories request with a list of repositories.
- GetRepositoriesRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
- GetRepositoriesRequestBuilder - Class in org.elasticsearch.action.admin.cluster.repositories.get
-
Get repository request builder
- GetRepositoriesRequestBuilder(ElasticsearchClient, GetRepositoriesAction) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequestBuilder
-
Creates new get repository request builder
- GetRepositoriesRequestBuilder(ElasticsearchClient, GetRepositoriesAction, String...) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequestBuilder
-
Creates new get repository request builder
- GetRepositoriesResponse - Class in org.elasticsearch.action.admin.cluster.repositories.get
-
Get repositories response
- getRepository() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan.SnapshotFilesToRecover
- getRepository() - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshot
- getRepository() - Method in class org.elasticsearch.indices.recovery.RecoverySnapshotFileRequest
- getRepository() - Method in class org.elasticsearch.repositories.ShardSnapshotInfo
- getRepository() - Method in class org.elasticsearch.snapshots.Snapshot
-
Gets the repository name for the snapshot.
- getRepositoryData(String, ActionListener<RepositoryData>) - Method in class org.elasticsearch.repositories.RepositoriesService
-
Gets the
RepositoryData
for the given repository. - getRepositoryData(ActionListener<RepositoryData>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getRepositoryData(ActionListener<RepositoryData>) - Method in class org.elasticsearch.repositories.FilterRepository
- getRepositoryData(ActionListener<RepositoryData>) - Method in interface org.elasticsearch.repositories.Repository
-
Returns a
RepositoryData
to describe the data in the repository, including the snapshots and the indices across all snapshots found in the repository. - getRepositoryFailures() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotResponse
- getRepositoryInfo() - Method in class org.elasticsearch.repositories.RepositoryStatsSnapshot
- getRepositoryMetaVersion() - Method in class org.elasticsearch.repositories.SnapshotShardContext
- getRepositoryName() - Method in exception org.elasticsearch.snapshots.SnapshotException
- getRepositoryRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Gets snapshot repository
- getRepositoryService() - Method in class org.elasticsearch.repositories.RepositoriesModule
- getRepositoryStats() - Method in class org.elasticsearch.repositories.RepositoryStatsSnapshot
- getRequest() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- getRequest() - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
- getRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Creates a get request to get the JSON source from an index based on a type and id.
- GetRequest - Class in org.elasticsearch.action.get
-
A request to get a document (its source) from an index based on its id.
- GetRequest() - Constructor for class org.elasticsearch.action.get.GetRequest
- GetRequest(String) - Constructor for class org.elasticsearch.action.get.GetRequest
-
Constructs a new get request against the specified index.
- GetRequest(String, String) - Constructor for class org.elasticsearch.action.get.GetRequest
-
Constructs a new get request against the specified index and document ID.
- GetRequest(String, String, String) - Constructor for class org.elasticsearch.action.get.GetRequest
-
Deprecated.Types are in the process of being removed, use
GetRequest(java.lang.String,java.lang.String)
instead. - GetRequestBuilder - Class in org.elasticsearch.action.get
-
A get document action request builder.
- GetRequestBuilder(ElasticsearchClient, GetAction) - Constructor for class org.elasticsearch.action.get.GetRequestBuilder
- GetRequestBuilder(ElasticsearchClient, GetAction, String) - Constructor for class org.elasticsearch.action.get.GetRequestBuilder
- getRequestCache() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getRequestCache() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getRequestCacheKeyDifferentiator() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
Allows plugins to register a cache differentiator which contributes to the cacheKey computation for the request cache.
- getRequestCacheKeyDifferentiator() - Method in class org.elasticsearch.search.SearchModule
- getRequestHandler(String) - Method in class org.elasticsearch.transport.TransportService
- getRequestHandlers() - Method in class org.elasticsearch.transport.TcpTransport
- getRequestHandlers() - Method in interface org.elasticsearch.transport.Transport
- getRequestHeadersOnly() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Returns the request headers, without the default headers
- getRequestId() - Method in class org.elasticsearch.rest.RestRequest
- getRequestId() - Method in class org.elasticsearch.transport.NetworkMessage
- getRequests() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- getRequestsPerSecond() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
The throttle for this request in sub-requests per second.
- getRequestsPerSecond() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
The number of requests per second to which to throttle the request.
- getRequiredFeature() - Method in interface org.elasticsearch.cluster.ClusterState.FeatureAware
-
An optional feature that is required for the client to have.
- getRequiredMappingUpdate() - Method in class org.elasticsearch.index.engine.Engine.Result
-
If the operation was aborted due to missing mappings, this method will return the mappings that are required to complete the operation.
- getRequiredPipeline() - Method in class org.elasticsearch.index.IndexSettings
- getRequiredSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- getRequiredSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- getRequiredSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- getRerouteInterval() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- getRerouteService() - Method in class org.elasticsearch.cluster.service.ClusterService
- getRescoredDocs() - Method in class org.elasticsearch.search.rescore.RescoreContext
- getRescoreDocIds() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- getRescoreDocIds() - Method in class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- getRescoreDocIds() - Method in class org.elasticsearch.search.SearchPhaseResult
- getRescoreDocIds(RescoreDocIds) - Method in class org.elasticsearch.search.internal.LegacyReaderContext
- getRescoreDocIds(RescoreDocIds) - Method in class org.elasticsearch.search.internal.ReaderContext
- getRescoreQuery() - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- getRescoreQueryWeight() - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Gets the original query weight for rescoring.
- getRescorers() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
Rescorer
s added by this plugin. - getReservedSize() - Method in class org.elasticsearch.index.store.StoreStats
-
A prediction of how much larger this store will eventually grow.
- getReservedSpace(String, String) - Method in class org.elasticsearch.cluster.ClusterInfo
-
Returns the reserved space for each shard on the given node/path pair
- getResizeSourceIndex() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getResizeType() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
Returns the type of the resize operation
- getResizeType() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestCloneIndexAction
- getResizeType() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestShrinkIndexAction
- getResizeType() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestSplitIndexAction
- getResolveTimeout(Settings) - Static method in class org.elasticsearch.discovery.SeedHostsResolver
- getResourceId() - Method in exception org.elasticsearch.ElasticsearchException
- getResourceType() - Method in exception org.elasticsearch.ElasticsearchException
- getResponse() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The actual response (
IndexResponse
orDeleteResponse
). - getResponse() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
-
The actual get response,
null
if its a failure. - getResponse() - Method in class org.elasticsearch.action.search.CanMatchNodeResponse.ResponseOrFailure
- getResponse() - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
-
The actual search response, null if its a failure.
- getResponse() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
-
The actual get response,
null
if its a failure. - getResponse() - Method in class org.elasticsearch.tasks.TaskResult
-
Get the response that this task finished with.
- getResponse(int) - Method in class org.elasticsearch.action.support.NodeResponseTracker
-
Returns the tracked response or null if the response hasn't been received yet for a specific index that represents a node of the cluster.
- GetResponse - Class in org.elasticsearch.action.get
-
The response of a get action.
- GetResponse(GetResult) - Constructor for class org.elasticsearch.action.get.GetResponse
- getResponseAsMap() - Method in class org.elasticsearch.tasks.TaskResult
-
Convert
TaskResult.getResponse()
from XContent to a Map for easy processing. - getResponseCollectorService() - Method in class org.elasticsearch.search.SearchService
- getResponseHandlers() - Method in class org.elasticsearch.transport.TcpTransport
- getResponseHandlers() - Method in interface org.elasticsearch.transport.Transport
- getResponseHeaders() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Get a copy of all response headers.
- getResponseReader() - Method in class org.elasticsearch.action.ActionType
-
Get a reader that can create a new instance of the class from a
StreamInput
- getResponseReader() - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- getResponseReader() - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
- getResponseReader() - Method in class org.elasticsearch.action.explain.TransportExplainAction
- getResponseReader() - Method in class org.elasticsearch.action.get.TransportGetAction
- getResponseReader() - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- getResponseReader() - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- getResponseReader() - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- getResponseReader() - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- getResponseReader() - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove.TransportAction
- getResponseResult() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
- getResponses() - Method in class org.elasticsearch.action.bulk.BulkShardResponse
- getResponses() - Method in class org.elasticsearch.action.get.MultiGetResponse
- getResponses() - Method in class org.elasticsearch.action.search.CanMatchNodeResponse
- getResponses() - Method in class org.elasticsearch.action.search.MultiSearchResponse
-
The list of responses, the order is the same as the one provided in the request.
- getResponses() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse
- getRestApiVersion() - Method in class org.elasticsearch.rest.RestHandler.Route
- getRestController() - Method in class org.elasticsearch.action.ActionModule
- getRestHandlers(Settings, RestController, ClusterSettings, IndexScopedSettings, SettingsFilter, IndexNameExpressionResolver, Supplier<DiscoveryNodes>) - Method in interface org.elasticsearch.plugins.ActionPlugin
-
Rest handlers added by this plugin.
- getRestHandlerWrapper(ThreadContext) - Method in interface org.elasticsearch.plugins.ActionPlugin
-
Returns a function used to wrap each rest request before handling the request.
- getRestHeaders() - Method in interface org.elasticsearch.plugins.ActionPlugin
-
Returns headers which should be copied through rest requests on to internal requests.
- getRestName() - Method in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- getRestoreInfo() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
-
Returns restore information if snapshot was completed before this method returned, null otherwise
- getRestoreInfo() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreCompletionResponse
- getRestoreThrottleTimeInNanos() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getRestoreThrottleTimeInNanos() - Method in class org.elasticsearch.repositories.FilterRepository
- getRestoreThrottleTimeInNanos() - Method in interface org.elasticsearch.repositories.Repository
-
Returns restore throttle time in nanoseconds
- getRestUsage() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- getRestUsageStats() - Method in class org.elasticsearch.usage.UsageService
-
Get the current usage statistics for this node.
- getResult() - Method in class org.elasticsearch.action.DocWriteResponse
-
The change that occurred to the document.
- GetResult - Class in org.elasticsearch.index.get
- GetResult(String, String, String, long, long, long, boolean, BytesReference, Map<String, DocumentField>, Map<String, DocumentField>) - Constructor for class org.elasticsearch.index.get.GetResult
- GetResult(StreamInput) - Constructor for class org.elasticsearch.index.get.GetResult
- GetResult(Engine.Searcher, VersionsAndSeqNoResolver.DocIdAndVersion) - Constructor for class org.elasticsearch.index.engine.Engine.GetResult
- getResultReaders() - Method in class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Get the readers that must be registered for this aggregation's results.
- getResultReaders() - Method in class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Get the readers that must be registered for this aggregation's results.
- getResults() - Method in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- getResultType() - Method in class org.elasticsearch.index.engine.Engine.Result
-
whether the operation was successful, has failed or was aborted due to a mapping update
- getResyncedOperations() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
-
number of operations that have been successfully replicated
- getRetainingSequenceNumber() - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.RenewRequest
- getRetentionLeaseMillis() - Method in class org.elasticsearch.index.IndexSettings
-
The maximum age of a retention lease before it is considered expired.
- getRetentionLeases() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Get all retention leases tracked on this shard.
- getRetentionLeases() - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction.Request
- getRetentionLeases() - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Request
- getRetentionLeases() - Method in class org.elasticsearch.index.shard.IndexShard
-
Get all retention leases tracked on this shard.
- getRetentionLeases(boolean) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
If the expire leases parameter is false, gets all retention leases tracked on this shard and otherwise first calculates expiration of existing retention leases, and then gets all non-expired retention leases tracked on this shard.
- getRetentionLeases(boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
If the expire leases parameter is false, gets all retention leases tracked on this shard and otherwise first calculates expiration of existing retention leases, and then gets all non-expired retention leases tracked on this shard.
- getRetentionLeaseStats() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
-
Gets the current retention lease stats.
- getRetentionLeaseStats() - Method in class org.elasticsearch.index.shard.IndexShard
- getRetryBackoffInitialTime() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Initial delay after a rejection before retrying request.
- getReturnType(Method) - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the resolved generic return type of
method
. - getRewriteable() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- getRewriteContext(LongSupplier) - Method in class org.elasticsearch.indices.IndicesService
-
Returns a new
QueryRewriteContext
with the givennow
provider - getRewriteContext(LongSupplier) - Method in class org.elasticsearch.search.SearchService
-
Returns a new
QueryRewriteContext
with the givennow
provider - getRewriteTime() - Method in class org.elasticsearch.search.profile.query.QueryProfiler
- getRewriteTime() - Method in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- getRng() - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
-
Returns the random number generator used for the cuckoo hashing process.
- getRoleFromRoleName(String) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
- getRoles() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
- getRoles() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Returns a set of all the roles that the node has.
- getRoles() - Method in class org.elasticsearch.plugins.Plugin
- getRolesFromSettings(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
-
extract node roles from the given settings
- getRolloverInfos() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getRolloverTarget() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- getRootCause() - Method in exception org.elasticsearch.ElasticsearchException
-
Retrieve the innermost cause of this exception, if none, returns the current exception.
- getRootDataPath() - Method in class org.elasticsearch.index.shard.ShardPath
-
Returns the data-path root for this shard.
- getRootId() - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
-
The _id of the root document.
- getRootLookup() - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
-
A source lookup for the root document.
- getRootSourceLookup(FetchSubPhase.HitContext) - Method in class org.elasticsearch.search.fetch.FetchContext
-
For a hit document that's being processed, return the source lookup representing the root document.
- getRootStatePath() - Method in class org.elasticsearch.index.shard.ShardPath
-
Returns the state-path root for this shard.
- getRoughEstimateDurationMillis() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- getRouting() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Gets the routing value used for this request
- getRouting() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getRouting() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The routing on the hit if there is any or null if there isn't.
- getRouting() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Gets the routing value used for this request
- getRoutingEntry() - Method in class org.elasticsearch.cluster.routing.allocation.FailedShard
-
The shard routing entry for the failed shard.
- getRoutingFactor() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Returns the routing factor for this index.
- getRoutingFactor(int, int) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Returns the routing factor for and shrunk index with the given number of target shards.
- getRoutingNodes() - Method in class org.elasticsearch.cluster.ClusterState
-
Returns a built (on demand) routing nodes view of the routing table.
- getRoutingNumShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
-
Returns number of shards that should be used for routing.
- getRoutingNumShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Returns the number of shards that should be used for routing.
- getRoutingPartitionSize() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getRoutingTable() - Method in class org.elasticsearch.cluster.ClusterState
- getRoutingTable() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- getRoutingTable() - Method in class org.elasticsearch.index.shard.ReplicationGroup
- getRows() - Method in class org.elasticsearch.common.Table
- getRunLens(long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLog
-
Returns an iterator over all values of the register.
- getRunningTimeNanos() - Method in class org.elasticsearch.tasks.TaskInfo
-
Returns the task running time
- getRuntimeFieldParsers() - Method in class org.elasticsearch.index.mapper.MapperRegistry
- getRuntimeFields() - Method in interface org.elasticsearch.plugins.MapperPlugin
-
Returns the runtime field implementations added by this plugin.
- getRuntimeFieldStats() - Method in class org.elasticsearch.action.admin.cluster.stats.MappingStats
-
Return stats about runtime field types.
- getRuntimeMappings() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- getRxCount() - Method in class org.elasticsearch.transport.TransportStats
- getRxSize() - Method in class org.elasticsearch.transport.TransportStats
- getSafe(Index) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- getSafeCommitInfo() - Method in class org.elasticsearch.index.engine.Engine
- getSafeCommitInfo() - Method in class org.elasticsearch.index.engine.InternalEngine
- getSafeCommitInfo() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getScheme() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getScheme() - Method in class org.elasticsearch.transport.DeflateTransportDecompressor
- getScheme() - Method in class org.elasticsearch.transport.Lz4TransportDecompressor
- getScheme() - Method in interface org.elasticsearch.transport.TransportDecompressor
- getScope() - Method in class org.elasticsearch.common.inject.spi.ScopeBinding
- getScope() - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
- getScopeAnnotation() - Method in class org.elasticsearch.common.inject.internal.Scoping
-
Returns the scope annotation, or
null
if that isn't known for this instance. - getScopedSettings() - Method in class org.elasticsearch.index.IndexSettings
- getScopeInstance() - Method in class org.elasticsearch.common.inject.internal.Scoping
-
Returns the scope instance, or
null
if that isn't known for this instance. - getScoping() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- getScore() - Method in class org.apache.lucene.search.uhighlight.Snippet
- getScore() - Method in class org.elasticsearch.search.SearchHit
-
The score.
- getScore() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ChiSquare
-
Calculates Chi^2 see "Information Retrieval", Manning et al., Eq.
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.GND
-
Calculates Google Normalized Distance, as described in "The Google Similarity Distance", Cilibrasi and Vitanyi, 2007 link: http://arxiv.org/pdf/cs/0412098v3.pdf
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.JLHScore
-
Calculates the significance of a term in a sample against a background of normal distributions by comparing the changes in frequency.
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.MutualInformation
-
Calculates mutual information see "Information Retrieval", Manning et al., Eq.
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.PercentageScore
-
Indicates the significance of a term in a sample by determining what percentage of all occurrences of a term are found in the sample.
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic
-
Calculates score with a script
- getScore(long, long, long, long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.SignificanceHeuristic
- getScoreFunction() - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- getScoreFunction() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- getScoreFunctions() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
ScoreFunction
s defined by this plugin. - getScoreMode() - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
-
Return the score mode for the matching children.
- getScoreMode() - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Gets the original query score mode.
- getScoreTerm(Term) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- getScript() - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- getScript() - Method in class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
-
Script to modify the documents before they are processed.
- getScript() - Method in exception org.elasticsearch.script.ScriptException
-
Returns the identifier for which script.
- getScript() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- getScript() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- getScript(AggregationScript.LeafFactory, ValueType) - Method in interface org.elasticsearch.search.aggregations.support.ValuesSourceType
-
Returns the type-specific sub class for a script data source.
- getScriptCacheStats() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- GetScriptContextAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- GetScriptContextRequest - Class in org.elasticsearch.action.admin.cluster.storedscripts
- GetScriptContextRequest() - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptContextRequest
- GetScriptContextResponse - Class in org.elasticsearch.action.admin.cluster.storedscripts
- getScriptContexts() - Method in class org.elasticsearch.script.ScriptService
- getScriptEngine(Settings, Collection<ScriptContext<?>>) - Method in interface org.elasticsearch.plugins.ScriptPlugin
-
Returns a
ScriptEngine
instance ornull
if this plugin doesn't add a new script engine. - getScriptField(String) - Method in interface org.elasticsearch.index.fielddata.LeafFieldData
-
Returns an
Field
for use in accessing field values in scripting. - getScriptField(String) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- getScriptFields() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getScriptFromClusterState(String) - Method in class org.elasticsearch.script.ScriptService
- GetScriptLanguageAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- GetScriptLanguageRequest - Class in org.elasticsearch.action.admin.cluster.storedscripts
- GetScriptLanguageRequest() - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptLanguageRequest
- GetScriptLanguageResponse - Class in org.elasticsearch.action.admin.cluster.storedscripts
- getScriptLanguages() - Method in class org.elasticsearch.script.ScriptService
- getScriptService() - Method in class org.elasticsearch.index.IndexService
-
The
ScriptService
to use for this index. - getScriptService() - Method in class org.elasticsearch.ingest.IngestService
- getScriptStack() - Method in exception org.elasticsearch.script.ScriptException
-
Returns the stacktrace for the error in the script.
- getScriptStats() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getScriptValues() - Method in interface org.elasticsearch.index.fielddata.LeafFieldData
-
Returns field values for use in scripting.
- getScriptValues() - Method in class org.elasticsearch.index.fielddata.plain.AbstractLeafGeoPointFieldData
- getScriptValues() - Method in class org.elasticsearch.index.fielddata.plain.AbstractLeafOrdinalsFieldData
- getScriptValues() - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVLeafFieldData
- getScriptValues() - Method in class org.elasticsearch.index.fielddata.plain.LeafDoubleFieldData
- getScriptValues() - Method in class org.elasticsearch.index.fielddata.plain.LeafLongFieldData
- getScriptValues() - Method in class org.elasticsearch.index.mapper.flattened.KeyedFlattenedLeafFieldData
- getScrollCount() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getScrollCurrent() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getScrollId() - Method in class org.elasticsearch.action.search.SearchResponse
-
If scrolling was enabled (
SearchRequest.scroll(org.elasticsearch.search.Scroll)
, the scroll id that can be used to continue scrolling. - getScrollId() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.Response
-
The scroll id used to fetch the next set of documents.
- getScrollIds() - Method in class org.elasticsearch.action.search.ClearScrollRequest
- getScrollTime() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Get scroll timeout
- getScrollTime() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getScrollTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getSearch() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getSearch() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getSearchAnalyzer() - Method in class org.elasticsearch.index.mapper.TextParams.Analyzers
- getSearchAnalyzer() - Method in class org.elasticsearch.index.mapper.TextSearchInfo
- getSearchContextId() - Method in class org.elasticsearch.action.search.SearchContextIdForNode
- getSearchContextId(NamedWriteableRegistry) - Method in class org.elasticsearch.search.builder.PointInTimeBuilder
-
Returns the search context of this point in time from its encoded id.
- getSearcherId() - Method in class org.elasticsearch.index.engine.Engine.SearcherSupplier
-
Returns an id associated with this searcher if exists.
- getSearcherId() - Method in class org.elasticsearch.search.internal.ShardSearchContextId
- getSearchExecutionContext() - Method in class org.elasticsearch.search.fetch.FetchContext
- getSearchExecutionContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- getSearchExecutionContext() - Method in class org.elasticsearch.search.internal.SearchContext
- getSearchExecutionContext() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getSearchExt(String) - Method in class org.elasticsearch.search.fetch.FetchContext
-
Configuration for external fetch phase plugins
- getSearchExt(String) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- getSearchExt(String) - Method in class org.elasticsearch.search.internal.SearchContext
- getSearchExts() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
SearchExtBuilder
s defined by this plugin. - getSearchFailures() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
-
All search failures.
- getSearchIdleAfter() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the time that an index shard becomes search idle unless it's accessed in between
- getSearchOperationListener() - Method in class org.elasticsearch.index.shard.IndexShard
- getSearchQuoteAnalyzer() - Method in class org.elasticsearch.index.mapper.TextParams.Analyzers
- getSearchQuoteAnalyzer() - Method in class org.elasticsearch.index.mapper.TextSearchInfo
- getSearchRequest() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
The search request that matches the documents to process.
- getSearchRetries() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
-
The number of times that the request had retry search actions.
- getSearchRetries() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Number of retries that had to be attempted due to search actions being rejected.
- getSearchRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- getSearchShardTarget() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- getSearchShardTarget() - Method in class org.elasticsearch.search.SearchPhaseResult
- getSearchSimilarity() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
The similarity to use in searches, which takes into account per-field configuration.
- getSecond() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getSecondOfDay() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getSecondOfMinute() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getSecretDigest(Settings) - Method in class org.elasticsearch.common.settings.SecureSetting
-
Returns the digest of this secure setting's value or
null
if the setting is missing (inside the keystore). - getSecureMungedAddress() - Static method in class org.elasticsearch.common.MacAddressProvider
- getSecureSettings() - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Return the current secure settings, or
null
if none have been set. - getSecureSettingsPassword() - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequest
- getSeed() - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- getSeedAddresses() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.PingingRound
- getSeedAddresses(SeedHostsProvider.HostsResolver) - Method in class org.elasticsearch.discovery.FileBasedSeedHostsProvider
- getSeedAddresses(SeedHostsProvider.HostsResolver) - Method in interface org.elasticsearch.discovery.SeedHostsProvider
-
Returns a list of seed hosts to use for discovery.
- getSeedAddresses(SeedHostsProvider.HostsResolver) - Method in class org.elasticsearch.discovery.SettingsBasedSeedHostsProvider
- getSeedHostProviders(TransportService, NetworkService) - Method in interface org.elasticsearch.plugins.DiscoveryPlugin
-
Returns providers of seed hosts for discovery.
- getSeedNodes() - Method in class org.elasticsearch.transport.SniffConnectionStrategy.SniffModeInfo
- getSegmentCount() - Method in class org.elasticsearch.common.lucene.FilterIndexCommit
- getSegmentCount() - Method in class org.elasticsearch.repositories.ShardSnapshotResult
- getSegmentName(MergePolicy.OneMerge) - Static method in class org.apache.lucene.index.OneMergeHelper
- getSegments() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getSegments() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- getSegments() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getSegments() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getSegmentsFile() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns the segments file that this metadata snapshot represents or null if the snapshot is empty.
- getSegmentsFileName() - Method in class org.elasticsearch.common.lucene.FilterIndexCommit
- getSegmentSort() - Method in class org.elasticsearch.index.engine.Segment
-
Return the sort order of this segment, or null if the segment has no sort.
- getSender() - Method in class org.elasticsearch.cluster.coordination.FollowersChecker.FollowerCheckRequest
- getSentence(Locale, int) - Static method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
-
Returns a
BreakIterator.getSentenceInstance(Locale)
bounded to maxLen. - getSeqNo() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The operation sequence number generated by primary NOTE:
SequenceNumbers.UNASSIGNED_SEQ_NO
indicates sequence number was not generated by primary - getSeqNo() - Method in class org.elasticsearch.action.DocWriteResponse
-
Returns the sequence number assigned for this change.
- getSeqNo() - Method in class org.elasticsearch.action.get.GetResponse
-
The sequence number assigned to the last operation that has changed this document, if found.
- getSeqNo() - Method in class org.elasticsearch.index.engine.Engine.Result
-
Get the sequence number on the primary.
- getSeqNo() - Method in class org.elasticsearch.index.get.GetResult
-
The sequence number assigned to the last operation that has changed this document, if found.
- getSeqNo() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getSeqNo() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The sequence number of the match or
SequenceNumbers.UNASSIGNED_SEQ_NO
if sequence numbers weren't requested. - getSeqNo() - Method in class org.elasticsearch.search.SearchHit
-
returns the sequence number of the last modification to the document, or
SequenceNumbers.UNASSIGNED_SEQ_NO
if not requested. - getSeqNoStats() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- getSeqNoStats(long) - Method in class org.elasticsearch.index.engine.Engine
- getSeqNoStats(long) - Method in class org.elasticsearch.index.engine.InternalEngine
- getSeqNoStats(long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getSequence() - Method in interface org.elasticsearch.http.HttpPipelinedMessage
-
Get the sequence number for this message.
- getSequence() - Method in class org.elasticsearch.http.HttpPipelinedRequest
- getSequence() - Method in class org.elasticsearch.http.HttpPipelinedResponse
- getSequentialStoredFieldsReader() - Method in class org.elasticsearch.common.lucene.index.SequentialStoredFieldsLeafReader
-
Returns a
StoredFieldsReader
optimized for sequential access (adjacent doc ids). - getSerializedSize() - Method in class org.elasticsearch.common.io.stream.DelayableWriteable
-
Returns the serialized size of the inner
Writeable
. - getSerializedSize() - Method in class org.elasticsearch.common.io.stream.DelayableWriteable.Serialized
- getSerializedSize(Writeable) - Static method in class org.elasticsearch.common.io.stream.DelayableWriteable
-
Returns the serialized size in bytes of the provided
Writeable
. - getServerName() - Method in class org.elasticsearch.transport.ProxyConnectionStrategy.ProxyModeInfo
- getServerOpen() - Method in class org.elasticsearch.http.HttpStats
- getServerOpen() - Method in class org.elasticsearch.transport.TransportStats
- getService() - Method in class org.elasticsearch.index.shard.IndexShard
- getSessionId() - Method in class org.elasticsearch.search.internal.ShardSearchContextId
- getSetting() - Method in interface org.elasticsearch.common.settings.Setting.AffixSettingDependency
- getSetting() - Method in interface org.elasticsearch.common.settings.Setting.SettingDependency
-
The setting to declare a dependency on.
- getSetting() - Method in interface org.elasticsearch.common.settings.SettingUpgrader
-
The setting upgraded by this upgrader.
- getSetting(String) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
-
Returns the string value of the setting for the specified index.
- getSetting(String, String) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
-
Returns the string value for the specified index and setting.
- getSetting(String, String) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
-
Returns the string value for the specified index and setting.
- getSettingNames() - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
It is possible to retrieve the setting names even if the keystore is closed.
- getSettingNames() - Method in interface org.elasticsearch.common.settings.SecureSettings
-
Returns the names of all secure settings available.
- getSettings() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
The settings of the node.
- getSettings() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- getSettings() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getSettings() - Method in class org.elasticsearch.cluster.service.ClusterService
-
The node's settings.
- getSettings() - Method in class org.elasticsearch.common.settings.SettingsModule
- getSettings() - Method in class org.elasticsearch.index.IndexModule
-
Returns the index
Settings
for this index - getSettings() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the settings for this index.
- getSettings() - Method in class org.elasticsearch.index.mapper.MappingParserContext
- getSettings() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getSettings() - Method in class org.elasticsearch.plugins.Plugin
-
Returns a list of additional
Setting
definitions for this plugin. - getSettings(GetSettingsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Executed a per index settings get request.
- getSettings(GetSettingsRequest, ActionListener<GetSettingsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Executed a per index settings get request and returns the settings for the indices specified.
- GetSettingsAction - Class in org.elasticsearch.action.admin.indices.settings.get
- GetSettingsAction() - Constructor for class org.elasticsearch.action.admin.indices.settings.get.GetSettingsAction
- getSettingsDependencies(String) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
- getSettingsDependencies(String) - Method in class org.elasticsearch.common.settings.Setting
-
Returns a set of settings that are required at validation time.
- getSettingsFilter() - Method in class org.elasticsearch.common.settings.SettingsModule
- getSettingsFilter() - Method in class org.elasticsearch.plugins.Plugin
-
Returns a list of additional settings filter for this plugin
- getSettingsKey() - Method in enum class org.elasticsearch.index.IndexModule.Type
- GetSettingsRequest - Class in org.elasticsearch.action.admin.indices.settings.get
- GetSettingsRequest() - Constructor for class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- GetSettingsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- GetSettingsRequestBuilder - Class in org.elasticsearch.action.admin.indices.settings.get
- GetSettingsRequestBuilder(ElasticsearchClient, GetSettingsAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequestBuilder
- GetSettingsResponse - Class in org.elasticsearch.action.admin.indices.settings.get
- GetSettingsResponse(ImmutableOpenMap<String, Settings>, ImmutableOpenMap<String, Settings>) - Constructor for class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- GetSettingsResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- getSettingsVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getSettingUpgraders() - Method in class org.elasticsearch.plugins.Plugin
-
Get the setting upgraders provided by this plugin.
- getSHA256Digest(String) - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Returns the SHA256 digest for the setting's value, even after
#close()
has been called. - getSHA256Digest(String) - Method in interface org.elasticsearch.common.settings.SecureSettings
- getShard() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Returns the shard id of the shard to explain, or
null
to use any unassigned shard (seeClusterAllocationExplainRequest.useAnyUnassignedShard()
). - getShard() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
Returns the shard that the explanation is about.
- getShard() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- getShard() - Method in class org.elasticsearch.search.SearchHit
-
The shard of the search hit.
- getShard(int) - Method in class org.elasticsearch.index.IndexService
-
Return the shard with the provided id, or throw an exception if it doesn't exist.
- getShardAllocationDecision() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
Returns the shard allocation decision for attempting to assign or move the shard.
- getShardBalance() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
Returns the shard related weight factor.
- getShardCount() - Method in class org.elasticsearch.snapshots.SnapshotInfo.IndexSnapshotDetails
- getShardCreationTime() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the timestamp at which this IndexShard instance was created
- getShardDataSetSize(ShardId) - Method in class org.elasticsearch.cluster.ClusterInfo
- getShardFailures() - Method in class org.elasticsearch.action.search.SearchResponse
-
The failures that occurred during the search.
- getShardFailures() - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
The list of shard failures exception.
- getShardGen(IndexId, int) - Method in class org.elasticsearch.repositories.ShardGenerations
-
Get the generation of the
BlobStoreIndexShardSnapshots
blob for a given index and shard. - getShardId() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
- getShardId() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotRequest
- getShardId() - Method in class org.elasticsearch.action.admin.indices.segments.IndexShardSegments
- getShardId() - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- getShardId() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexShardUpgradeStatus
- getShardId() - Method in class org.elasticsearch.action.bulk.BulkShardResponse
- getShardId() - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- getShardId() - Method in class org.elasticsearch.action.DocWriteResponse
-
The exact shard the document was changed in.
- getShardId() - Method in class org.elasticsearch.action.search.SearchShard
-
Return the
ShardId
of this shard. - getShardId() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardResponse
- getShardId() - Method in class org.elasticsearch.action.update.UpdateRequest
- getShardId() - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.FailedShardEntry
- getShardId() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- getShardId() - Method in class org.elasticsearch.cluster.routing.allocation.StaleShard
-
The shard id of the stale shard.
- getShardId() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns the shards id
- getShardId() - Method in exception org.elasticsearch.ElasticsearchException
- getShardId() - Method in class org.elasticsearch.env.ShardLock
-
Returns the locks shards Id.
- getShardId() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeRequest
- getShardId() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the engines shard ID
- getShardId() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Returns the shard ID this context was created for.
- getShardId() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- getShardId() - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.RemoveRequest
- getShardId() - Method in class org.elasticsearch.index.shard.ShardPath
- getShardId() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns the shard ID this config is created for
- getShardId() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- getShardId() - Method in class org.elasticsearch.indices.recovery.RecoverySnapshotFileRequest
- getShardId() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getShardId() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodeRequest
- getShardId() - Method in class org.elasticsearch.repositories.ShardSnapshotInfo
- getShardId() - Method in class org.elasticsearch.search.SearchShardTarget
- getShardId() - Method in exception org.elasticsearch.snapshots.SnapshotShardFailure
- getShardId(Object) - Method in class org.elasticsearch.common.lucene.ShardCoreKeyMap
-
Return the
ShardId
that holds the given segment, ornull
if this segment is not tracked. - getShardIndex() - Method in class org.elasticsearch.search.SearchPhaseResult
-
Returns the shard index in the context of the currently executing search request that is used for accounting on the coordinating node
- getShardInfo() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse
- getShardLevelRequests() - Method in class org.elasticsearch.action.search.CanMatchNodeRequest
- getShardLimitPerNode() - Method in class org.elasticsearch.indices.ShardLimitValidator
-
Gets the currently configured value of the
ShardLimitValidator.SETTING_CLUSTER_MAX_SHARDS_PER_NODE
setting. - getShardMinDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
-
The minimum number of documents a bucket must have in order to be returned from a shard.
- getShardOrNull(int) - Method in class org.elasticsearch.index.IndexService
-
Return the shard with the provided id, or null if there is no such shard.
- getShardOrNull(int) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndex
-
Returns shard with given id.
- getShardOrNull(ShardId) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
-
Returns shard for the specified id if it exists otherwise returns
null
. - getShardRequestIndex() - Method in class org.elasticsearch.action.search.CanMatchNodeRequest.Shard
- getShardRequestIndex() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Returns the shard request ordinal that is used by the main search request to reference this shard.
- getShardResults() - Method in class org.elasticsearch.search.profile.SearchProfileResults
- getShardRouting() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- getShardRouting() - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageShardResponse
- getShardRouting() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
-
The shard routing information (cluster wide shard state).
- getShardRouting() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.ShardUpgradeStatus
- getShardRoutings() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
- getShardRoutings() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
Returns the
ShardRouting
s that this shards iterator holds. - getShards() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
- getShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
-
A shard id to index snapshot shard status map
- getShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Returns list of snapshot shards
- getShards() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getShards() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.IndexResult
- getShards() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockResult
- getShards() - Method in class org.elasticsearch.action.admin.indices.segments.IndexSegments
-
A shard id to index shard segments map (note, index shard segments is the replication shard group that maps to the shard id).
- getShards() - Method in class org.elasticsearch.action.admin.indices.segments.IndexShardSegments
- getShards() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getShards() - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- getShards() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- getShards() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- getShards() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexShardUpgradeStatus
- getShards() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexUpgradeStatus
-
A shard id to index shard upgrade status map (note, index shard upgrade status is the replication shard group that maps to the shard id).
- getShards() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- getShards() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getShards() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- getShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of shards - getShards(ClusterState, String, int, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- getShards(ClusterState, String, String, String, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
-
Shards to use for a
GET
operation. - getShards(ClusterState, ShardId) - Static method in class org.elasticsearch.cluster.routing.OperationRouting
- getShardsAllocators(Settings, ClusterSettings) - Method in interface org.elasticsearch.plugins.ClusterPlugin
-
Return
ShardsAllocator
implementations added by this plugin. - getShardSearchRequest() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- getShardSearchRequest() - Method in class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- getShardSearchRequest() - Method in class org.elasticsearch.search.SearchPhaseResult
- getShardSearchRequest(ShardSearchRequest) - Method in class org.elasticsearch.search.internal.LegacyReaderContext
- getShardSearchRequest(ShardSearchRequest) - Method in class org.elasticsearch.search.internal.ReaderContext
- getShardSize() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- getShardSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- getShardSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- getShardSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- getShardSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- getShardSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- getShardSize() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getShardSize(ShardRouting) - Method in class org.elasticsearch.cluster.ClusterInfo
-
Returns the shard size for the given shard routing or
null
it that metric is not available. - getShardSize(ShardRouting) - Method in class org.elasticsearch.snapshots.SnapshotShardSizeInfo
- getShardSize(ShardRouting, long) - Method in class org.elasticsearch.cluster.ClusterInfo
-
Returns the shard size for the given shard routing or
defaultValue
it that metric is not available. - getShardSize(ShardRouting, long) - Method in class org.elasticsearch.snapshots.SnapshotShardSizeInfo
- GetShardSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.get.shard
- GetShardSnapshotAction() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotAction
- getShardSnapshotInfo() - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshot
- GetShardSnapshotRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.get.shard
- GetShardSnapshotRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotRequest
- GetShardSnapshotResponse - Class in org.elasticsearch.action.admin.cluster.snapshots.get.shard
- getShardSnapshotResult() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- getShardSnapshotStatus(SnapshotId, IndexId, ShardId) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getShardSnapshotStatus(SnapshotId, IndexId, ShardId) - Method in class org.elasticsearch.repositories.FilterRepository
- getShardSnapshotStatus(SnapshotId, IndexId, ShardId) - Method in interface org.elasticsearch.repositories.Repository
-
Retrieve shard snapshot status for the stored snapshot
- getShardsRemaining() - Method in class org.elasticsearch.cluster.metadata.ShutdownShardMigrationStatus
- getShardsResultPerIndex() - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
- getShardsStats() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
-
Shards stats
- getShardsStats() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
- getShardState() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
Returns the current
ShardRoutingState
of the shard. - getShardStateId(IndexShard, IndexCommit) - Static method in class org.elasticsearch.snapshots.SnapshotShardsService
-
Generates an identifier from the current state of a shard that can be used to detect whether a shard's contents have changed between two snapshots.
- getShardStateIdentifier() - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshot
- getShardStateIdentifier() - Method in class org.elasticsearch.repositories.ShardSnapshotInfo
- getShardStatePath() - Method in class org.elasticsearch.index.shard.ShardPath
- getShardStats(Index) - Method in class org.elasticsearch.indices.NodeIndicesStats
- getShardStoreInfo() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
-
Get the shard store information for the node, if it exists.
- getShardUuid() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns a unique UUID that identifies this IndexShard instance
- getShardWritingBytes(IndexShard) - Method in class org.elasticsearch.indices.IndexingMemoryController
-
returns how many bytes this shard is currently writing to disk
- getShouldStoreResult() - Method in class org.elasticsearch.action.ActionRequest
-
Should this task store its result after it has finished?
- getShouldStoreResult() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- getShowDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms.AbstractTermsBucket
- getShowDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- getShutdowns(ClusterState) - Static method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- getSiblingAggregations() - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder.ValidationContext
-
Aggregations that are siblings to the aggregation being validated.
- getSiblingPipelineAggregations() - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder.ValidationContext
-
Pipeline aggregations that are siblings to the aggregation being validated.
- getSigma() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getSignificanceHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- getSignificanceHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- getSignificanceHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- getSignificanceHeuristics() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
SignificanceHeuristic
s defined by this plugin. - getSignificanceScore() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket
- getSignificanceScore() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- getSignificanceScore() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.SignificantTerms.Bucket
- getSimilarity() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getSimilarity() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
- getSimilarity() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the
Similarity
used for indexing and searching. - getSimilarity() - Method in class org.elasticsearch.index.mapper.TextSearchInfo
- getSimilarity(String) - Method in class org.elasticsearch.index.mapper.MappingParserContext
- getSimilarity(String) - Method in class org.elasticsearch.index.similarity.SimilarityService
- getSinceTime() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- getSingles() - Method in class org.elasticsearch.common.unit.SizeValue
- getSize() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Get the number of known nodes
- getSize() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns the number of this shards instances.
- getSize() - Method in class org.elasticsearch.index.engine.Segment
- getSize() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getSize() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Deprecated.please use getMaxDocs() instead.
- getSize() - Method in class org.elasticsearch.index.store.StoreStats
- getSize() - Method in class org.elasticsearch.repositories.ShardSnapshotResult
- getSize() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- getSize() - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- getSize() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- getSize() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getSize() - Method in class org.elasticsearch.snapshots.SnapshotInfo.IndexSnapshotDetails
- getSizeInBytes() - Method in class org.elasticsearch.common.util.CuckooFilter
- getSizeInBytes() - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
-
Get the approximate size of this datastructure.
- getSizeInBytes() - Method in class org.elasticsearch.index.store.StoreStats
- getSizeInBytes() - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- getSkipped() - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
-
Returns how many total clusters were during the execution of the search request
- getSkippedOperations() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
-
number of translog operations that have been skipped
- getSkippedShards() - Method in class org.elasticsearch.action.search.SearchResponse
-
The number of shards skipped due to pre-filtering
- getSkippedShards() - Method in class org.elasticsearch.index.shard.ReplicationGroup
-
Returns the subset of shards in the routing table that are unassigned or initializing and not ready yet to receive operations (i.e.
- getSlices() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
The number of slices this task should be divided into.
- getSlices() - Method in class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
-
Returns the number of slices this BulkByScrollRequest will use
- getSliceStatuses() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Statuses of the sub requests into which this sub-request was sliced.
- getSlmPolicy() - Method in class org.elasticsearch.repositories.RepositoryData.SnapshotDetails
- getSlop() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Sets the phrase slop for this query.
- getSmallestNonClientNodeVersion() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns the version of the node with the oldest version in the cluster that is not a client node If there are no non-client nodes, Version.CURRENT will be returned.
- getSnakeCaseName() - Method in enum class org.elasticsearch.common.time.FormatNames
- getSnapshot() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Returns snapshot
- getSnapshot() - Method in class org.elasticsearch.repositories.ShardSnapshotInfo
- getSnapshot() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreCompletionResponse
- getSnapshotCommitSupplier() - Method in class org.elasticsearch.index.engine.EngineConfig
- getSnapshotCommitSuppliers() - Method in interface org.elasticsearch.plugins.IndexStorePlugin
-
The
IndexStorePlugin.SnapshotCommitSupplier
mappings for this plugin. - getSnapshotDetails(SnapshotId) - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns the
RepositoryData.SnapshotDetails
for the given snapshot. - getSnapshotFiles() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan.SnapshotFilesToRecover
- getSnapshotFiles() - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshot
- getSnapshotFilesMatching(List<StoreFileMetadata>) - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshot
- getSnapshotFilesToRecover() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- getSnapshotGlobalMetadata(SnapshotId) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getSnapshotGlobalMetadata(SnapshotId) - Method in class org.elasticsearch.repositories.FilterRepository
- getSnapshotGlobalMetadata(SnapshotId) - Method in interface org.elasticsearch.repositories.Repository
-
Returns global metadata associated with the snapshot.
- getSnapshotId() - Method in class org.elasticsearch.snapshots.Snapshot
-
Gets the snapshot id for the snapshot.
- getSnapshotIds() - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns an unmodifiable collection of the snapshot ids.
- getSnapshotIndexMetaData(RepositoryData, SnapshotId, IndexId) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getSnapshotIndexMetaData(RepositoryData, SnapshotId, IndexId) - Method in class org.elasticsearch.repositories.FilterRepository
- getSnapshotIndexMetaData(RepositoryData, SnapshotId, IndexId) - Method in interface org.elasticsearch.repositories.Repository
-
Returns the index metadata associated with the snapshot.
- getSnapshotInfo() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
-
Returns snapshot information if snapshot was completed by the time this method returned or null otherwise.
- getSnapshotInfo(GetSnapshotInfoContext) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getSnapshotInfo(GetSnapshotInfoContext) - Method in class org.elasticsearch.repositories.FilterRepository
- getSnapshotInfo(GetSnapshotInfoContext) - Method in interface org.elasticsearch.repositories.Repository
-
Reads snapshot descriptions from the repository.
- getSnapshotInfo(SnapshotId, ActionListener<SnapshotInfo>) - Method in interface org.elasticsearch.repositories.Repository
-
Reads a single snapshot description from the repository
- GetSnapshotInfoContext - Class in org.elasticsearch.repositories
-
Describes the context of fetching one or more
SnapshotInfo
viaRepository.getSnapshotInfo(GetSnapshotInfoContext)
. - GetSnapshotInfoContext(Collection<SnapshotId>, boolean, BooleanSupplier, BiConsumer<GetSnapshotInfoContext, SnapshotInfo>, ActionListener<Void>) - Constructor for class org.elasticsearch.repositories.GetSnapshotInfoContext
- getSnapshotName() - Method in exception org.elasticsearch.snapshots.SnapshotException
- getSnapshots() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
-
Returns the list of snapshots
- getSnapshots() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse
-
Returns the list of snapshots
- getSnapshots() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- getSnapshots(GetSnapshotsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshots.
- getSnapshots(GetSnapshotsRequest, ActionListener<GetSnapshotsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshots.
- getSnapshots(IndexId) - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns an immutable collection of the snapshot ids for the snapshots that contain the given index.
- GetSnapshotsAction - Class in org.elasticsearch.action.admin.cluster.snapshots.get
-
Get snapshots action
- getSnapshotsRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Gets snapshots from repositories
- GetSnapshotsRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.get
-
Get snapshot request
- GetSnapshotsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- GetSnapshotsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Constructs a new get snapshots request with given repository names
- GetSnapshotsRequest(String[], String[]) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Constructs a new get snapshots request with given repository names and list of snapshots
- GetSnapshotsRequest(String, String[]) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Constructs a new get snapshots request with given repository name and list of snapshots
- GetSnapshotsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- GetSnapshotsRequest.After - Class in org.elasticsearch.action.admin.cluster.snapshots.get
- GetSnapshotsRequest.SortBy - Enum Class in org.elasticsearch.action.admin.cluster.snapshots.get
- GetSnapshotsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.snapshots.get
-
Get snapshots request builder
- GetSnapshotsRequestBuilder(ElasticsearchClient, GetSnapshotsAction) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Constructs the new get snapshot request
- GetSnapshotsRequestBuilder(ElasticsearchClient, GetSnapshotsAction, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Constructs the new get snapshot request with specified repository
- GetSnapshotsRequestBuilder(ElasticsearchClient, GetSnapshotsAction, String...) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Constructs the new get snapshot request with specified repositories
- GetSnapshotsResponse - Class in org.elasticsearch.action.admin.cluster.snapshots.get
-
Get snapshots response
- GetSnapshotsResponse(List<SnapshotInfo>, Map<String, ElasticsearchException>, String, int, int) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- GetSnapshotsResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- getSnapshotState() - Method in class org.elasticsearch.repositories.RepositoryData.SnapshotDetails
- getSnapshotState(SnapshotId) - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns the
SnapshotState
for the given snapshot. - getSnapshottableFeatures() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse
- GetSnapshottableFeaturesRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.features
- GetSnapshottableFeaturesRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesRequest
- GetSnapshottableFeaturesRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesRequest
- GetSnapshottableFeaturesResponse - Class in org.elasticsearch.action.admin.cluster.snapshots.features
- GetSnapshottableFeaturesResponse(List<GetSnapshottableFeaturesResponse.SnapshottableFeature>) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse
- GetSnapshottableFeaturesResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse
- GetSnapshottableFeaturesResponse.SnapshottableFeature - Class in org.elasticsearch.action.admin.cluster.snapshots.features
- getSnapshotThrottleTimeInNanos() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- getSnapshotThrottleTimeInNanos() - Method in class org.elasticsearch.repositories.FilterRepository
- getSnapshotThrottleTimeInNanos() - Method in interface org.elasticsearch.repositories.Repository
-
Returns snapshot throttle time in nanoseconds
- getSocketTimeout() - Method in class org.elasticsearch.index.reindex.RemoteInfo
-
Time to wait for a response from each request.
- getSoftDeleteRetentionOperations() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the number of extra operations (i.e.
- getSort() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- getSortFields() - Method in class org.elasticsearch.search.SearchHits
-
In case documents were sorted by field(s), returns information about such field(s), null otherwise
- getSortFieldType(SortField) - Static method in class org.elasticsearch.index.IndexSortConfig
- getSorts() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- getSortValueFormats() - Method in class org.elasticsearch.search.SearchSortValuesAndFormats
- getSortValues() - Method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- getSortValues() - Method in class org.elasticsearch.search.SearchHit
-
An array of the (formatted) sort values used.
- getSource() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- getSource() - Method in class org.elasticsearch.action.get.GetResponse
- getSource() - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- getSource() - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- getSource() - Method in class org.elasticsearch.action.search.ParsedScrollId
- getSource() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- getSource() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- getSource() - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- getSource() - Method in class org.elasticsearch.common.inject.internal.MatcherAndConverter
- getSource() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- getSource() - Method in interface org.elasticsearch.common.inject.spi.Element
-
Returns an arbitrary object containing information about the "place" where this element was configured.
- getSource() - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
- getSource() - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
- getSource() - Method in class org.elasticsearch.common.inject.spi.Message
- getSource() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
- getSource() - Method in class org.elasticsearch.common.inject.spi.ScopeBinding
- getSource() - Method in class org.elasticsearch.common.inject.spi.StaticInjectionRequest
- getSource() - Method in class org.elasticsearch.common.inject.spi.TypeConverterBinding
- getSource() - Method in class org.elasticsearch.common.inject.spi.TypeListenerBinding
- getSource() - Method in class org.elasticsearch.index.get.GetResult
- getSource() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getSource() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The source of the hit.
- getSource() - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.RenewRequest
- getSource() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- getSource() - Method in class org.elasticsearch.index.translog.Translog.Delete
- getSource() - Method in class org.elasticsearch.index.translog.Translog.Index
- getSource() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- getSource() - Method in interface org.elasticsearch.index.translog.Translog.Operation
- getSource() - Method in class org.elasticsearch.script.StoredScriptSource
- getSource(SearchExecutionContext, MappedFieldType) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Combine
- getSource(SearchExecutionContext, MappedFieldType) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Disjunction
- getSource(SearchExecutionContext, MappedFieldType) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Fuzzy
- getSource(SearchExecutionContext, MappedFieldType) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider
- getSource(SearchExecutionContext, MappedFieldType) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Match
- getSource(SearchExecutionContext, MappedFieldType) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Prefix
- getSource(SearchExecutionContext, MappedFieldType) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Wildcard
- getSourceAndMetadata() - Method in class org.elasticsearch.ingest.IngestDocument
-
Returns the document including its metadata fields, unless
IngestDocument.extractMetadata()
has been called, in which case the metadata fields will not be present anymore. - getSourceAsBytes() - Method in class org.elasticsearch.action.get.GetResponse
-
The source of the document if exists.
- getSourceAsBytesRef() - Method in class org.elasticsearch.action.get.GetResponse
-
Returns bytes reference, also un compress the source if needed.
- getSourceAsMap() - Method in class org.elasticsearch.action.get.GetResponse
-
The source of the document (As a map).
- getSourceAsMap() - Method in class org.elasticsearch.cluster.metadata.MappingMetadata
-
Converts the serialized compressed form of the mappings into a parsed map.
- getSourceAsMap() - Method in class org.elasticsearch.search.SearchHit
-
The source of the document as a map (can be
null
). - getSourceAsString() - Method in class org.elasticsearch.action.get.GetResponse
-
The source of the document (as a string).
- getSourceAsString() - Method in class org.elasticsearch.search.SearchHit
-
The source of the document as string (can be
null
). - getSourceFilesToRecover() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- getSourceIndex() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
Returns the source index name
- getSourceInternal() - Method in class org.elasticsearch.action.get.GetResponse
-
Returns the internal source bytes, as they are returned without munging (for example, might still be compressed).
- getSourceKey() - Method in interface org.elasticsearch.common.inject.spi.ConvertedConstantBinding
-
Returns the key for the source binding.
- getSourceMetadataSnapshot() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- getSourceNode() - Method in class org.elasticsearch.cluster.coordination.Join
- getSourceNode() - Method in class org.elasticsearch.cluster.coordination.JoinRequest
- getSourceNode() - Method in class org.elasticsearch.cluster.coordination.PreVoteRequest
- getSourceNode() - Method in class org.elasticsearch.cluster.coordination.StartJoinRequest
- getSourceNode() - Method in class org.elasticsearch.cluster.coordination.ApplyCommitRequest
- getSourceNode() - Method in class org.elasticsearch.discovery.PeersRequest
- getSourceNode() - Method in class org.elasticsearch.indices.recovery.RecoveryState
-
Returns recovery source node (only non-null if peer recovery)
- getSourceProvider() - Method in class org.elasticsearch.index.query.IntervalQueryBuilder
- getSourceRef() - Method in class org.elasticsearch.search.SearchHit
-
Returns bytes reference, also uncompress the source if needed.
- getSources() - Method in class org.elasticsearch.common.inject.internal.Errors
- getSources() - Method in class org.elasticsearch.common.inject.spi.Message
- getStage() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
-
Returns snapshot stage
- getStage() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getStage() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getStart() - Method in class org.elasticsearch.index.query.IntervalFilterScript.Interval
- getStartedAt() - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshot
- getStartedAt() - Method in class org.elasticsearch.repositories.ShardSnapshotInfo
- getStartedAtMillis() - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- getStartedShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
-
Number of shards with the snapshot in the started stage
- getStartingSeqNo() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- getStartNanoTime() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- getStartOffset() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeToken
- getStartRecoveryRequest(Logger, DiscoveryNode, RecoveryTarget, long) - Static method in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
-
Prepare the start recovery request.
- getStartTime() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns time when snapshot started
- getStartTime() - Method in class org.elasticsearch.cluster.coordination.Publication
- getStartTime() - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.Context
- getStartTime() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
-
The start time in milliseconds for deleting the snapshots.
- getStartTime() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getStartTime() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getStartTime() - Method in class org.elasticsearch.tasks.Task
-
Returns the task's start time as a wall clock time since epoch (
System.currentTimeMillis()
style). - getStartTime() - Method in class org.elasticsearch.tasks.TaskInfo
-
Returns the task start time
- getStartTimeInNano() - Method in class org.elasticsearch.search.internal.ReaderContext
- getStartTimeMillis() - Method in class org.elasticsearch.repositories.RepositoryData.SnapshotDetails
- getStartTimeNanos() - Method in class org.elasticsearch.tasks.Task
-
Returns the task's start time in nanoseconds (
System.nanoTime()
style). - getState() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteResponse
-
Returns the cluster state resulted from the cluster reroute request execution
- getState() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Returns snapshot state
- getState() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
-
The requested cluster state.
- getState() - Method in class org.elasticsearch.cluster.coordination.ValidateJoinRequest
- getState() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getState() - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.Context
- getState() - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.ResolverContext
- getState() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- getState() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.CombineScript
- getState() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.InitScript
- getState() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- getState() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
-
Return the internal
DoubleHistogram
sketch for this metric. - getState() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
-
Return the internal
TDigestState
sketch for this metric. - getStateFileName(long) - Method in class org.elasticsearch.gateway.MetadataStateFormat
- getStatePath() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- getStates() - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.ReduceScript
- getStats() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
-
Returns snapshot stats
- getStats() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
-
Returns snapshot stats
- getStats() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Returns number of files in the snapshot
- getStats() - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageShardResponse
- getStats() - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsResponse
- getStats() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- getStats() - Method in interface org.elasticsearch.cluster.service.ClusterApplier
- getStats() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- getStats() - Method in class org.elasticsearch.index.shard.IndexShard
- getStats() - Method in class org.elasticsearch.ingest.IngestStats.PipelineStat
- getStats() - Method in class org.elasticsearch.ingest.IngestStats.ProcessorStat
- getStats() - Method in class org.elasticsearch.transport.TcpTransport
- getStats() - Method in interface org.elasticsearch.transport.Transport
- getStats(long) - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
constructs a
SeqNoStats
object, using local state and the supplied global checkpoint This is needed to make sure the persisted local checkpoint and max seq no are consistent - getStats(String) - Method in class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
- getStats(ShardId) - Method in class org.elasticsearch.indices.IndicesQueryCache
-
Get usage statistics for the given shard.
- GetStats - Class in org.elasticsearch.index.get
- GetStats() - Constructor for class org.elasticsearch.index.get.GetStats
- GetStats(long, long, long, long, long) - Constructor for class org.elasticsearch.index.get.GetStats
- GetStats(StreamInput) - Constructor for class org.elasticsearch.index.get.GetStats
- getStatsSubtype() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
-
Returns the aggregation subtype for nodes usage stats.
- getStatsSubtype() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
- getStatsTracker() - Method in class org.elasticsearch.transport.TcpTransport
- getStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getStatus() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus
- getStatus() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- getStatus() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The rest status.
- getStatus() - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
The REST status that should be used for the response
- getStatus() - Method in class org.elasticsearch.action.support.replication.ReplicationTask
- getStatus() - Method in class org.elasticsearch.action.TaskOperationFailure
- getStatus() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getStatus() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- getStatus() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getStatus() - Method in class org.elasticsearch.cluster.metadata.ShutdownPersistentTasksStatus
- getStatus() - Method in class org.elasticsearch.cluster.metadata.ShutdownPluginsStatus
- getStatus() - Method in class org.elasticsearch.cluster.metadata.ShutdownShardMigrationStatus
- getStatus() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getStatus() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
- getStatus() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- getStatus() - Method in class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
-
Get the combined statuses of sliced subtasks
- getStatus() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- getStatus() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- getStatus() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
- getStatus() - Method in class org.elasticsearch.monitor.StatusInfo
- getStatus() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- getStatus() - Method in enum class org.elasticsearch.rest.RestStatus
- getStatus() - Method in class org.elasticsearch.tasks.Task
-
Build a status for this task or null if this task doesn't have status.
- getStatus() - Method in class org.elasticsearch.tasks.TaskInfo
-
The status of the running task.
- getStatus(List<BulkByScrollTask.StatusOrException>) - Method in class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
-
Get the combined statuses of slice subtasks, merged with the given list of statuses
- getStatus(Response) - Method in class org.elasticsearch.rest.action.RestToXContentListener
- getStdDeviation() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The population standard deviation of the collected values.
- getStdDeviation() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getStdDeviation() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getStdDeviationAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The population standard deviation of the collected values as a String.
- getStdDeviationAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getStdDeviationAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getStdDeviationBound(ExtendedStats.Bounds) - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The upper or lower bounds of the stdDeviation
- getStdDeviationBound(ExtendedStats.Bounds) - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getStdDeviationBound(ExtendedStats.Bounds) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getStdDeviationBoundAsString(ExtendedStats.Bounds) - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The upper or lower bounds of stdDev of the collected values as a String.
- getStdDeviationBoundAsString(ExtendedStats.Bounds) - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getStdDeviationBoundAsString(ExtendedStats.Bounds) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getStdDeviationPopulation() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The population standard deviation of the collected values.
- getStdDeviationPopulation() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getStdDeviationPopulation() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getStdDeviationPopulationAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The population standard deviation of the collected values as a String.
- getStdDeviationPopulationAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getStdDeviationPopulationAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getStdDeviationSampling() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The sampling standard deviation of the collected values.
- getStdDeviationSampling() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getStdDeviationSampling() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getStdDeviationSamplingAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The sampling standard deviation of the collected values as a String.
- getStdDeviationSamplingAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getStdDeviationSamplingAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getStopWords() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- getStopWords() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Get the current stop words being used.
- getStore() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getStore() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getStore() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the
Store
instance that provides access to theDirectory
used for the enginesIndexWriter
to write it's index files to. - getStore() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getStoredFieldBytes() - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats.PerFieldDiskUsage
- getStoredFields() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- getStoredFieldsContext() - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Gets the stored fields context.
- getStoredFieldsMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the stored fields memory usage by a segment.
- getStoredScript(GetStoredScriptRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get a script from the cluster state
- getStoredScript(GetStoredScriptRequest, ActionListener<GetStoredScriptResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get a script from the cluster state
- getStoredScript(ClusterState, GetStoredScriptRequest) - Method in class org.elasticsearch.script.ScriptService
- GetStoredScriptAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- GetStoredScriptRequest - Class in org.elasticsearch.action.admin.cluster.storedscripts
- GetStoredScriptRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- GetStoredScriptRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- GetStoredScriptRequestBuilder - Class in org.elasticsearch.action.admin.cluster.storedscripts
- GetStoredScriptRequestBuilder(ElasticsearchClient, GetStoredScriptAction) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequestBuilder
- GetStoredScriptResponse - Class in org.elasticsearch.action.admin.cluster.storedscripts
- GetStoredScriptResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- getStoreException() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
-
Exception while trying to open the shard index or from when the shard failed
- getStoreException() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
-
Gets the store exception when trying to read the store, if there was an error.
- getStoreStatuses() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
-
Returns
IndicesShardStoresResponse.StoreStatus
s grouped by their index names and shard ids. - getStrategyName() - Method in enum class org.elasticsearch.common.geo.SpatialStrategy
- getStrictStandardDateFormatter() - Static method in class org.elasticsearch.common.joda.Joda
-
Deprecated.
- getString(String) - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
- getString(String) - Method in interface org.elasticsearch.common.settings.SecureSettings
-
Return a string setting.
- getStringKeySerializer() - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Returns a map key serializer for String keys
- getStringRep() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getStringRep() - Method in class org.elasticsearch.common.unit.RelativeByteSizeValue
- getSubAggregations() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Return the configured set of subaggregations
- getSubQuery() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- getSubsetDf() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket
- getSubsetDf() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- getSubsetDf() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.SignificantTerms.Bucket
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- getSubsetSize() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.SignificantTerms.Bucket
- getSubsetSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- getSuccessful() - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
-
Returns how many total clusters the search was executed successfully on
- getSuccessful() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- getSuccessfulCommitElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getSuccessfulCompletionElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getSuccessfulComputationElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getSuccessfulContextConstructionElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getSuccessfullyProcessed() - Method in interface org.elasticsearch.index.reindex.SuccessfullyProcessed
-
Total number of successfully processed documents.
- getSuccessfulMasterApplyElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getSuccessfulNotificationElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getSuccessfulPublicationElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getSuccessfulShards() - Method in class org.elasticsearch.action.search.SearchResponse
-
The successful number of shards the search was executed on.
- getSuccessfulShards() - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
The successful shards this request was executed on.
- getSuffix() - Method in enum class org.elasticsearch.common.unit.ByteSizeUnit
- getSuggest() - Method in class org.elasticsearch.action.search.SearchResponse
- getSuggestCount() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getSuggestCurrent() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getSuggester() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getSuggesters() - Method in interface org.elasticsearch.plugins.SearchPlugin
-
The new
Suggester
s defined by this plugin. - getSuggestion(String) - Method in class org.elasticsearch.search.suggest.Suggest
- getSuggestionReader() - Method in class org.elasticsearch.plugins.SearchPlugin.SuggesterSpec
-
Returns the reader used to read the
Suggest.Suggestion
generated by this suggester - getSuggestions() - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
Get all the
Suggestions
that were added to the globalSuggestBuilder
, together with their names - getSuggestTime() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getSuggestTimeInMillis() - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- getSum() - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- getSum() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- getSum() - Method in interface org.elasticsearch.search.aggregations.metrics.Stats
- getSumAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- getSumAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- getSumAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.Stats
- getSumDocFreq() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Field
-
Return the sum of
ScriptedSimilarity.Term.getDocFreq()
for all terms that exist in this field, or-1
if this statistic is not available. - getSummary() - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- getSumOfOtherDocCounts() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- getSumOfOtherDocCounts() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- getSumOfOtherDocCounts() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- getSumOfOtherDocCounts() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.Terms
-
Return the sum of the document counts of all buckets that did not make it to the top buckets.
- getSumOfOtherDocCounts() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- getSumOfSquares() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The sum of the squares of the collected values.
- getSumOfSquares() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getSumOfSquares() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getSumOfSquaresAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The sum of the squares of the collected values as a String.
- getSumOfSquaresAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getSumOfSquaresAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getSumTotalTermFreq() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Field
-
Return the sum of
ScriptedSimilarity.Term.getTotalTermFreq()
for all terms that exist in this field, or-1
if this statistic is not available. - getSupersetDf() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket
- getSupersetDf() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- getSupersetDf() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.SignificantTerms.Bucket
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- getSupersetSize() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.SignificantTerms.Bucket
- getSupersetSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- getSupertype(Class<?>) - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Returns the generic form of
supertype
. - getSupportedContexts() - Method in interface org.elasticsearch.script.ScriptEngine
-
Script contexts supported by this engine.
- getSupportTransportActions() - Method in class org.elasticsearch.plugins.ActionPlugin.ActionHandler
- getSwap() - Method in class org.elasticsearch.monitor.os.OsStats
- getSyncId() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns the sync id of the commit point that this MetadataSnapshot represents.
- getSynonymFilter() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory
- getSynonymFilter() - Method in interface org.elasticsearch.index.analysis.TokenFilterFactory
-
Return a version of this TokenFilterFactory appropriate for synonym parsing Filters that should not be applied to synonyms (for example, those that produce multiple tokens) should throw an exception
- getSystemCpuPercent() - Method in class org.elasticsearch.monitor.os.OsProbe
- getSystemDataStreamDescriptor() - Method in class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService.CreateDataStreamClusterStateUpdateRequest
- getSystemDataStreamDescriptors() - Method in interface org.elasticsearch.plugins.SystemIndexPlugin
- getSystemIndexAccessLevel() - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- getSystemIndexAccessLevel(ThreadContext) - Method in class org.elasticsearch.indices.SystemIndices
-
Determines what level of system index access should be allowed in the current context.
- getSystemIndexAccessPredicate() - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.Context
-
Used to determine system index access is allowed in this context (e.g.
- getSystemIndexAccessPredicate() - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- getSystemIndexDescriptors(Settings) - Method in interface org.elasticsearch.plugins.SystemIndexPlugin
-
Returns a
Collection
ofSystemIndexDescriptor
s that describe this plugin's system indices, including name, mapping, and settings. - getSystemIndices() - Method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
- getSystemProperties() - Static method in class org.elasticsearch.bootstrap.BootstrapInfo
-
Returns a read-only view of all system properties
- getSystemProperties() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.AbstractCatAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestAliasAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestAllocationAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestCatRecoveryAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestCountAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestFielddataAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestHealthAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestIndicesAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestMasterAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestNodeAttrsAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestNodesAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestPendingClusterTasksAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestPluginsAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestRepositoriesAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestSegmentsAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestShardsAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestSnapshotAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestTasksAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestTemplatesAction
- getTableWithHeader(RestRequest) - Method in class org.elasticsearch.rest.action.cat.RestThreadPoolAction
- getTag() - Method in class org.elasticsearch.ingest.AbstractProcessor
- getTag() - Method in class org.elasticsearch.ingest.CompoundProcessor
- getTag() - Method in interface org.elasticsearch.ingest.Processor
-
Gets the tag of a processor.
- getTag() - Method in class org.elasticsearch.ingest.TrackingResultProcessor
- getTargetAllocationID() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- getTargetBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- getTargetBuckets() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- getTargetIndexRequest() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
Returns the
CreateIndexRequest
for the shrink index - getTargetNode() - Method in class org.elasticsearch.cluster.coordination.Join
- getTargetNode() - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Get the node that the allocator will assign the shard to, returning
null
if there is no node to which the shard will be assigned or moved. - getTargetNode() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getTargetNodeName() - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- getTargetRelocatingShard() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns a shard routing representing the target shard.
- getTask() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskResponse
-
Get the actual result of the fetch.
- getTask() - Method in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
- getTask() - Method in class org.elasticsearch.persistent.PersistentTaskResponse
- getTask() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- getTask() - Method in class org.elasticsearch.search.internal.SearchContext
- getTask() - Method in class org.elasticsearch.tasks.TaskResult
-
Get the task that this wraps.
- getTask(long) - Method in class org.elasticsearch.tasks.TaskManager
-
Returns a task with given id, or null if the task is not found.
- getTask(String) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- getTask(GetTaskRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get a task.
- getTask(GetTaskRequest, ActionListener<GetTaskResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get a task.
- GetTaskAction - Class in org.elasticsearch.action.admin.cluster.node.tasks.get
-
ActionType for retrieving a list of currently running tasks
- getTaskClusterTasksResult(ClusterState, List<NodeRemovalClusterStateTaskExecutor.Task>, ClusterState) - Method in class org.elasticsearch.cluster.coordination.NodeRemovalClusterStateTaskExecutor
- getTaskExecutionEWMA() - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
-
Returns the exponentially weighted moving average of the task execution time
- getTaskFailures() - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
-
The list of task failures exception.
- getTaskGroups() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
Get the tasks found by this request grouped by parent tasks.
- getTaskHeaders() - Method in interface org.elasticsearch.plugins.ActionPlugin
-
Returns headers which should be copied from internal requests into tasks.
- getTaskHeaders() - Method in class org.elasticsearch.tasks.TaskManager
- getTaskId() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
- getTaskId() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
Returns the id of the task that should be processed.
- getTaskId() - Method in class org.elasticsearch.action.TaskOperationFailure
- getTaskId() - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- getTaskId() - Method in class org.elasticsearch.tasks.TaskInfo
- getTaskInfo() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup.Builder
- getTaskInfo() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup
- getTaskManager() - Method in class org.elasticsearch.transport.TransportService
- getTaskMaxWaitingTime() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getTaskName() - Method in class org.elasticsearch.common.StopWatch.TaskInfo
-
Return the name of this task.
- getTaskName() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- getTaskName() - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
- getTaskName() - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- getTaskRequest() - Static method in class org.elasticsearch.client.Requests
-
Creates a get task request.
- GetTaskRequest - Class in org.elasticsearch.action.admin.cluster.node.tasks.get
-
A request to get node tasks
- GetTaskRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
-
Get the TaskId to look up.
- GetTaskRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
- GetTaskRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.tasks.get
-
Builder for the request to retrieve the list of tasks running on the specified nodes
- GetTaskRequestBuilder(ElasticsearchClient, GetTaskAction) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequestBuilder
- GetTaskResponse - Class in org.elasticsearch.action.admin.cluster.node.tasks.get
-
Returns the list of tasks currently running on the nodes
- GetTaskResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskResponse
- GetTaskResponse(TaskResult) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskResponse
- getTasks() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
Get the tasks found by this request.
- getTasks() - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
-
Returns a stream of all pending tasks.
- getTasks() - Method in class org.elasticsearch.tasks.TaskManager
-
Returns the list of currently running tasks on the node
- getTaskWithId(ClusterState, String) - Static method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- getTb() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getTbFrac() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- getTemplateName() - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction.Request
- getTemplates() - Method in class org.elasticsearch.cluster.metadata.Metadata
- getTemplates(GetIndexTemplatesRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Gets index template.
- getTemplates(GetIndexTemplatesRequest, ActionListener<GetIndexTemplatesResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Gets an index template.
- getTempNameForFile(String) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
Get a temporary name for the provided file name.
- getTera() - Method in class org.elasticsearch.common.unit.SizeValue
- getTeraFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- getTerm() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeToken
- getTerm() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The operation primary term of the primary NOTE:
SequenceNumbers.UNASSIGNED_PRIMARY_TERM
indicates primary term was not assigned by primary - getTerm() - Method in class org.elasticsearch.cluster.coordination.FollowersChecker.FollowerCheckRequest
- getTerm() - Method in class org.elasticsearch.cluster.coordination.Join
- getTerm() - Method in class org.elasticsearch.cluster.coordination.JoinRequest
- getTerm() - Method in class org.elasticsearch.cluster.coordination.PeersResponse
- getTerm() - Method in class org.elasticsearch.cluster.coordination.PublishResponse
- getTerm() - Method in class org.elasticsearch.cluster.coordination.StartJoinRequest
- getTerm() - Method in class org.elasticsearch.cluster.coordination.ApplyCommitRequest
- getTerm() - Method in class org.elasticsearch.index.engine.Engine.Result
- getTermFrequencies() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- getTerms() - Method in class org.apache.lucene.queries.BlendedTermQuery
- getTerms() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Returns the terms for each position in this phrase
- getTerms() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- getTerms(boolean, String, SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldType
- getTerms(boolean, String, SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- getTerms(boolean, String, SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
This method is used to support auto-complete services and implementations are expected to find terms beginning with the provided string very quickly.
- getTermsMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the terms dictionary memory usage by a segment.
- getTermVectors() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- getTermVectors(IndexShard, TermVectorsRequest) - Static method in class org.elasticsearch.index.termvectors.TermVectorsService
- getTermVectorsBytes() - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats.PerFieldDiskUsage
- getTermVectorsMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the term vectors memory usage by a segment.
- getters - Variable in class org.elasticsearch.script.ScriptContextInfo
- getText() - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- getText() - Method in class org.apache.lucene.search.uhighlight.Snippet
- getText() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- getText() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- getText() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- getTexts() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.CharFilteredText
- getTextSearchInfo() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns information on how any text in this field is indexed Fields that do not support any text-based queries should return
TextSearchInfo.NONE
. - getThreadAllocatedBytes(long) - Method in class org.elasticsearch.monitor.jvm.SunThreadInfo
- getThreadContext() - Method in class org.elasticsearch.threadpool.ThreadPool
- getThreadPool() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
-
Thread Pool level statistics.
- getThreadPool() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
-
Use the same threadpool by default.
- getThreadPool() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- getThreadPool() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns a thread-pool mainly used to get estimated time stamps from
ThreadPool.relativeTimeInMillis()
and to schedule async force merge calls on theThreadPool.Names.FORCE_MERGE
thread-pool - getThreadPool() - Method in class org.elasticsearch.index.IndexService
-
The
ThreadPool
to use for this index. - getThreadPool() - Method in class org.elasticsearch.index.shard.IndexShard
- getThreadPool() - Method in class org.elasticsearch.transport.TcpTransport
- getThreadPool() - Method in class org.elasticsearch.transport.TransportService
-
Returns the internal thread pool
- getThreadPoolNames() - Method in class org.elasticsearch.indices.SystemDataStreamDescriptor
-
Get the names of the thread pools that should be used for operations on this data stream.
- getThreadPoolNames() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getThreadPoolType() - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- getThreads() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
-
The total number of threads in the cluster
- getThreads() - Method in class org.elasticsearch.monitor.jvm.JvmStats
- getThreads() - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- getThreshold() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
-
Returns the currently configured delta threshold
- getThreshold() - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
-
Returns the number of distinct values that are tracked before converting to an approximate representation.
- getThrottled() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
The total time this request has throttled itself not including the current throttle time if it is currently sleeping.
- getThrottledUntil() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Remaining delay of any current throttle sleep or 0 if not sleeping.
- getThrottleTime() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
Gets the amount of time in a TimeValue that the index has been under merge throttling control
- getTierPreference() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getTime() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns snapshot running time
- getTime() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- getTime() - Method in class org.elasticsearch.common.StopWatch.TaskInfo
-
Return the time this task took.
- getTime() - Method in class org.elasticsearch.index.get.GetStats
- getTime() - Method in class org.elasticsearch.search.profile.ProfileResult
-
Returns the total time (inclusive of children) for this query node.
- getTime() - Method in class org.elasticsearch.search.profile.query.CollectorResult
- getTime() - Method in class org.elasticsearch.search.profile.query.InternalProfileCollector
- getTimeBreakdown() - Method in class org.elasticsearch.search.profile.ProfileResult
-
The timing breakdown for this node.
- getTimeInMillis() - Method in class org.elasticsearch.index.get.GetStats
- getTimeInQueue() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- getTimeInQueueInMillis() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- getTimeout() - Method in class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
- getTimeout() - Method in class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsRequest
- getTimeout() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
-
Timeout to wait for any async actions this request must take.
- getTimeout() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- getTimeout() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Timeout to wait for the shards on to be available for each bulk request?
- getTimeoutClusterStateListenersSize() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- getTimer() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getTimer(T) - Method in class org.elasticsearch.search.profile.AbstractProfileBreakdown
- getTimestamp() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getTimestamp() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- getTimestamp() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- getTimestamp() - Method in class org.elasticsearch.monitor.fs.FsInfo
- getTimestamp() - Method in class org.elasticsearch.monitor.jvm.JvmStats
- getTimestamp() - Method in class org.elasticsearch.monitor.os.OsStats
- getTimestamp() - Method in class org.elasticsearch.monitor.process.ProcessStats
- getTimestampField() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedDataStream
- getTimestampField() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- getTimeStampField() - Method in class org.elasticsearch.cluster.metadata.DataStream
- getTimestampFieldType(Index) - Method in class org.elasticsearch.indices.IndicesService
- getTimestampFieldType(Index) - Method in class org.elasticsearch.indices.TimestampFieldMapperService
- getTimestampRange() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- getTimestampRange() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getTimestampRange() - Method in class org.elasticsearch.index.shard.IndexShard
- getTimestampRange() - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.Shard
- getTimeThrottledNanos() - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup.CpuStat
-
The total time duration for which tasks in the control group have been throttled.
- getTimeZone() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- getTimeZone() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- getTo() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Range
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Bucket
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder.Range
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedDateRange.ParsedBucket
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- getTo() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
- getTo() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- getToAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- getToAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- getToAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- getToAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- getToAsString() - Method in interface org.elasticsearch.search.aggregations.bucket.range.Range.Bucket
- getToAsString() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- getTokenFilters() - Method in class org.elasticsearch.index.analysis.AnalyzerComponents
- getTokenFilters() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional
TokenFilter
s. - getTokenizerFactory() - Method in class org.elasticsearch.index.analysis.AnalyzerComponents
- getTokenizers() - Method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Override to add additional
Tokenizer
s. - getTokens() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeTokenList
- getTokens() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Response
- getTombstones() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
-
Get the current unmodifiable index tombstone list.
- getTook() - Method in class org.elasticsearch.action.bulk.BulkResponse
-
How long the bulk execution took.
- getTook() - Method in class org.elasticsearch.action.search.MultiSearchResponse
-
How long the msearch took.
- getTook() - Method in class org.elasticsearch.action.search.SearchResponse
-
How long the search took.
- getTook() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- getTook() - Method in class org.elasticsearch.index.engine.Engine.Result
-
get total time in nanoseconds
- getTook() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getTopDocs() - Method in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
-
Transform
FirstPassGroupingCollector.getTopGroups(int)
output inCollapseTopFieldDocs
. - getTopLevelPipelineAggregators() - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
Deprecated.these only exist for BWC serialization
- getTotal() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
-
total number of shards in the cluster
- getTotal() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
- getTotal() - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- getTotal() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- getTotal() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- getTotal() - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
-
Returns how many total clusters the search was requested to be executed on
- getTotal() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- getTotal() - Method in class org.elasticsearch.cluster.ClusterInfo.ReservedSpace
- getTotal() - Method in class org.elasticsearch.discovery.zen.PendingClusterStateStats
- getTotal() - Method in class org.elasticsearch.index.engine.SegmentsStats.FileStats
- getTotal() - Method in class org.elasticsearch.index.flush.FlushStats
-
The total number of flush executed.
- getTotal() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total number of merges executed.
- getTotal() - Method in class org.elasticsearch.index.refresh.RefreshStats
-
The total number of refresh executed.
- getTotal() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getTotal() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
The total number of documents this request will process.
- getTotal() - Method in class org.elasticsearch.index.search.stats.SearchStats
- getTotal() - Method in class org.elasticsearch.index.shard.IndexingStats
- getTotal() - Method in class org.elasticsearch.monitor.fs.FsInfo
- getTotal() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- getTotal() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- getTotal() - Method in class org.elasticsearch.monitor.os.OsStats.Swap
- getTotal() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
-
Get the Process cpu time (sum of User and Sys).
- getTotal(FileStore) - Static method in class org.elasticsearch.monitor.fs.FsProbe
- getTotalBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexShardUpgradeStatus
- getTotalBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexUpgradeStatus
- getTotalBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.ShardUpgradeStatus
- getTotalBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusResponse
- getTotalBytes() - Method in class org.elasticsearch.cluster.DiskUsage
- getTotalBytes() - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
- getTotalBytesPerSecAutoThrottle() - Method in class org.elasticsearch.index.merge.MergeStats
- getTotalBytesSize() - Method in class org.elasticsearch.index.merge.OnGoingMerge
-
Returns the total size in bytes of this merge.
- getTotalBytesWritten(Thread, MergePolicy.OneMerge) - Static method in class org.apache.lucene.index.OneMergeHelper
-
Returns total bytes written by this merge.
- getTotalCapacity() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
- getTotalCombinedCoordinatingAndPrimaryBytes() - Method in class org.elasticsearch.index.stats.IndexingPressureStats
- getTotalCompressedDiffBytes() - Method in class org.elasticsearch.cluster.coordination.ClusterStateSerializationStats
- getTotalCompressedFullStateBytes() - Method in class org.elasticsearch.cluster.coordination.ClusterStateSerializationStats
- getTotalCoordinatingBytes() - Method in class org.elasticsearch.index.stats.IndexingPressureStats
- getTotalCount() - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
-
The total number of lookups in the cache.
- getTotalCount() - Method in class org.elasticsearch.index.shard.ShardCountStats
- getTotalDataSetSize() - Method in class org.elasticsearch.index.store.StoreStats
- getTotalFileCount() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns total number of files in the snapshot
- getTotalFileCount() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getTotalHits() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.Response
-
What were the total number of documents matching the search?
- getTotalHits() - Method in class org.elasticsearch.search.query.QuerySearchResult
- getTotalHits() - Method in class org.elasticsearch.search.SearchHits
-
The total number of hits for the query or null if the tracking of total hits is disabled in the request.
- getTotalIndexingBuffer() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- getTotalIndexingBufferBytes() - Method in class org.elasticsearch.indices.IndicesService
- getTotalIOTimeMillis() - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- getTotalLoadedClassCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Classes
- getTotalMemory() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
-
Utility method which computes total memory by adding FieldData, PercolatorCache, Segments (memory, index writer, version map)
- getTotalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getTotalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Gets the total number of shards from all indices, including replicas and closed indices.
- getTotalNumDocs() - Method in class org.elasticsearch.index.merge.MergeStats
- getTotalNumOrds() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns the number of document ID to ordinal pairs in this builder.
- getTotalOpen() - Method in class org.elasticsearch.http.HttpStats
- getTotalOpenIndexShards() - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Gets the total number of open shards from all indices.
- getTotalOperations() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
-
total number of translog operations that were captured by translog snapshot
- getTotalOperations() - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- getTotalPhysicalMemorySize() - Method in class org.elasticsearch.monitor.os.OsProbe
-
Returns the total amount of physical memory in bytes.
- getTotalPrimaryBytes() - Method in class org.elasticsearch.index.stats.IndexingPressureStats
- getTotalReadKilobytes() - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- getTotalReadOperations() - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- getTotalReplicaBytes() - Method in class org.elasticsearch.index.stats.IndexingPressureStats
- getTotalShardCount() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- getTotalShards() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
-
Total number of shards
- getTotalShards() - Method in class org.elasticsearch.action.search.SearchResponse
-
The total number of shards the search was executed on.
- getTotalShards() - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
-
The total shards this request ran against.
- getTotalSize() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
-
Returns total size of files in the snapshot
- getTotalSize() - Method in class org.elasticsearch.index.merge.MergeStats
- getTotalSize() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getTotalSize() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- getTotalSizeInBytes() - Method in class org.elasticsearch.index.merge.MergeStats
- getTotalSizeInBytes() - Method in class org.elasticsearch.index.shard.DocsStats
-
Returns the total size in bytes of all documents in this stats.
- getTotalStats() - Method in class org.elasticsearch.ingest.IngestStats
- getTotalStoppedTime() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total time large merges were stopped so smaller merges could finish.
- getTotalStoppedTimeInMillis() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total time large merges were stopped so smaller merges could finish.
- getTotalSwapSpaceSize() - Method in class org.elasticsearch.monitor.os.OsProbe
-
Returns the total amount of swap space in bytes.
- getTotalTermFreq() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity.Term
-
Return the total number of occurrences of this term in the index, or
-1
if this statistic is not available. - getTotalThrottledTime() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total time merge IO writes were throttled.
- getTotalThrottledTimeInMillis() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total time merge IO writes were throttled.
- getTotalTime() - Method in class org.elasticsearch.index.flush.FlushStats
-
The total time merges have been executed.
- getTotalTime() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total time merges have been executed.
- getTotalTime() - Method in class org.elasticsearch.index.refresh.RefreshStats
-
The total time refreshes have been executed.
- getTotalTime() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- getTotalTimeInMillis() - Method in class org.elasticsearch.index.flush.FlushStats
-
The total time merges have been executed (in milliseconds).
- getTotalTimeInMillis() - Method in class org.elasticsearch.index.merge.MergeStats
-
The total time merges have been executed (in milliseconds).
- getTotalTimeInMillis() - Method in class org.elasticsearch.index.refresh.RefreshStats
-
The total time spent executing refreshes (in milliseconds).
- getTotalUncompressedDiffBytes() - Method in class org.elasticsearch.cluster.coordination.ClusterStateSerializationStats
- getTotalUncompressedFullStateBytes() - Method in class org.elasticsearch.cluster.coordination.ClusterStateSerializationStats
- getTotalVirtual() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
- getTotalVirtualMemorySize() - Method in class org.elasticsearch.monitor.process.ProcessProbe
-
Returns the size (in bytes) of virtual memory that is guaranteed to be available to the running process
- getTotalWriteKilobytes() - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- getTotalWriteOperations() - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- getToUpgradeBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexShardUpgradeStatus
- getToUpgradeBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexUpgradeStatus
- getToUpgradeBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.ShardUpgradeStatus
- getToUpgradeBytes() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusResponse
- getToUpgradeBytesAncient() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexShardUpgradeStatus
- getToUpgradeBytesAncient() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexUpgradeStatus
- getToUpgradeBytesAncient() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.ShardUpgradeStatus
- getToUpgradeBytesAncient() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusResponse
- getTraceId() - Static method in class org.elasticsearch.common.logging.TraceIdConverter
- getTrackedAllocationIds() - Method in class org.elasticsearch.index.shard.ReplicationGroup
- getTrackedLocalCheckpointForShard(String) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Returns the local checkpoint information tracked for a specific shard.
- getTrackingId() - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageShardResponse
- getTrackingStartTime() - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageShardResponse
- getTragicException() - Method in class org.elasticsearch.index.translog.Translog
-
If this
Translog
was closed as a side-effect of a tragic exception, e.g. - getTransient(String) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Returns a transient header object or
null
if there is no header for the given key - getTransientSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
-
Returns the transient settings for the cluster
- getTransientSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- getTranslog() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getTranslog() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getTranslog() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getTranslogConfig() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns the translog config for this engine
- getTranslogDurability() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the translog durability for this index.
- getTranslogDurability() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the current translog durability mode
- getTranslogLastWriteLocation() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the last location that the translog of this engine has written into.
- getTranslogLastWriteLocation() - Method in class org.elasticsearch.index.engine.InternalEngine
- getTranslogLastWriteLocation() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getTranslogLocation() - Method in class org.elasticsearch.index.engine.Engine.Result
-
get the translog location after executing the operation
- getTranslogOps() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- getTranslogPath() - Method in class org.elasticsearch.index.translog.TranslogConfig
-
Returns the translog path for this engine
- getTranslogRetentionAge() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the transaction log retention age which controls the maximum age (time from creation) that translog files will be kept around
- getTranslogRetentionSize() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the transaction log retention size which controls how much of the translog is kept around to allow for ops based recoveries
- getTranslogRetentionTotalFiles() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the maximum number of translog files that that no longer required for persistence should be kept for peer recovery when soft-deletes is disabled.
- getTranslogSizeInBytes() - Method in class org.elasticsearch.index.translog.TranslogStats
- getTranslogStats() - Method in class org.elasticsearch.index.engine.Engine
- getTranslogStats() - Method in class org.elasticsearch.index.engine.InternalEngine
- getTranslogStats() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getTranslogSyncInterval() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the translog sync interval.
- getTranslogUUID() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the translog uuid used to associate a lucene index with a translog.
- getTransport() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- getTransportAction() - Method in class org.elasticsearch.plugins.ActionPlugin.ActionHandler
- getTransportInterceptor() - Method in class org.elasticsearch.common.network.NetworkModule
-
Returns a composite
TransportInterceptor
containing all registered interceptors - getTransportInterceptors(NamedWriteableRegistry, ThreadContext) - Method in interface org.elasticsearch.plugins.NetworkPlugin
-
Returns a list of
TransportInterceptor
instances that are used to intercept incoming and outgoing transport (inter-node) requests. - getTransportNodeAction(DiscoveryNode) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
Get a backwards compatible transport action name
- getTransports(Settings, ThreadPool, PageCacheRecycler, CircuitBreakerService, NamedWriteableRegistry, NetworkService) - Method in interface org.elasticsearch.plugins.NetworkPlugin
-
Returns a map of
Transport
suppliers. - getTransportSupplier() - Method in class org.elasticsearch.common.network.NetworkModule
- getTree() - Method in class org.elasticsearch.search.profile.AbstractInternalProfileTree
-
After the element has been run and profiled, we need to merge the flat timing map with the dependency graph to build a data structure that mirrors the original query tree
- getTree() - Method in class org.elasticsearch.search.profile.AbstractProfiler
- getTrigramLambda() - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- getTrimAboveSeqNo() - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- getTrippedCount() - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
- getTrippedCount() - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
- getTrippedCount() - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- getTrippedCount() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- getTxCount() - Method in class org.elasticsearch.transport.TransportStats
- getTxSize() - Method in class org.elasticsearch.transport.TransportStats
- getType() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeToken
- getType() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
The type of the action.
- getType() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The type of the action.
- getType() - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- getType() - Method in class org.elasticsearch.action.DocWriteResponse
-
Deprecated.Types are in the process of being removed.
- getType() - Method in class org.elasticsearch.action.explain.ExplainResponse
-
Deprecated.Types are in the process of being removed.
- getType() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
The type of the field.
- getType() - Method in class org.elasticsearch.action.fieldcaps.IndexFieldCapabilities
- getType() - Method in class org.elasticsearch.action.get.GetResponse
-
The type of the document.
- getType() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
-
The type of the document.
- getType() - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
-
The type of the action.
- getType() - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- getType() - Method in exception org.elasticsearch.action.RoutingMissingException
- getType() - Method in class org.elasticsearch.action.search.ParsedScrollId
- getType() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
-
The type of the document.
- getType() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
-
Deprecated.Types are in the process of being removed.
- getType() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- getType() - Method in class org.elasticsearch.cluster.metadata.DataStreamAction
- getType() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- getType() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.ConcreteIndex
- getType() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- getType() - Method in interface org.elasticsearch.cluster.metadata.IndexAbstraction
- getType() - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- getType() - Method in class org.elasticsearch.cluster.routing.RecoverySource.EmptyStoreRecoverySource
- getType() - Method in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- getType() - Method in class org.elasticsearch.cluster.routing.RecoverySource
- getType() - Method in class org.elasticsearch.cluster.routing.RecoverySource.LocalShardsRecoverySource
- getType() - Method in class org.elasticsearch.cluster.routing.RecoverySource.PeerRecoverySource
- getType() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- getType() - Method in class org.elasticsearch.common.inject.spi.InjectionRequest
- getType() - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
-
Gets the type containing the members to be injected.
- getType() - Method in class org.elasticsearch.common.inject.spi.StaticInjectionRequest
- getType() - Method in class org.elasticsearch.common.inject.TypeLiteral
-
Gets underlying
Type
instance. - getType() - Method in class org.elasticsearch.common.logging.ESJsonLayout.Builder
- getType() - Method in class org.elasticsearch.index.get.GetResult
-
The type of the document.
- getType() - Method in class org.elasticsearch.index.mapper.MappingLookup
- getType() - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypeFieldType
-
Returns the name of the current type
- getType() - Method in class org.elasticsearch.index.mapper.TypeFieldType
-
Returns the name of the current type
- getType() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Returns the type (for testing)
- getType() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- getType() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getType() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The type that the hit has.
- getType() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
- getType() - Method in class org.elasticsearch.ingest.CompoundProcessor
- getType() - Method in class org.elasticsearch.ingest.ConditionalProcessor
- getType() - Method in class org.elasticsearch.ingest.DropProcessor
- getType() - Method in class org.elasticsearch.ingest.IngestStats.ProcessorStat
- getType() - Method in class org.elasticsearch.ingest.PipelineProcessor
- getType() - Method in interface org.elasticsearch.ingest.Processor
-
Gets the type of a processor
- getType() - Method in class org.elasticsearch.ingest.ProcessorInfo
- getType() - Method in class org.elasticsearch.ingest.TrackingResultProcessor
- getType() - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- getType() - Method in class org.elasticsearch.persistent.decider.AssignmentDecision
- getType() - Method in class org.elasticsearch.plugins.PluginDescriptor
-
Returns the type of this plugin.
- getType() - Method in class org.elasticsearch.script.Script
- getType() - Method in interface org.elasticsearch.script.ScriptEngine
-
The language name used in the script APIs to refer to this scripting backend.
- getType() - Method in interface org.elasticsearch.search.aggregations.Aggregation
- getType() - Method in interface org.elasticsearch.search.aggregations.BaseAggregationBuilder
-
The name of the type of aggregation built by this builder.
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.ParsedAdjacencyMatrix
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilter
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoHashGrid
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoTileGrid
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.global.ParsedGlobal
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedHistogram
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.missing.ParsedMissing
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ParsedNested
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ParsedReverseNested
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedDateRange
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedGeoDistance
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.ParsedSampler
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongRareTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantLongTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantStringTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringRareTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- getType() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- getType() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedAvg
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedCardinality
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedGeoBounds
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedGeoCentroid
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedHDRPercentileRanks
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedHDRPercentiles
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedMax
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedMedianAbsoluteDeviation
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedMin
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedScriptedMetric
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedSum
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentileRanks
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentiles
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTopHits
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedValueCount
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedWeightedAvg
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.PercentileRanksAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedBucketMetricValue
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedDerivative
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedExtendedStatsBucket
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedPercentilesBucket
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedSimpleValue
- getType() - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedStatsBucket
- getType() - Method in class org.elasticsearch.search.SearchHit
-
Deprecated.Types are in the process of being removed. Instead of using a type, prefer to filter on a field on the document.
- getType() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
gets the type identifier of this
PhraseSuggestionBuilder.CandidateGenerator
- getType() - Method in interface org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder.CandidateGenerator
- getType() - Method in class org.elasticsearch.tasks.Task
-
Returns task channel type (netty, transport, direct)
- getType() - Method in class org.elasticsearch.tasks.TaskInfo
- getType() - Method in enum class org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
- getTypeConverter() - Method in class org.elasticsearch.common.inject.internal.MatcherAndConverter
- getTypeConverter() - Method in class org.elasticsearch.common.inject.spi.TypeConverterBinding
- getTypeForUpdate(String, CompressedXContent) - Method in class org.elasticsearch.index.mapper.MapperService
-
If the _type name is _doc and there is no _doc top-level key then this means that we are handling a typeless call.
- getTypeFromElement(E) - Method in class org.elasticsearch.search.profile.AbstractInternalProfileTree
- getTypeFromElement(Aggregator) - Method in class org.elasticsearch.search.profile.aggregation.InternalAggregationProfileTree
- getTypeLiteral() - Method in class org.elasticsearch.common.inject.Key
-
Gets the key type.
- getTypeMatcher() - Method in class org.elasticsearch.common.inject.internal.MatcherAndConverter
- getTypeMatcher() - Method in class org.elasticsearch.common.inject.spi.TypeConverterBinding
- getTypeMatcher() - Method in class org.elasticsearch.common.inject.spi.TypeListenerBinding
-
Returns the type matcher which chooses which types the listener should be notified of.
- getTypes() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- getTypeStats() - Method in class org.elasticsearch.index.shard.IndexingStats
- getTypeValue() - Method in enum class org.elasticsearch.monitor.jvm.HotThreads.ReportType
- getUnassignedInfo() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
Returns the unassigned info for the shard, or
null
if the shard is active. - getUnassignedShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- getUnassignedShards() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- getUnassignedShards() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- getUnassignedShards() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- getUnassignedTimeInMillis() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
The timestamp in milliseconds when the shard became unassigned, based on System.currentTimeMillis().
- getUnassignedTimeInNanos() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
The timestamp in nanoseconds when the shard became unassigned, based on System.nanoTime().
- getUnavailableInSyncShards() - Method in class org.elasticsearch.index.shard.ReplicationGroup
-
Returns the set of shard allocation ids that are in the in-sync set but have no assigned routing entry
- getUnchangedComputationElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getUnchangedNotificationElapsedMillis() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getUnchangedTaskCount() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- getUncommittedOperations() - Method in class org.elasticsearch.index.translog.TranslogStats
-
the number of operations in generations of the translog that weren't yet to committed to lucene
- getUncommittedSizeInBytes() - Method in class org.elasticsearch.index.translog.TranslogStats
-
the size of the generations in the translog that weren't yet to committed to lucene
- getUnigramLambda() - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- getUnloadedClassCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Classes
- getUpdated() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getUpdated() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- getUpdated() - Method in interface org.elasticsearch.index.reindex.SuccessfullyProcessed
-
Count of documents updated.
- getUpdated() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- getUpgradeStatus() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.FeatureUpgradeStatus
- getUpgradeStatus() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse
- getUpperBounds() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
- getUpserts() - Method in class org.elasticsearch.cluster.DiffableUtils.MapDiff
-
Map entries that, when this diff is applied to a map, should be added to the map or fully replace the previous value.
- getUpserts() - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap.DiffableStringMapDiff
- getUptime() - Method in class org.elasticsearch.monitor.jvm.JvmStats
- getUsableSpace(Path) - Static method in class org.elasticsearch.env.Environment
- getUsageCount() - Method in class org.elasticsearch.rest.BaseRestHandler
- getUsageService() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
The
AggregationUsageService
used to track which aggregations are actually used. - getUsageService() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry
- getUsageStats() - Method in class org.elasticsearch.search.aggregations.support.AggregationUsageService
- getUsed() - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
- getUsed() - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
- getUsed() - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- getUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
- getUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- getUsed() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- getUsed() - Method in class org.elasticsearch.monitor.os.OsStats.Swap
- getUsedAnalyzerTypes() - Method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
-
Return the set of used analyzers in the cluster.
- getUsedBuiltInAnalyzers() - Method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
-
Return the set of used built-in analyzers in the cluster.
- getUsedBuiltInCharFilters() - Method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
-
Return the set of used built-in char filters in the cluster.
- getUsedBuiltInTokenFilters() - Method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
-
Return the set of used built-in token filters in the cluster.
- getUsedBuiltInTokenizers() - Method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
-
Return the set of used built-in tokenizers in the cluster.
- getUsedBytes() - Method in class org.elasticsearch.cluster.DiskUsage
- getUsedCharFilterTypes() - Method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
-
Return the set of used char filters in the cluster.
- getUsedDiskAsPercentage() - Method in class org.elasticsearch.cluster.DiskUsage
- getUsedPercent() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- getUsedTokenFilterTypes() - Method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
-
Return the set of used token filters in the cluster.
- getUsedTokenizerTypes() - Method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
-
Return the set of used tokenizers in the cluster.
- getUserData() - Method in class org.elasticsearch.common.lucene.FilterIndexCommit
- getUserData() - Method in class org.elasticsearch.index.engine.CommitStats
- getUsername() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- getUserValueTypeHint() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- getUserValueTypeHint() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- getUseSnapshotsDuringRecovery() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- getUsingBundledJdk() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getUuid() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- getUuid() - Method in class org.elasticsearch.repositories.RepositoryData
- getUuid() - Method in class org.elasticsearch.snapshots.RestoreService.RestoreCompletionResponse
- getUUID() - Method in class org.elasticsearch.index.Index
- getUUID() - Method in class org.elasticsearch.index.IndexSettings
-
Returns the indexes UUID
- getUUID() - Method in class org.elasticsearch.snapshots.SnapshotId
-
Returns the snapshot UUID
- getValidationException() - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder.ValidationContext
-
The validation exception, if there is one.
- getValidationMethod() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Returns geo coordinate validation method to use.
- getValidationMethod() - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Returns validation method for geo coordinates.
- getValidationMethod() - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.Returns the validation method to use for geo coordinates.
- getValidValuesWriter() - Method in class org.elasticsearch.common.document.DocumentField
- getValue() - Method in enum class org.elasticsearch.action.support.WriteRequest.RefreshPolicy
- getValue() - Method in class org.elasticsearch.common.cache.RemovalNotification
- getValue() - Method in class org.elasticsearch.common.document.DocumentField
-
The first value of the hit.
- getValue() - Method in interface org.elasticsearch.common.inject.spi.ConvertedConstantBinding
-
Returns the converted value.
- getValue() - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.BytesRefs
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Dates
-
Fetch the first field value or 0 millis after epoch if there are no in.
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
- getValue() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Strings
- getValue() - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Returns the current value of the parameter
- getValue() - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType.IpScriptDocValues
- getValue() - Method in enum class org.elasticsearch.index.VersionType
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.Avg
-
The average value.
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.Cardinality
-
The number of unique terms.
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.InternalAvg
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.InternalCardinality
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.InternalMax
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.InternalMin
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.InternalSum
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.InternalValueCount
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.InternalWeightedAvg
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.Max
-
The maximum.
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.Min
-
The minimum.
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedAvg
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedCardinality
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedMax
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedMin
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedSum
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedValueCount
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedWeightedAvg
- getValue() - Method in class org.elasticsearch.search.aggregations.metrics.Percentile
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.Sum
-
The sum.
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.ValueCount
- getValue() - Method in interface org.elasticsearch.search.aggregations.metrics.WeightedAvg
-
The average value.
- getValue() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- getValue() - Method in class org.elasticsearch.search.lookup.FieldLookup
- getValue(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForDoubles
- getValue(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForFloats
- getValue(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForLongs
- getValue(long) - Method in class org.elasticsearch.search.sort.BucketedSort
-
Get the value at an index.
- getValue(String) - Method in interface org.elasticsearch.common.settings.SettingUpgrader
-
The logic to upgrade the setting value.
- getValue(Setting<T>) - Method in class org.elasticsearch.index.IndexSettings
- getValue(Settings, Settings) - Method in interface org.elasticsearch.common.settings.AbstractScopedSettings.SettingUpdater
-
Returns the instance value for the current settings.
- getValueAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
- getValueAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregation.SingleValue
- getValueAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedCardinality
- getValueAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- getValueAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedValueCount
- getValueCount() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns the number of distinct ordinals in this builder.
- getValueFor(String) - Method in class org.elasticsearch.common.logging.ESLogMessage
- getValues() - Method in class org.elasticsearch.common.document.DocumentField
-
The field values.
- getValues() - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- getValues() - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- getValues() - Method in class org.elasticsearch.search.lookup.FieldLookup
- getValues(long) - Method in class org.elasticsearch.search.sort.BucketedSort
-
Get the values for a bucket if it has been collected.
- getValues(long, BucketedSort.ResultBuilder<T>) - Method in class org.elasticsearch.search.sort.BucketedSort
-
Get the values for a bucket if it has been collected.
- getValues(String) - Method in class org.elasticsearch.script.CompositeFieldScript
-
Runs the object script and returns the values that were emitted for the provided field name
- getValues(IndexableField[]) - Static method in class org.elasticsearch.index.termvectors.TermVectorsService
-
Returns an array of values of the field specified as the method parameter.
- getValues(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
- getValues(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.DoubleValuesComparatorSource
- getValues(ValuesSource.Numeric, LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTermsAggregator
- getValuesAsStrings(String) - Method in interface org.elasticsearch.search.aggregations.metrics.MultiValueAggregation
-
Return a list of all results with the specified name
- getValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance.Factory
- getValueSourceType() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
- getValuesSource() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- getValuesSourceRegistry() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- getValuesSourceRegistry() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
The
ValuesSourceRegistry
to resolveAggregator
s and the like. - getValuesSourceRegistry() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- getValuesSourceRegistry() - Method in class org.elasticsearch.search.SearchModule
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.BooleanScriptFieldData
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.DateScriptFieldData
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.DoubleScriptFieldData
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.GeoPointScriptFieldData
- getValuesSourceType() - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
-
The ValuesSourceType of the underlying data.
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.IndexHistogramFieldData
- getValuesSourceType() - Method in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.IpScriptFieldData
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.LongScriptFieldData
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData.Consumer
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointIndexFieldData
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.plain.StringBinaryIndexFieldData
- getValuesSourceType() - Method in class org.elasticsearch.index.fielddata.StringScriptFieldData
- getValuesSourceType() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldData
- getValuesSourceType() - Method in enum class org.elasticsearch.search.aggregations.support.ValueType
- getValueType() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange.Factory
- getValueType() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance.Factory
- getValueType() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Factory
- getVariance() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The population variance of the collected values.
- getVariance() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getVariance() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getVarianceAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The population variance of the collected values as a String.
- getVarianceAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getVarianceAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getVariancePopulation() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The population variance of the collected values.
- getVariancePopulation() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getVariancePopulation() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getVariancePopulationAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The population variance of the collected values as a String.
- getVariancePopulationAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getVariancePopulationAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getVarianceSampling() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The sampling variance of the collected values.
- getVarianceSampling() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getVarianceSampling() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getVarianceSamplingAsString() - Method in interface org.elasticsearch.search.aggregations.metrics.ExtendedStats
-
The sampling variance of the collected values as a String.
- getVarianceSamplingAsString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getVarianceSamplingAsString() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- getVerifyIndex() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- getVersion() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.IndexInfo
- getVersion() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
-
The current ES version
- getVersion() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
The version of the action.
- getVersion() - Method in class org.elasticsearch.action.DocWriteResponse
-
Returns the current version of the doc.
- getVersion() - Method in class org.elasticsearch.action.get.GetResponse
-
The version of the doc.
- getVersion() - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- getVersion() - Method in class org.elasticsearch.action.main.MainResponse
- getVersion() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- getVersion() - Method in class org.elasticsearch.cluster.ClusterState
- getVersion() - Method in class org.elasticsearch.cluster.coordination.PublishResponse
- getVersion() - Method in class org.elasticsearch.cluster.coordination.ApplyCommitRequest
- getVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- getVersion() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- getVersion() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- getVersion() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- getVersion() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
The version of the node on the other side of this stream.
- getVersion() - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
The version of the node on the other side of this stream.
- getVersion() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
- getVersion() - Method in class org.elasticsearch.index.engine.Engine.Result
-
get the updated document version
- getVersion() - Method in class org.elasticsearch.index.engine.Segment
- getVersion() - Method in class org.elasticsearch.index.get.GetResult
-
The version of the doc.
- getVersion() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getVersion() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The version of the match or
-1
if the version wasn't requested. - getVersion() - Method in class org.elasticsearch.index.shard.ReplicationGroup
- getVersion() - Method in class org.elasticsearch.ingest.Pipeline
-
An optional version stored with the pipeline so that it can be used to determine if the pipeline should be updated / replaced.
- getVersion() - Method in class org.elasticsearch.ingest.PipelineConfiguration
- getVersion() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getVersion() - Method in class org.elasticsearch.monitor.os.OsInfo
- getVersion() - Method in class org.elasticsearch.plugins.PluginDescriptor
-
The version of the plugin
- getVersion() - Method in class org.elasticsearch.repositories.RepositoryData.SnapshotDetails
- getVersion() - Method in class org.elasticsearch.search.SearchHit
-
The version of the hit.
- getVersion() - Method in class org.elasticsearch.transport.NetworkMessage
- getVersion() - Method in class org.elasticsearch.transport.TaskTransportChannel
- getVersion() - Method in class org.elasticsearch.transport.TcpTransport
- getVersion() - Method in class org.elasticsearch.transport.TcpTransport.NodeChannels
- getVersion() - Method in class org.elasticsearch.transport.TcpTransportChannel
- getVersion() - Method in interface org.elasticsearch.transport.Transport.Connection
-
Returns the version of the node this connection was established with.
- getVersion() - Method in interface org.elasticsearch.transport.TransportChannel
-
Returns the version of the other party that this channel will send a response to.
- getVersion() - Method in class org.elasticsearch.transport.TransportService.HandshakeResponse
- getVersion(SnapshotId) - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns the
Version
for the given snapshot ornull
if unknown. - getVersionConflicts() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- getVersionConflicts() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Number of version conflicts this request has hit.
- getVersionMapMemory() - Method in class org.elasticsearch.index.engine.SegmentsStats
- getVersionMapMemoryInBytes() - Method in class org.elasticsearch.index.engine.SegmentsStats
-
Estimation of the memory usage by version map
- getVersionMetaKey() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- getVersionOrMetadataVersion() - Method in class org.elasticsearch.cluster.ClusterState
- getVersions() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- getVersions() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- getVersions() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
- getVIntKeySerializer() - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Returns a map key serializer for Integer keys.
- getVmName() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getVmVendor() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getVmVersion() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- getVotingConfigExclusions() - Method in class org.elasticsearch.cluster.ClusterState
- getVotingConfigExclusions() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- getWaitForActiveShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Returns the configured
IndexMetadata.SETTING_WAIT_FOR_ACTIVE_SHARDS
, which defaults to an active shard count of 1 if not specified. - getWaitForActiveShards() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
The number of shard copies that must be active before proceeding with the write.
- getWaitForCheckpoints() - Method in class org.elasticsearch.action.search.SearchRequest
- getWaitForCheckpointsTimeout() - Method in class org.elasticsearch.action.search.SearchRequest
- getWaitForCheckpointsTimeout() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- getWaitForCompletion() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
-
Should this request wait for all found tasks to complete?
- getWaitForCompletion() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
-
Should this request wait for all found tasks to complete?
- getWaitForRemoval() - Method in class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsRequest
- getWarmer() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- getWarmer() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns an
Engine.Warmer
used to warm new searchers before they are used for searching. - getWarmer() - Method in class org.elasticsearch.indices.NodeIndicesStats
- getWeekOfWeekyear() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getWeekyear() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getWeight() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.FilterScoreFunction
- getWeight() - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
- getWeight() - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- getWeight() - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
The weight applied to the function before combining.
- getWeight() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregatorFactory
-
Returns the
Weight
for this filter aggregation, creating it if necessary. - getWeightRanking() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
-
The weight ranking for allocating a shard to the node.
- getWhitespaceNormalizer(String) - Method in class org.elasticsearch.index.analysis.IndexAnalyzers
-
Returns a normalizer that splits on whitespace mapped to the given name or
null
if not present - getWildcardQuery(String, String) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- getWindow() - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
-
Returns the window size for this aggregation
- getWindowSize() - Method in class org.elasticsearch.search.rescore.RescoreContext
-
Size of the window to rescore.
- getWordList(Environment, Settings, String) - Static method in class org.elasticsearch.index.analysis.Analysis
-
Fetches a list of words from the specified settings file.
- getWordList(Environment, Settings, String, String, boolean) - Static method in class org.elasticsearch.index.analysis.Analysis
-
Fetches a list of words from the specified settings file.
- getWordSet(Environment, Settings, String) - Static method in class org.elasticsearch.index.analysis.Analysis
- getWorkerState() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Returns the object that manages sending search requests.
- getWrappedAnalyzer(String) - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
- getWrappedAnalyzer(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.LimitTokenOffsetAnalyzer
- getWriteableName() - Method in class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- getWriteableName() - Method in class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- getWriteableName() - Method in class org.elasticsearch.action.admin.indices.rollover.MaxPrimaryShardSizeCondition
- getWriteableName() - Method in class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- getWriteableName() - Method in class org.elasticsearch.action.support.replication.ReplicationTask.Status
- getWriteableName() - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownCondition
- getWriteableName() - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownMetadataCustom
- getWriteableName() - Method in class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- getWriteableName() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- getWriteableName() - Method in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- getWriteableName() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- getWriteableName() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.IndexGraveyardDiff
- getWriteableName() - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- getWriteableName() - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata.NodeShutdownMetadataDiff
- getWriteableName() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
-
Returns the name of the writeable object
- getWriteableName() - Method in class org.elasticsearch.cluster.RepositoryCleanupInProgress
- getWriteableName() - Method in class org.elasticsearch.cluster.RestoreInProgress
-
Returns the name of the writeable object
- getWriteableName() - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand
- getWriteableName() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- getWriteableName() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- getWriteableName() - Method in interface org.elasticsearch.common.io.stream.NamedWriteable
-
Returns the name of the writeable object
- getWriteableName() - Method in interface org.elasticsearch.common.io.stream.VersionedNamedWriteable
-
Returns the name of the writeable object
- getWriteableName() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- getWriteableName() - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.DistanceFeatureQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.ExistsQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.
- getWriteableName() - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.IdsQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.IntervalQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Combine
- getWriteableName() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Disjunction
- getWriteableName() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Fuzzy
- getWriteableName() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Match
- getWriteableName() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Prefix
- getWriteableName() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Wildcard
- getWriteableName() - Method in class org.elasticsearch.index.query.MatchAllQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MatchNoneQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.NestedQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.ScriptQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanOrQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanTermQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.TermQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.TypeQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- getWriteableName() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- getWriteableName() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- getWriteableName() - Method in class org.elasticsearch.ingest.IngestMetadata
- getWriteableName() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- getWriteableName() - Method in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- getWriteableName() - Method in class org.elasticsearch.script.ScriptMetadata
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilter
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoTileGrid
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.global.InternalGlobal
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.missing.InternalMissing
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ChiSquare
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.GND
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.JLHScore
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.MutualInformation
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.PercentageScore
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalAvg
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalCardinality
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalMax
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalMedianAbsoluteDeviation
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalMin
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalScriptedMetric
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalSum
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTopHits
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalValueCount
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.metrics.InternalWeightedAvg
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalBucketMetricValue
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalDerivative
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalExtendedStatsBucket
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalStatsBucket
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.MaxBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.MaxBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.MinBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.MinBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
-
Deprecated.pipeline aggregations added after 7.8.0 don't need to implement this
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.StatsBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.StatsBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.SumBucketPipelineAggregationBuilder
- getWriteableName() - Method in class org.elasticsearch.search.aggregations.pipeline.SumBucketPipelineAggregator
- getWriteableName() - Method in class org.elasticsearch.search.DocValueFormat.BinaryDocValueFormat
- getWriteableName() - Method in class org.elasticsearch.search.DocValueFormat.BooleanDocValueFormat
- getWriteableName() - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- getWriteableName() - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- getWriteableName() - Method in class org.elasticsearch.search.DocValueFormat.GeoHashDocValueFormat
- getWriteableName() - Method in class org.elasticsearch.search.DocValueFormat.GeoTileDocValueFormat
- getWriteableName() - Method in class org.elasticsearch.search.DocValueFormat.IpDocValueFormat
- getWriteableName() - Method in class org.elasticsearch.search.DocValueFormat.RawDocValueFormat
- getWriteableName() - Method in class org.elasticsearch.search.DocValueFormat.UnsignedLongShiftedDocValueFormat
- getWriteableName() - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- getWriteableName() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- getWriteableName() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- getWriteableName() - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- getWriteableName() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- getWriteableName() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- getWriteableName() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- getWriteableName() - Method in class org.elasticsearch.search.suggest.phrase.Laplace
- getWriteableName() - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- getWriteableName() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
- getWriteableName() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- getWriteableName() - Method in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- getWriteableName() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- getWriteableName() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- getWriteableName() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
- getWriteableName() - Method in class org.elasticsearch.tasks.RawTaskStatus
- getWriteableName() - Method in class org.elasticsearch.upgrades.FeatureMigrationResults
- getWriteableName() - Method in class org.elasticsearch.upgrades.FeatureMigrationResults.ResultsDiff
- getWriteableName() - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskParams
- getWriteableName() - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskState
- getWriteableRegistry() - Method in class org.elasticsearch.index.query.QueryRewriteContext
- getWriteableType() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- getWriteableType() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
- getWriteableType() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
-
Deprecated.
- getWriteableType() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- getWriteDataStream() - Method in class org.elasticsearch.cluster.metadata.AliasAction.AddDataStreamAlias
- getWriteDataStream() - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
-
Returns the write data stream this data stream alias is referring to.
- getWriteExecutorForShard(ExecutorSelector, IndexShard) - Static method in class org.elasticsearch.indices.ExecutorSelector
-
This is a convenience method for the case when we need to find an executor for a shard.
- getWriteIndex() - Method in class org.elasticsearch.cluster.metadata.DataStream
- getWriteIndex() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- getWriteIndex() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.ConcreteIndex
- getWriteIndex() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- getWriteIndex() - Method in interface org.elasticsearch.cluster.metadata.IndexAbstraction
-
A write index is a dedicated concrete index, that accepts all the new documents that belong to an index abstraction.
- getWriter() - Method in class org.elasticsearch.bootstrap.plugins.LoggerTerminal
- getWritingBytes() - Method in class org.elasticsearch.index.engine.Engine
-
Returns how many bytes we are currently moving from heap to disk
- getWritingBytes() - Method in class org.elasticsearch.index.engine.InternalEngine
-
Returns how many bytes we are currently moving from indexing buffer to segments on disk
- getWritingBytes() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- getWritingBytes() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns how many bytes we are currently moving from heap to disk
- getX() - Method in class org.apache.lucene.geo.XTessellator.Node
-
get the x value
- getX(int) - Method in class org.apache.lucene.geo.XTessellator.Triangle
-
get x value for the given vertex
- getXContentHumanReadableTransformers() - Method in class org.elasticsearch.common.xcontent.XContentElasticsearchExtension
- getXContentRegistry() - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
The registry used to build new
XContentParser
s. - getXContentRegistry() - Method in class org.elasticsearch.rest.RestRequest
-
Get the
NamedXContentRegistry
that should be used to create parsers from this request. - getXContentType() - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- getXContentType() - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- getXContentType() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- getXContentType() - Method in class org.elasticsearch.index.mapper.SourceToParse
- getXContentType() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- getXContentType() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.Hit
-
The content type of the hit source.
- getXContentType() - Method in class org.elasticsearch.rest.RestRequest
-
The
XContentType
that was parsed from theContent-Type
header. - getXContentWriters() - Method in class org.elasticsearch.common.xcontent.XContentElasticsearchExtension
- getXOpaqueId() - Static method in class org.elasticsearch.common.logging.HeaderWarning
- getXTile(double, long) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
-
Calculates the x-coordinate in the tile grid for the specified longitude given the number of tile columns for a pre-determined zoom-level.
- getY() - Method in class org.apache.lucene.geo.XTessellator.Node
-
get the y value
- getY(int) - Method in class org.apache.lucene.geo.XTessellator.Triangle
-
get y value for the given vertex
- getYear() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getYearOfCentury() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getYearOfEra() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- getYesDecisionMessages() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
-
Provides feedback from commands with a YES decision that should be displayed to the user after the command has been applied
- getYTile(double, long) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
-
Calculates the y-coordinate in the tile grid for the specified longitude given the number of tile rows for pre-determined zoom-level.
- getZone() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- getZonedDateTime() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- giga() - Method in class org.elasticsearch.common.unit.SizeValue
- GIGA - Enum constant in enum class org.elasticsearch.common.unit.SizeUnit
- gigaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- gloabalOrdsFilter(IncludeExclude, DocValueFormat, SortedSetDocValues) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
- global() - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- global(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Global
aggregation with the given name. - global(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- Global - Interface in org.elasticsearch.search.aggregations.bucket.global
-
A
global
aggregation. - GLOBAL - Enum constant in enum class org.elasticsearch.index.analysis.AnalyzerScope
- GLOBAL_CHECKPOINT_SYNC_INTERVAL_SETTING - Static variable in class org.elasticsearch.index.IndexService
- GLOBAL_METADATA_FORMAT - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- GLOBAL_NETWORK_BIND_HOST_SETTING - Static variable in class org.elasticsearch.common.network.NetworkService
- GLOBAL_NETWORK_HOST_SETTING - Static variable in class org.elasticsearch.common.network.NetworkService
- GLOBAL_NETWORK_PUBLISH_HOST_SETTING - Static variable in class org.elasticsearch.common.network.NetworkService
- GLOBAL_ORDINALS - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
- GLOBAL_ORDINALS - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregatorFactory.ExecutionMode
- GLOBAL_ORDINALS - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
- GLOBAL_STATE_FILE_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- GLOBAL_TEXT_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestBuilder
- GlobalAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.global
- GlobalAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- GlobalAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
-
Read from a stream.
- GlobalAggregationBuilder(GlobalAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- GlobalAggregator - Class in org.elasticsearch.search.aggregations.bucket.global
- GlobalAggregator(String, AggregatorFactories, AggregationContext, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregator
- GlobalAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.global
- GlobalAggregatorFactory(String, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregatorFactory
- globalBlockedException(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- globalBlockedRaiseException(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- globalBlockLevel() - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- globalBlockLevel() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Cluster level block to check before request execution.
- globalBlockLevel() - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- globalCheckpoint() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Returns the persisted global checkpoint on the primary shard.
- globalCheckpoint() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.ReplicaResponse
-
The persisted global checkpoint for the shard.
- globalCheckpoint() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResponse
- GlobalCheckpointListeners - Class in org.elasticsearch.index.shard
-
Represents a collection of global checkpoint listeners.
- GlobalCheckpointListeners.GlobalCheckpointListener - Interface in org.elasticsearch.index.shard
-
A global checkpoint listener consisting of a callback that is notified when the global checkpoint is updated or the shard is closed.
- GlobalCheckpointSyncAction - Class in org.elasticsearch.index.seqno
-
Background global checkpoint sync action initiated when a shard goes inactive.
- GlobalCheckpointSyncAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters) - Constructor for class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- GlobalCheckpointSyncAction.Request - Class in org.elasticsearch.index.seqno
- globalMaxOrd(IndexSearcher) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
-
Get the maximum global ordinal.
- GlobalOrdCardinalityAggregator - Class in org.elasticsearch.search.aggregations.metrics
-
An aggregator that computes approximate counts of unique values using global ords.
- GlobalOrdCardinalityAggregator(String, ValuesSource.Bytes.WithOrdinals, int, int, AggregationContext, Aggregator, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.GlobalOrdCardinalityAggregator
- GlobalOrdinalsBuilder - Enum Class in org.elasticsearch.index.fielddata.ordinals
-
Utility class to build global ordinals.
- GlobalOrdinalsIndexFieldData - Class in org.elasticsearch.index.fielddata.ordinals
-
Concrete implementation of
IndexOrdinalsFieldData
for global ordinals. - GlobalOrdinalsIndexFieldData(String, ValuesSourceType, LeafOrdinalsFieldData[], OrdinalMap, long, Function<SortedSetDocValues, ScriptDocValues<?>>) - Constructor for class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- GlobalOrdinalsIndexFieldData.Consumer - Class in org.elasticsearch.index.fielddata.ordinals
-
A non-thread safe
IndexOrdinalsFieldData
for global ordinals that creates theTermsEnum
of each segment once and use them to provide a single lookup per segment. - globalOrdinalsMapping(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
- globalOrdinalsMapping(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
-
Returns a mapping from segment ordinals to global ordinals.
- GlobalOrdinalsStringTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
-
An aggregator of string values that relies on global ordinals in order to build buckets.
- GlobalOrdinalsStringTermsAggregator(String, AggregatorFactories, Function<GlobalOrdinalsStringTermsAggregator, GlobalOrdinalsStringTermsAggregator.ResultStrategy<?, ?, ?>>, ValuesSource.Bytes.WithOrdinals, SortedSetDocValues, BucketOrder, DocValueFormat, TermsAggregator.BucketCountThresholds, LongPredicate, AggregationContext, Aggregator, boolean, Aggregator.SubAggCollectionMode, boolean, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- GlobalOrdinalsStringTermsAggregator.GlobalOrdLookupFunction - Interface in org.elasticsearch.search.aggregations.bucket.terms
- globalOrdinalsValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
- globalOrdinalsValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
-
Get a "global" view into the leaf's ordinals.
- globalOrdsValues(AggregationContext, ValuesSource.Bytes.WithOrdinals) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory
- GND - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- GND(boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.GND
- GND(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.GND
-
Read from a stream.
- GND.GNDBuilder - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- GNDBuilder(boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.GND.GNDBuilder
- GONE - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The requested resource is no longer available at the server and no forwarding address is known.
- gramSize() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the
PhraseSuggestionBuilder.gramSize(int)
parameter - gramSize(int) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets the gram size for the n-gram model used for this suggester.
- GRAMSIZE_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- GREEN - Enum constant in enum class org.elasticsearch.cluster.health.ClusterHealthStatus
- groupBy(ShardOperationFailedException[]) - Static method in class org.elasticsearch.ExceptionsHelper
-
Deduplicate the failures by exception message and index.
- groupClusterIndices(Set<String>, String[], Predicate<String>) - Method in class org.elasticsearch.transport.RemoteClusterAware
-
Groups indices per cluster by splitting remote cluster-alias, index-name pairs on
RemoteClusterAware.REMOTE_CLUSTER_INDEX_SEPARATOR
. - GroupedActionListener<T> - Class in org.elasticsearch.action.support
-
An action listener that delegates its results to another listener once it has received N results (either successes or failures).
- GroupedActionListener(ActionListener<Collection<T>>, int) - Constructor for class org.elasticsearch.action.support.GroupedActionListener
-
Creates a new listener
- groupIndices(IndicesOptions, String[], Predicate<String>) - Method in class org.elasticsearch.transport.RemoteClusterService
- GroupKey(String) - Constructor for class org.elasticsearch.common.settings.Setting.GroupKey
- groups() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- groups() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- groups(String...) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
Sets specific search group stats to retrieve the stats for.
- groups(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
Sets specific search group stats to retrieve the stats for.
- groupSetting(String, Consumer<Settings>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- groupSetting(String, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- GroupShardsIterator<ShardIt extends Comparable<ShardIt> & Countable> - Class in org.elasticsearch.cluster.routing
-
This class implements a compilation of
ShardIterator
s. - GroupShardsIterator(List<ShardIt>) - Constructor for class org.elasticsearch.cluster.routing.GroupShardsIterator
-
Constructs a new GroupShardsIterator from the given list.
- groupStats() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- groupStats() - Method in class org.elasticsearch.search.internal.SearchContext
- groupStats(List<String>) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- groupStats(List<String>) - Method in class org.elasticsearch.search.internal.SearchContext
- groupStats(List<String>) - Method in class org.elasticsearch.search.internal.SubSearchContext
- grow() - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
- grow() - Method in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
-
Make sure the
SortingBinaryDocValues.values
array can store at leastSortingBinaryDocValues.count
entries. - grow(long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Ensure there are at least
maxBucketOrd
buckets available. - grow(ByteArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Grow an array to a size that is larger than
minSize
, preserving content, and potentially reusing part of the provided array. - grow(DoubleArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Grow an array to a size that is larger than
minSize
, preserving content, and potentially reusing part of the provided array. - grow(FloatArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Grow an array to a size that is larger than
minSize
, preserving content, and potentially reusing part of the provided array. - grow(IntArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Grow an array to a size that is larger than
minSize
, preserving content, and potentially reusing part of the provided array. - grow(LongArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Grow an array to a size that is larger than
minSize
, preserving content, and potentially reusing part of the provided array. - grow(ObjectArray<T>, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Grow an array to a size that is larger than
minSize
, preserving content, and potentially reusing part of the provided array. - growExact(int) - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
-
Grow the array in a method so we can override it during testing
- growValues(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForDoubles
- growValues(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForFloats
- growValues(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForLongs
- growValues(long) - Method in class org.elasticsearch.search.sort.BucketedSort
-
Grow the BigArray backing this sort to account for new buckets.
- gt(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- GT_FIELD - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- gte(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The from part of the range query.
- GTE_FIELD - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- guardedRamBytesUsed(Accountable) - Static method in class org.elasticsearch.index.engine.Engine
-
Returns 0 in the case where accountable is null, otherwise returns
ramBytesUsed()
- guessRootCauses() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- guessRootCauses() - Method in exception org.elasticsearch.ElasticsearchException
-
Returns the root cause of this exception or multiple if different shards caused different exceptions
- guessRootCauses(Throwable) - Static method in exception org.elasticsearch.ElasticsearchException
-
Returns the root cause of this exception or multiple if different shards caused different exceptions.
- Guice - Class in org.elasticsearch.common.inject
-
The entry point to the Guice framework.
H
- h1 - Variable in class org.elasticsearch.common.hash.MurmurHash3.Hash128
-
lower 64 bits part
- h2 - Variable in class org.elasticsearch.common.hash.MurmurHash3.Hash128
-
higher 64 bits part
- HALF_FLOAT - Enum constant in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- HALF_FLOAT - Enum constant in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- handle(int) - Method in interface org.elasticsearch.bootstrap.ConsoleCtrlHandler
-
Handles the Ctrl event.
- handle(Object, Errors) - Method in interface org.elasticsearch.common.inject.internal.ErrorHandler
-
Handles an error.
- handle(Message) - Method in interface org.elasticsearch.common.inject.internal.ErrorHandler
-
Handles a user-reported error.
- handleBareFuzzy(String, Token, String) - Method in class org.apache.lucene.queryparser.classic.XQueryParser
- handleBareFuzzy(String, Token, String) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- handleBytes(TcpChannel, ReleasableBytesReference) - Method in class org.elasticsearch.transport.InboundPipeline
- handleCancel() - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- handleClientValue(ClusterState) - Method in class org.elasticsearch.cluster.coordination.CoordinationState
-
May be called in order to prepare publication of the given cluster state
- handleCommit(ApplyCommitRequest) - Method in class org.elasticsearch.cluster.coordination.CoordinationState
-
May be called on receipt of an ApplyCommitRequest.
- handleCommitRequest(PublishClusterStateAction.CommitClusterStateRequest, TransportChannel) - Method in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- HandledTransportAction<Request extends ActionRequest,
Response extends ActionResponse> - Class in org.elasticsearch.action.support -
A TransportAction that self registers a handler into the transport service
- HandledTransportAction(String, boolean, TransportService, ActionFilters, Writeable.Reader<Request>) - Constructor for class org.elasticsearch.action.support.HandledTransportAction
- HandledTransportAction(String, boolean, TransportService, ActionFilters, Writeable.Reader<Request>, String) - Constructor for class org.elasticsearch.action.support.HandledTransportAction
- HandledTransportAction(String, TransportService, ActionFilters, Writeable.Reader<Request>) - Constructor for class org.elasticsearch.action.support.HandledTransportAction
- HandledTransportAction(String, TransportService, ActionFilters, Writeable.Reader<Request>, String) - Constructor for class org.elasticsearch.action.support.HandledTransportAction
- handleError(Source, Exception) - Method in class org.elasticsearch.indices.recovery.MultiChunkTransfer
- handleException(TransportException) - Method in class org.elasticsearch.action.ActionListenerResponseHandler
- handleException(TransportException) - Method in class org.elasticsearch.transport.EmptyTransportResponseHandler
- handleException(TransportException) - Method in class org.elasticsearch.transport.FutureTransportResponseHandler
- handleException(TransportException) - Method in class org.elasticsearch.transport.PlainTransportFuture
- handleException(TransportException) - Method in interface org.elasticsearch.transport.TransportResponseHandler
- handleException(TransportException) - Method in class org.elasticsearch.transport.TransportService.ContextRestoreResponseHandler
- handleInbound(HttpRequest) - Method in class org.elasticsearch.http.CorsHandler
- handleIncomingClusterStateRequest(BytesTransportRequest, TransportChannel) - Method in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- handleJoin(Join) - Method in class org.elasticsearch.cluster.coordination.CoordinationState
-
May be called on receipt of a Join.
- handleJoinRequest(DiscoveryNode, MembershipAction.JoinCallback) - Method in class org.elasticsearch.discovery.zen.NodeJoinController
-
processes or queues an incoming join request.
- handleNow(SearchExecutionContext, Function<LongSupplier, Query>) - Static method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
-
Handle
now
in queries. - handlePrimaryRequest(TransportReplicationAction.ConcreteShardRequest<Request>, TransportChannel, Task) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- handlePublishRequest(PublishRequest) - Method in class org.elasticsearch.cluster.coordination.CoordinationState
-
May be called on receipt of a PublishRequest.
- handlePublishResponse(DiscoveryNode, PublishResponse) - Method in class org.elasticsearch.cluster.coordination.CoordinationState
-
May be called on receipt of a PublishResponse from the given sourceNode.
- handlePublishResponse(DiscoveryNode, PublishResponse) - Method in class org.elasticsearch.cluster.coordination.Publication
- handler() - Method in class org.elasticsearch.transport.Transport.ResponseContext
- handleReplicaRequest(TransportReplicationAction.ConcreteReplicaRequest<ReplicaRequest>, TransportChannel, Task) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- handleRequest(RestRequest, RestChannel, NodeClient) - Method in class org.elasticsearch.rest.BaseRestHandler
- handleRequest(RestRequest, RestChannel, NodeClient) - Method in class org.elasticsearch.rest.DeprecationRestHandler
-
Handles a rest request.
- handleRequest(RestRequest, RestChannel, NodeClient) - Method in interface org.elasticsearch.rest.RestHandler
-
Handles a rest request.
- handleResponse(TransportResponse.Empty) - Method in class org.elasticsearch.transport.EmptyTransportResponseHandler
- handleResponse(Response) - Method in class org.elasticsearch.action.ActionListenerResponseHandler
- handleResponse(T) - Method in class org.elasticsearch.transport.FutureTransportResponseHandler
- handleResponse(T) - Method in interface org.elasticsearch.transport.TransportResponseHandler
- handleResponse(T) - Method in class org.elasticsearch.transport.TransportService.ContextRestoreResponseHandler
- handleResponse(V) - Method in class org.elasticsearch.transport.PlainTransportFuture
- handleStartJoin(StartJoinRequest) - Method in class org.elasticsearch.cluster.coordination.CoordinationState
-
May be safely called at any time to move this instance to a new term.
- handlesThrowable() - Method in class org.elasticsearch.common.logging.JsonThrowablePatternConverter
- handleTransportDisconnect(DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- handleTransportDisconnect(DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
- handlingSettings - Variable in class org.elasticsearch.http.AbstractHttpServerTransport
- HANDOFF_PRIMARY_CONTEXT - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- handoffPrimaryContext(ReplicationTracker.PrimaryContext, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- handoffPrimaryContext(ReplicationTracker.PrimaryContext, ActionListener<Void>) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
Handoff the primary context between the relocation source and the relocation target.
- handoffPrimaryContext(ReplicationTracker.PrimaryContext, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- handshake(Transport.Connection, TimeValue, Predicate<ClusterName>, ActionListener<TransportService.HandshakeResponse>) - Method in class org.elasticsearch.transport.TransportService
-
Executes a high-level handshake using the given connection and returns the discovery node of the node the connection was established with.
- handshake(Transport.Connection, TimeValue, ActionListener<DiscoveryNode>) - Method in class org.elasticsearch.transport.TransportService
-
Executes a high-level handshake using the given connection and returns the discovery node of the node the connection was established with.
- HANDSHAKE_ACTION_NAME - Static variable in class org.elasticsearch.transport.TransportService
- HandshakeResponse(StreamInput, boolean) - Constructor for class org.elasticsearch.transport.TransportService.HandshakeResponse
- HandshakeResponse(Version, String, DiscoveryNode, ClusterName) - Constructor for class org.elasticsearch.transport.TransportService.HandshakeResponse
- HandshakingTransportAddressConnector - Class in org.elasticsearch.discovery
- HandshakingTransportAddressConnector(Settings, TransportService) - Constructor for class org.elasticsearch.discovery.HandshakingTransportAddressConnector
- HARD_BOUNDS_FIELD - Static variable in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
- hardBounds - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- hardBounds() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Return hard bounds for this histogram, or
null
if none are set. - hardBounds(DoubleBounds) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Set hard bounds on this histogram, specifying boundaries outside which buckets cannot be created.
- hardBounds(LongBounds) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set hard bounds on this histogram, specifying boundaries outside which buckets cannot be created.
- HasAggregations - Interface in org.elasticsearch.search.aggregations
- hasAggs() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns
true
if this query result has unconsumed aggregations - hasAlias(String) - Method in class org.elasticsearch.cluster.metadata.Metadata
- hasAliases(String[], String[]) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Checks if at least one of the specified aliases exists in the specified concrete indices.
- hasAllFieldsWildcard(Collection<String>) - Static method in class org.elasticsearch.index.search.QueryParserHelper
-
Returns true if any of the fields is the wildcard
*
, false otherwise. - hasAllPeerRecoveryRetentionLeases() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
- hasArray() - Method in class org.elasticsearch.common.bytes.BytesArray
- hasArray() - Method in interface org.elasticsearch.common.bytes.BytesReference
- hasArray() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- hasArray() - Method in interface org.elasticsearch.common.util.ByteArray
-
Checks if this instance is backed by a single byte array analogous to
ByteBuffer.hasArray()
. - hasAsyncActions() - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
Returns
true
if there are any registered async actions. - hasAtomicOverwrites() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- hasAtomicOverwrites() - Method in class org.elasticsearch.repositories.fs.FsRepository
- hasBeenProcessedBefore(Engine.Operation) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Checks if the given operation has been processed in this engine or not.
- hasBytes() - Method in class org.elasticsearch.common.text.Text
-
Whether a
BytesReference
view of the data is already materialized. - hasCancellations() - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- hasChanged(Settings, Settings) - Method in interface org.elasticsearch.common.settings.AbstractScopedSettings.SettingUpdater
-
Returns true if this updaters setting has changed with the current update
- hasChanges() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- hasClauses() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Returns
true
iff this query builder has at least one should, must, must not or filter clause. - hasCleanupInProgress() - Method in class org.elasticsearch.cluster.RepositoryCleanupInProgress
- hasCompleteHistoryOperations(String, Engine.HistorySource, long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Checks if we have a completed history of operations since the given starting seqno (inclusive).
- hasCompleteOperationHistory(String, Engine.HistorySource, MapperService, long) - Method in class org.elasticsearch.index.engine.Engine
-
Checks if this engine has every operations since
startingSeqNo
(inclusive) in its history (either Lucene or translog) - hasCompleteOperationHistory(String, Engine.HistorySource, MapperService, long) - Method in class org.elasticsearch.index.engine.InternalEngine
- hasCompleteOperationHistory(String, Engine.HistorySource, MapperService, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- hasConsumedTopDocs() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns
true
iff the top docs have already been consumed. - hasContent() - Method in class org.elasticsearch.rest.RestRequest
- hasContentOrSourceParam() - Method in class org.elasticsearch.rest.RestRequest
-
Does this request have content or a
source
parameter? Use this instead ofRestRequest.hasContent()
if this RestHandler treats thesource
parameter like the body content. - hasContextMappings() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- hasContextSettings() - Method in class org.elasticsearch.script.ScriptService.ContextSettings
-
Are there any context specific settings
- hasCustomDataPath() - Method in class org.elasticsearch.index.IndexSettings
-
Returns
true
if the index has a custom data path - hasData() - Method in class org.elasticsearch.gateway.AsyncShardFetch.FetchResult
-
Does the result actually contain data? If not, then there are on going fetch operations happening, and it should wait for it.
- hasDataRole(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Check if the given settings are indicative of having the top-level data role.
- hasDecimalPart(Object) - Static method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
-
Returns true if the object is a number and has a decimal part
- hasDeletionsInProgress() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
-
Returns
true
if there are snapshot deletions in progress in the cluster, returnsfalse
otherwise. - HasDependencies - Interface in org.elasticsearch.common.inject.spi
- hasDifferentPhysicalFiles(Store.MetadataSnapshot) - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshot
- hasDocValues() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- hasDynamicMappings() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- hasEarlyTerminated() - Method in class org.elasticsearch.search.query.EarlyTerminatingCollector
-
Returns true if this collector has early terminated.
- hasEnoughCandidates(Collection<ElectMasterService.MasterCandidate>) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
- hasEnoughMasterNodes(Iterable<DiscoveryNode>) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
- hasErrors() - Method in class org.elasticsearch.common.inject.internal.Errors
- hasExecutingDeletion(String) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
-
Checks if there is an actively executing delete operation for the given repository
- hasExplanation() - Method in class org.elasticsearch.action.explain.ExplainResponse
- hasFailures() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.IndexResult
- hasFailures() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult
- hasFailures() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockResult
- hasFailures() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult
- hasFailures() - Method in class org.elasticsearch.action.bulk.BulkResponse
-
Has anything failed with the execution.
- hasFailures() - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
Determine if there are any node failures in
BaseNodesResponse.failures
. - hasFeature(String) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Test if the stream has the specified feature.
- hasFetchSourceContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- hasFetchSourceContext() - Method in class org.elasticsearch.search.internal.SearchContext
- hasFetchSourceContext() - Method in class org.elasticsearch.search.internal.SubSearchContext
- hasField(String) - Method in class org.elasticsearch.index.search.stats.FieldUsageStats
- hasField(String) - Method in class org.elasticsearch.ingest.IngestDocument
-
Checks whether the document contains a value for the provided path
- hasField(String, boolean) - Method in class org.elasticsearch.ingest.IngestDocument
-
Checks whether the document contains a value for the provided path
- hasField(TemplateScript.Factory) - Method in class org.elasticsearch.ingest.IngestDocument
-
Checks whether the document contains a value for the provided templated path
- hasGaps(TokenStream) - Static method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- hasGlobalBlock(ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- hasGlobalBlockWithId(int) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- hasGlobalBlockWithLevel(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- hasGlobalBlockWithStatus(RestStatus) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
-
Is there a global block with the provided status?
- hash() - Method in class org.elasticsearch.Build
- hash() - Method in class org.elasticsearch.index.store.StoreFileMetadata
-
Returns a variable length hash of the file represented by this metadata object.
- hash(byte[], int, int) - Static method in class org.elasticsearch.cluster.routing.Murmur3HashFunction
- hash(String) - Static method in class org.elasticsearch.cluster.routing.Murmur3HashFunction
- hash128(byte[], int, int, long, MurmurHash3.Hash128) - Static method in enum class org.elasticsearch.common.hash.MurmurHash3
-
Compute the hash of the MurmurHash3_x64_128 hashing function.
- Hash128() - Constructor for class org.elasticsearch.common.hash.MurmurHash3.Hash128
- hashAsLong - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- hashAsString - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoGridBucket
- hashCode() - Method in class org.apache.lucene.queries.BinaryDocValuesRangeQuery
- hashCode() - Method in class org.apache.lucene.queries.BlendedTermQuery
- hashCode() - Method in class org.apache.lucene.queries.MinDocQuery
- hashCode() - Method in class org.apache.lucene.queries.SearchAfterSortedDocQuery
- hashCode() - Method in class org.apache.lucene.queries.SpanMatchNoDocsQuery
- hashCode() - Method in class org.elasticsearch.action.ActionType
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.FeatureUpgradeStatus
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.IndexInfo
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse.Feature
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse
-
We disregard exceptions when calculating hash code
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse.NodeResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse.SnapshottableFeature
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotRequest
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmVersion
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.stats.FieldScriptStats
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.stats.FieldStats
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.stats.IndexFeatureStats
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.stats.MappingStats
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.stats.RuntimeFieldStats
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.stats.VersionStats
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptContextResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptLanguageResponse
- hashCode() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
- hashCode() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- hashCode() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeToken
- hashCode() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeTokenList
- hashCode() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.CharFilteredText
- hashCode() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.DetailAnalyzeResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Response
- hashCode() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- hashCode() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetadata
- hashCode() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Request
- hashCode() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedAlias
- hashCode() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedDataStream
- hashCode() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedIndex
- hashCode() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Response
- hashCode() - Method in class org.elasticsearch.action.admin.indices.rollover.Condition
- hashCode() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- hashCode() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- hashCode() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- hashCode() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- hashCode() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteComposableIndexTemplateAction.Request
- hashCode() - Method in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Response
- hashCode() - Method in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Request
- hashCode() - Method in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Response
- hashCode() - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateRequest
- hashCode() - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateResponse
- hashCode() - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction.Request
- hashCode() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
- hashCode() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- hashCode() - Method in class org.elasticsearch.action.datastreams.ModifyDataStreamsAction.Request
- hashCode() - Method in class org.elasticsearch.action.explain.ExplainResponse
- hashCode() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
- hashCode() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexResponse
- hashCode() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- hashCode() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
- hashCode() - Method in class org.elasticsearch.action.fieldcaps.IndexFieldCapabilities
- hashCode() - Method in class org.elasticsearch.action.get.GetResponse
- hashCode() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- hashCode() - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- hashCode() - Method in class org.elasticsearch.action.main.MainResponse
- hashCode() - Method in class org.elasticsearch.action.OriginalIndices
- hashCode() - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- hashCode() - Method in class org.elasticsearch.action.search.MultiSearchRequest
- hashCode() - Method in class org.elasticsearch.action.search.SearchRequest
- hashCode() - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
- hashCode() - Method in class org.elasticsearch.action.search.SearchScrollRequest
- hashCode() - Method in class org.elasticsearch.action.search.SearchShard
- hashCode() - Method in class org.elasticsearch.action.search.SearchShardIterator
- hashCode() - Method in class org.elasticsearch.action.support.ActiveShardCount
- hashCode() - Method in class org.elasticsearch.action.support.IndicesOptions
- hashCode() - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- hashCode() - Method in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- hashCode() - Method in class org.elasticsearch.action.support.replication.ReplicationTask.Status
- hashCode() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResponse
- hashCode() - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
- hashCode() - Method in class org.elasticsearch.Build
- hashCode() - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.FailedShardEntry
- hashCode() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- hashCode() - Method in class org.elasticsearch.cluster.ClusterInfo.NodeAndPath
- hashCode() - Method in class org.elasticsearch.cluster.ClusterInfo.ReservedSpace
- hashCode() - Method in class org.elasticsearch.cluster.ClusterName
- hashCode() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- hashCode() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfigExclusion
- hashCode() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfiguration
- hashCode() - Method in class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- hashCode() - Method in class org.elasticsearch.cluster.coordination.FollowersChecker.FollowerCheckRequest
- hashCode() - Method in class org.elasticsearch.cluster.coordination.Join
- hashCode() - Method in class org.elasticsearch.cluster.coordination.JoinRequest
- hashCode() - Method in class org.elasticsearch.cluster.coordination.PeersResponse
- hashCode() - Method in class org.elasticsearch.cluster.coordination.PreVoteRequest
- hashCode() - Method in class org.elasticsearch.cluster.coordination.PreVoteResponse
- hashCode() - Method in class org.elasticsearch.cluster.coordination.PublishRequest
- hashCode() - Method in class org.elasticsearch.cluster.coordination.PublishResponse
- hashCode() - Method in class org.elasticsearch.cluster.coordination.PublishWithJoinResponse
- hashCode() - Method in class org.elasticsearch.cluster.coordination.StartJoinRequest
- hashCode() - Method in class org.elasticsearch.cluster.coordination.ApplyCommitRequest
- hashCode() - Method in class org.elasticsearch.cluster.DiskUsage
- hashCode() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- hashCode() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- hashCode() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- hashCode() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- hashCode() - Method in class org.elasticsearch.cluster.metadata.ComponentTemplate
- hashCode() - Method in class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- hashCode() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- hashCode() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- hashCode() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- hashCode() - Method in class org.elasticsearch.cluster.metadata.DataStream
- hashCode() - Method in class org.elasticsearch.cluster.metadata.DataStream.TimestampField
- hashCode() - Method in class org.elasticsearch.cluster.metadata.DataStreamAction
- hashCode() - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
- hashCode() - Method in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- hashCode() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- hashCode() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.ConcreteIndex
- hashCode() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- hashCode() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- hashCode() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Tombstone
- hashCode() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- hashCode() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- hashCode() - Method in class org.elasticsearch.cluster.metadata.ItemUsage
- hashCode() - Method in class org.elasticsearch.cluster.metadata.Manifest
- hashCode() - Method in class org.elasticsearch.cluster.metadata.MappingMetadata
- hashCode() - Method in class org.elasticsearch.cluster.metadata.MappingMetadata.Routing
- hashCode() - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- hashCode() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
- hashCode() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
- hashCode() - Method in class org.elasticsearch.cluster.metadata.ShutdownPersistentTasksStatus
- hashCode() - Method in class org.elasticsearch.cluster.metadata.ShutdownPluginsStatus
- hashCode() - Method in class org.elasticsearch.cluster.metadata.ShutdownShardMigrationStatus
- hashCode() - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- hashCode() - Method in class org.elasticsearch.cluster.metadata.Template
- hashCode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- hashCode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodeRole
- hashCode() - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
- hashCode() - Method in class org.elasticsearch.cluster.RestoreInProgress
- hashCode() - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- hashCode() - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
- hashCode() - Method in class org.elasticsearch.cluster.routing.AllocationId
- hashCode() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- hashCode() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- hashCode() - Method in class org.elasticsearch.cluster.routing.PlainShardIterator
- hashCode() - Method in class org.elasticsearch.cluster.routing.RecoverySource
- hashCode() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- hashCode() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- hashCode() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- hashCode() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- hashCode() - Method in class org.elasticsearch.cluster.routing.ShardRouting
- hashCode() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
- hashCode() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
- hashCode() - Method in class org.elasticsearch.cluster.service.ClusterApplierRecordingService.Stats
- hashCode() - Method in class org.elasticsearch.cluster.service.ClusterApplierRecordingService.Stats.Recording
- hashCode() - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- hashCode() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- hashCode() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- hashCode() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- hashCode() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- hashCode() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- hashCode() - Method in class org.elasticsearch.common.blobstore.BlobPath
- hashCode() - Method in class org.elasticsearch.common.bytes.AbstractBytesReference
- hashCode() - Method in class org.elasticsearch.common.bytes.BytesArray
- hashCode() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- hashCode() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- hashCode() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- hashCode() - Method in class org.elasticsearch.common.compress.CompressedXContent
- hashCode() - Method in class org.elasticsearch.common.document.DocumentField
- hashCode() - Method in class org.elasticsearch.common.Explicit
- hashCode() - Method in class org.elasticsearch.common.FieldMemoryStats
- hashCode() - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- hashCode() - Method in class org.elasticsearch.common.geo.GeoPoint
- hashCode() - Method in class org.elasticsearch.common.hash.MurmurHash3.Hash128
- hashCode() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
- hashCode() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- hashCode() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
- hashCode() - Method in class org.elasticsearch.common.inject.internal.ProviderMethodsModule
- hashCode() - Method in class org.elasticsearch.common.inject.Key
- hashCode() - Method in class org.elasticsearch.common.inject.multibindings.MapBinder.RealMapBinder
- hashCode() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
- hashCode() - Method in class org.elasticsearch.common.inject.spi.Dependency
- hashCode() - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
- hashCode() - Method in class org.elasticsearch.common.inject.spi.Message
- hashCode() - Method in class org.elasticsearch.common.inject.TypeLiteral
- hashCode() - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- hashCode() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- hashCode() - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
- hashCode() - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreQuery
- hashCode() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- hashCode() - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.common.Rounding
- hashCode() - Method in class org.elasticsearch.common.rounding.Rounding
-
Deprecated.
- hashCode() - Method in class org.elasticsearch.common.settings.SecureString
- hashCode() - Method in class org.elasticsearch.common.settings.Setting.AffixKey
- hashCode() - Method in class org.elasticsearch.common.settings.Setting
- hashCode() - Method in class org.elasticsearch.common.settings.Setting.SimpleKey
- hashCode() - Method in class org.elasticsearch.common.settings.Settings
- hashCode() - Method in class org.elasticsearch.common.text.Text
- hashCode() - Method in class org.elasticsearch.common.time.WriteableZoneId
- hashCode() - Method in class org.elasticsearch.common.transport.TransportAddress
- hashCode() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- hashCode() - Method in class org.elasticsearch.common.unit.DistanceUnit.Distance
- hashCode() - Method in class org.elasticsearch.common.unit.Fuzziness
- hashCode() - Method in class org.elasticsearch.common.unit.SizeValue
- hashCode() - Method in class org.elasticsearch.common.util.CuckooFilter
- hashCode() - Method in class org.elasticsearch.common.util.LazyMap
- hashCode() - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
- hashCode() - Method in class org.elasticsearch.discovery.PeersRequest
- hashCode() - Method in class org.elasticsearch.env.NodeMetadata
- hashCode() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- hashCode() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
- hashCode() - Method in class org.elasticsearch.index.analysis.NameOrDefinition
- hashCode() - Method in class org.elasticsearch.index.engine.Engine.CommitId
- hashCode() - Method in class org.elasticsearch.index.engine.Segment
- hashCode() - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- hashCode() - Method in class org.elasticsearch.index.get.GetResult
- hashCode() - Method in class org.elasticsearch.index.Index
- hashCode() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Range
- hashCode() - Method in class org.elasticsearch.index.mapper.Uid
- hashCode() - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- hashCode() - Method in class org.elasticsearch.index.query.DateRangeIncludingNowQuery
- hashCode() - Method in class org.elasticsearch.index.query.DistanceFeatureQueryBuilder.Origin
- hashCode() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- hashCode() - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
- hashCode() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- hashCode() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Combine
- hashCode() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Disjunction
- hashCode() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Fuzzy
- hashCode() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider
- hashCode() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.IntervalFilter
- hashCode() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Match
- hashCode() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Prefix
- hashCode() - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Wildcard
- hashCode() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- hashCode() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- hashCode() - Method in class org.elasticsearch.index.refresh.RefreshStats
- hashCode() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- hashCode() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- hashCode() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- hashCode() - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
- hashCode() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
- hashCode() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
- hashCode() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- hashCode() - Method in class org.elasticsearch.index.seqno.RetentionLease
- hashCode() - Method in class org.elasticsearch.index.seqno.RetentionLeases
- hashCode() - Method in class org.elasticsearch.index.seqno.RetentionLeaseStats
- hashCode() - Method in class org.elasticsearch.index.seqno.SeqNoStats
- hashCode() - Method in class org.elasticsearch.index.shard.IndexLongFieldRange
- hashCode() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- hashCode() - Method in class org.elasticsearch.index.shard.ReplicationGroup
- hashCode() - Method in class org.elasticsearch.index.shard.ShardCountStats
- hashCode() - Method in class org.elasticsearch.index.shard.ShardId
- hashCode() - Method in class org.elasticsearch.index.shard.ShardLongFieldRange
- hashCode() - Method in class org.elasticsearch.index.shard.ShardPath
- hashCode() - Method in class org.elasticsearch.index.shard.ShardStateMetadata
- hashCode() - Method in class org.elasticsearch.index.similarity.SimilarityProvider
- hashCode() - Method in class org.elasticsearch.index.translog.Translog.Delete
- hashCode() - Method in class org.elasticsearch.index.translog.Translog.Index
- hashCode() - Method in class org.elasticsearch.index.translog.Translog.Location
- hashCode() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- hashCode() - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
- hashCode() - Method in class org.elasticsearch.indices.recovery.RecoveryState.FileDetail
- hashCode() - Method in class org.elasticsearch.indices.TermsLookup
- hashCode() - Method in class org.elasticsearch.ingest.IngestDocument
- hashCode() - Method in class org.elasticsearch.ingest.IngestInfo
- hashCode() - Method in class org.elasticsearch.ingest.IngestMetadata
- hashCode() - Method in class org.elasticsearch.ingest.IngestStats
- hashCode() - Method in class org.elasticsearch.ingest.IngestStats.PipelineStat
- hashCode() - Method in class org.elasticsearch.ingest.IngestStats.ProcessorStat
- hashCode() - Method in class org.elasticsearch.ingest.IngestStats.Stats
- hashCode() - Method in class org.elasticsearch.ingest.PipelineConfiguration
- hashCode() - Method in class org.elasticsearch.ingest.ProcessorInfo
- hashCode() - Method in class org.elasticsearch.ingest.ValueSource.ByteValue
- hashCode() - Method in class org.elasticsearch.ingest.ValueSource.ListValue
- hashCode() - Method in class org.elasticsearch.ingest.ValueSource.MapValue
- hashCode() - Method in class org.elasticsearch.ingest.ValueSource.ObjectValue
- hashCode() - Method in class org.elasticsearch.ingest.ValueSource.TemplatedValue
- hashCode() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
- hashCode() - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction.Request
- hashCode() - Method in class org.elasticsearch.persistent.PersistentTaskResponse
- hashCode() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Assignment
- hashCode() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- hashCode() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- hashCode() - Method in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- hashCode() - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- hashCode() - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- hashCode() - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- hashCode() - Method in class org.elasticsearch.plugins.ActionPlugin.ActionHandler
- hashCode() - Method in class org.elasticsearch.plugins.PluginDescriptor
- hashCode() - Method in class org.elasticsearch.plugins.PluginsService.Bundle
- hashCode() - Method in class org.elasticsearch.repositories.IndexId
- hashCode() - Method in class org.elasticsearch.repositories.IndexMetaDataGenerations
- hashCode() - Method in class org.elasticsearch.repositories.RepositoryData
- hashCode() - Method in class org.elasticsearch.repositories.RepositoryData.SnapshotDetails
- hashCode() - Method in class org.elasticsearch.repositories.RepositoryInfo
- hashCode() - Method in class org.elasticsearch.repositories.RepositoryShardId
- hashCode() - Method in class org.elasticsearch.repositories.RepositoryStats
- hashCode() - Method in class org.elasticsearch.repositories.RepositoryStatsSnapshot
- hashCode() - Method in class org.elasticsearch.repositories.ShardGeneration
- hashCode() - Method in class org.elasticsearch.repositories.ShardGenerations
- hashCode() - Method in class org.elasticsearch.repositories.ShardSnapshotInfo
- hashCode() - Method in class org.elasticsearch.repositories.ShardSnapshotResult
- hashCode() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- hashCode() - Method in class org.elasticsearch.script.Script
- hashCode() - Method in class org.elasticsearch.script.ScriptCache.CompilationRate
- hashCode() - Method in class org.elasticsearch.script.ScriptContextInfo
- hashCode() - Method in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo
- hashCode() - Method in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo.ParameterInfo
- hashCode() - Method in class org.elasticsearch.script.ScriptContextStats.TimeSeries
- hashCode() - Method in class org.elasticsearch.script.ScriptException.Position
- hashCode() - Method in class org.elasticsearch.script.ScriptLanguagesInfo
- hashCode() - Method in class org.elasticsearch.script.ScriptMetadata
- hashCode() - Method in class org.elasticsearch.script.StoredScriptSource
- hashCode() - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.Aggregations
- hashCode() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.GeoTileGridValuesSourceBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite.InternalBucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.filter.MergedPointRangeQuery
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DoubleBounds
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.EmptyBucketInfo
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket.BucketBounds
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.LongBounds
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder.Range
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ChiSquare
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.GND
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.JLHScore
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.MutualInformation
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.PercentageScore
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- hashCode() - Method in class org.elasticsearch.search.aggregations.BucketOrder
- hashCode() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- hashCode() - Method in class org.elasticsearch.search.aggregations.InternalOrder.Aggregation
- hashCode() - Method in class org.elasticsearch.search.aggregations.InternalOrder.CompoundOrder
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalAvg
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalCardinality
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalMax
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalMedianAbsoluteDeviation
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalMin
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalScriptedMetric
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalSum
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTopHits
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalValueCount
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.InternalWeightedAvg
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.Percentile
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.Hdr
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.TDigest
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.TDigestState
- hashCode() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalBucketMetricValue
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalDerivative
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel
- hashCode() - Method in class org.elasticsearch.search.aggregations.support.AggregationInfo
- hashCode() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
- hashCode() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
- hashCode() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- hashCode() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- hashCode() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry.RegistryKey
- hashCode() - Method in class org.elasticsearch.search.builder.PointInTimeBuilder
- hashCode() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- hashCode() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.IndexBoost
- hashCode() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- hashCode() - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- hashCode() - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- hashCode() - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- hashCode() - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
- hashCode() - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- hashCode() - Method in class org.elasticsearch.search.fetch.subphase.FieldAndFormat
- hashCode() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- hashCode() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- hashCode() - Method in class org.elasticsearch.search.internal.AliasFilter
- hashCode() - Method in class org.elasticsearch.search.internal.ShardSearchContextId
- hashCode() - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- hashCode() - Method in class org.elasticsearch.search.profile.ProfileResult
- hashCode() - Method in class org.elasticsearch.search.profile.query.CollectorResult
- hashCode() - Method in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- hashCode() - Method in class org.elasticsearch.search.profile.SearchProfileQueryPhaseResult
- hashCode() - Method in class org.elasticsearch.search.profile.SearchProfileResults
- hashCode() - Method in class org.elasticsearch.search.profile.SearchProfileResultsBuilder
- hashCode() - Method in class org.elasticsearch.search.profile.SearchProfileShardResult
- hashCode() - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- hashCode() - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- hashCode() - Method in class org.elasticsearch.search.runtime.AbstractScriptFieldQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.BooleanScriptFieldTermQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldRangeQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldTermQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldTermsQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.GeoPointScriptFieldDistanceFeatureQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.GeoPointScriptFieldGeoShapeQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.IpScriptFieldRangeQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.IpScriptFieldTermQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.IpScriptFieldTermsQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.LongScriptFieldDistanceFeatureQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.LongScriptFieldRangeQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.LongScriptFieldTermQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.LongScriptFieldTermsQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.StringScriptFieldFuzzyQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.StringScriptFieldPrefixQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.StringScriptFieldRangeQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.StringScriptFieldRegexpQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.StringScriptFieldTermQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.StringScriptFieldTermsQuery
- hashCode() - Method in class org.elasticsearch.search.runtime.StringScriptFieldWildcardQuery
- hashCode() - Method in class org.elasticsearch.search.Scroll
- hashCode() - Method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- hashCode() - Method in class org.elasticsearch.search.SearchExtBuilder
- hashCode() - Method in class org.elasticsearch.search.SearchHit
- hashCode() - Method in class org.elasticsearch.search.SearchHit.NestedIdentity
- hashCode() - Method in class org.elasticsearch.search.SearchHits
- hashCode() - Method in class org.elasticsearch.search.SearchShardTarget
- hashCode() - Method in class org.elasticsearch.search.SearchSortValues
- hashCode() - Method in class org.elasticsearch.search.SearchSortValuesAndFormats
- hashCode() - Method in class org.elasticsearch.search.slice.SliceBuilder
- hashCode() - Method in class org.elasticsearch.search.slice.SliceQuery
- hashCode() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- hashCode() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- hashCode() - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- hashCode() - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- hashCode() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- hashCode() - Method in class org.elasticsearch.search.sort.SortValue
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
- hashCode() - Method in class org.elasticsearch.search.suggest.completion.RegexOptions
- hashCode() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- hashCode() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- hashCode() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- hashCode() - Method in class org.elasticsearch.search.suggest.phrase.SmoothingModel
- hashCode() - Method in class org.elasticsearch.search.suggest.Suggest
- hashCode() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- hashCode() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- hashCode() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- hashCode() - Method in class org.elasticsearch.search.suggest.SuggestBuilder
- hashCode() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- hashCode() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- hashCode() - Method in class org.elasticsearch.snapshots.InternalSnapshotsInfoService.SnapshotShard
- hashCode() - Method in class org.elasticsearch.snapshots.RestoreInfo
- hashCode() - Method in class org.elasticsearch.snapshots.Snapshot
- hashCode() - Method in class org.elasticsearch.snapshots.SnapshotFeatureInfo
- hashCode() - Method in class org.elasticsearch.snapshots.SnapshotId
- hashCode() - Method in class org.elasticsearch.snapshots.SnapshotInfo
- hashCode() - Method in class org.elasticsearch.snapshots.SnapshotInfo.IndexSnapshotDetails
- hashCode() - Method in exception org.elasticsearch.snapshots.SnapshotShardFailure
- hashCode() - Method in class org.elasticsearch.snapshots.UpdateIndexShardSnapshotStatusRequest
- hashCode() - Method in class org.elasticsearch.tasks.RawTaskStatus
- hashCode() - Method in class org.elasticsearch.tasks.TaskId
- hashCode() - Method in class org.elasticsearch.tasks.TaskInfo
- hashCode() - Method in class org.elasticsearch.tasks.TaskResult
- hashCode() - Method in class org.elasticsearch.transport.ProxyConnectionStrategy.ProxyModeInfo
- hashCode() - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- hashCode() - Method in class org.elasticsearch.transport.SniffConnectionStrategy.SniffModeInfo
- hashCode() - Method in class org.elasticsearch.upgrades.FeatureMigrationResults
- hashCode() - Method in class org.elasticsearch.upgrades.SingleFeatureMigrationResult
- hashCode() - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskParams
- hashCode() - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskState
- hashCode() - Method in class org.elasticsearch.Version
- hashCode(long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
- hashCode(Type) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
Returns the hashCode of
type
. - hashCode(ByteArray) - Method in class org.elasticsearch.common.util.BigArrays
- hashEqualsContents() - Method in class org.elasticsearch.index.store.StoreFileMetadata
-
Checks if the bytes returned by
StoreFileMetadata.hash()
are the contents of the file that this instances refers to. - hashesOfConsistentSettings() - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- hashesOfConsistentSettings() - Method in class org.elasticsearch.cluster.metadata.Metadata
- hashesOfConsistentSettings(Map<String, String>) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- hashesOfConsistentSettings(DiffableStringMap) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- hashFile(BytesRefBuilder, InputStream, long) - Static method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Computes a strong hash value for small files.
- hashToShardId(int) - Method in class org.elasticsearch.cluster.routing.IndexRouting
-
Convert a hash generated from an
(id, routing
) pair into a shard id. - hasInactivePrimaries() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- hasInactiveReplicas() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- hasInactiveShards() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- hasIndex(String) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Checks whether an index exists (as of this
Metadata
with the given name. - hasIndex(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- hasIndex(String) - Method in class org.elasticsearch.repositories.RepositoryData
-
Checks if any snapshot in this repository contains the specified index in
indexName
- hasIndex(Index) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Checks whether an index exists.
- hasIndex(Index) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- hasIndex(Index) - Method in class org.elasticsearch.indices.IndicesService
- hasIndexAbstraction(String) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Checks whether an index abstraction (that is, index, alias, or data stream) exists (as of this
Metadata
with the given name. - hasIndexAbstraction(String, ClusterState) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- hasIndexBlock(String, ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- hasIndexBlock(String, ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- hasIndexBlockWithId(String, int) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- hasIndexMetadata(IndexMetadata) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Returns true iff existing index has the same
IndexMetadata
instance - hasIndexScope() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting has an index scope, otherwisefalse
- hasIndexSort() - Method in class org.elasticsearch.index.IndexSortConfig
-
Returns true if the index should be sorted
- hasInitiatedFetching(ShardRouting) - Method in class org.elasticsearch.gateway.ReplicaShardAllocator
-
Returns a boolean indicating whether fetching shard data has been triggered at any point for the given shard.
- hasLength(CharSequence) - Static method in class org.elasticsearch.common.Strings
-
Check that the given CharSequence is neither
null
nor of length 0. - hasLength(String) - Static method in class org.elasticsearch.common.Strings
-
Check that the given String is neither
null
nor of length 0. - hasLength(BytesReference) - Static method in class org.elasticsearch.common.Strings
-
Check that the given BytesReference is neither
null
nor of length 0 Note: Will returntrue
for a BytesReference that purely consists of whitespace. - hasLocalIndices() - Method in class org.elasticsearch.action.search.ParsedScrollId
- hasLockedKeys() - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
-
Returns
true
if this lock has at least one locked key. - hasMappings() - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Returns true if the index has mappings.
- hasMappings() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- hasMatchingSyncId() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
-
Returns
true
if the shard copy has a matching sync id with the primary shard. - hasMetric(String) - Method in class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.MultiValue
- hasMissingDetails(SnapshotId) - Method in class org.elasticsearch.repositories.RepositoryData
- hasMultiFields() - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- hasNativeController() - Method in class org.elasticsearch.plugins.PluginDescriptor
-
Whether or not the plugin has a native controller.
- hasNested() - Method in class org.elasticsearch.index.mapper.MapperService
- hasNested() - Method in class org.elasticsearch.index.mapper.MappingLookup
- hasNested() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- hasNext() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
- hasNext() - Method in class org.elasticsearch.search.aggregations.bucket.IteratorAndCurrent
- hasNext() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks.Iter
- hasNext() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles.Iter
- hasNext() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks.Iter
- hasNext() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles.Iter
- hasNext() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket.Iter
- hasNodeFile() - Method in class org.elasticsearch.env.NodeEnvironment
- hasNodeScope() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting has a node scope, otherwisefalse
- hasNorms() - Method in class org.elasticsearch.index.mapper.TextSearchInfo
- hasOffsets() - Method in class org.elasticsearch.index.mapper.TextSearchInfo
- hasOnlySuggest() - Method in class org.elasticsearch.search.internal.SearchContext
- hasOrdinals() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
- hasOrdinals() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource
-
Check if this values source supports using global and segment ordinals.
- hasOrdinals() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
Check if this values source supports using global and segment ordinals.
- hasOverlap(RangeAggregator.Range[]) - Static method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- hasParam(String) - Method in class org.elasticsearch.rest.RestRequest
- hasPassword() - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Return true iff calling
KeyStoreWrapper.decrypt(char[])
requires a non-empty password. - HasPasswordKeyStoreCommand - Class in org.elasticsearch.common.settings
- hasPendingAsyncFetch() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Returns
true
iff the current allocation run has not processed all of the in-flight or available shard or store fetches. - hasPermitToDownloadSnapshotFiles() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- hasPositions() - Method in class org.elasticsearch.index.mapper.TextSearchInfo
- hasPrimaryFieldSort(SearchSourceBuilder) - Static method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Return true if the primary sort in the provided
source
is an instance ofFieldSortBuilder
. - hasPrimarySortOnField(String) - Method in class org.elasticsearch.index.IndexSortConfig
- hasProcessed(long) - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
Checks if the given sequence number was marked as processed in this tracker.
- hasProfileResults() - Method in class org.elasticsearch.search.query.QuerySearchResult
- hasQuorum(Collection<String>) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfiguration
- hasRecoveries() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
- hasReferences() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- hasReferences() - Method in class org.elasticsearch.index.store.Store
- hasReferences() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- hasReferences() - Method in class org.elasticsearch.transport.BytesTransportRequest
- hasReferences() - Method in class org.elasticsearch.transport.TransportMessage
- hasRefreshPending() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns true if this shard has some scheduled refresh that is pending because of search-idle.
- hasRole(Settings, DiscoveryNodeRole) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
- hasRun() - Method in class org.elasticsearch.common.util.concurrent.RunOnce
-
true
if theRunOnce
has been executed once. - hasScoreDocs() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- hasScoreDocs() - Method in class org.elasticsearch.search.suggest.Suggest
-
Whether any suggestions had query hits
- hasScores - Variable in class org.elasticsearch.action.termvectors.TermVectorsFields
- hasScoreTerm(Term) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- hasScript - Variable in class org.elasticsearch.index.mapper.FieldMapper
- hasScript() - Method in class org.elasticsearch.index.mapper.FieldMapper
- hasScriptFields() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- hasScriptFields() - Method in class org.elasticsearch.search.internal.SearchContext
- hasScriptFields() - Method in class org.elasticsearch.search.internal.SubSearchContext
- hasSearchContext() - Method in class org.elasticsearch.search.query.QuerySearchResult
- hasShard(int) - Method in class org.elasticsearch.index.IndexService
- hasSource() - Method in class org.elasticsearch.search.SearchHit
-
Is the source available or not.
- hasSourceAsMap() - Method in class org.elasticsearch.search.lookup.SourceLookup
-
Checks if the source has been deserialized as a
Map
of java objects. - hasStoredFields() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- hasStoredFields() - Method in class org.elasticsearch.search.internal.SearchContext
- hasStoredFields() - Method in class org.elasticsearch.search.internal.SubSearchContext
- hasString() - Method in class org.elasticsearch.common.text.Text
-
Whether a
String
view of the data is already materialized. - hasSubTrees() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.PipelineTree
-
Return
true
if this node in the tree has any subtrees. - hasSuggestHits() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns
true
if this result has any suggest score docs - hasTask(String) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Builder
-
Checks if the task is currently present in the list
- hasTask(String, long) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Builder
-
Checks if the task is currently present in the list and has the right allocation id
- hasText(CharSequence) - Static method in class org.elasticsearch.common.Strings
-
Check whether the given CharSequence has actual text.
- hasText(String) - Static method in class org.elasticsearch.common.Strings
-
Check whether the given String has actual text.
- hasTimestampField() - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Returns if this mapping contains a timestamp field that is of type date, indexed and has doc values.
- hasTooManyMasterNodes(Iterable<DiscoveryNode>) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
- hasUnassignedPrimaries() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns
true
iff thisRoutingNodes
instance has any unassigned primaries even if the primaries are marked as temporarily ignored. - hasUnassignedShards() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns
true
iff thisRoutingNodes
instance has any unassigned shards even if the shards are marked as temporarily ignored. - hasUncompletedPendingDeletes() - Method in class org.elasticsearch.indices.IndicesService
-
Checks if all pending deletes have completed.
- hasValue(int) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- hasValue(int) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
-
Checks to see this model can produce a new value, without actually running the algo.
- hasValue(String) - Method in class org.elasticsearch.common.settings.Settings
-
Returns
true
iff the given key has a value in this settings object - hasValue(InternalAdjacencyMatrix) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalComposite) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalFilter) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalFilters) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalGeoGrid<?>) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalGlobal) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalAutoDateHistogram) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalDateHistogram) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalHistogram) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalVariableWidthHistogram) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalMissing) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalNested) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalReverseNested) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalRange<?, ?>) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalSampler) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(UnmappedSampler) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalSignificantTerms<?, ?>) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalTerms<A, B>) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(UnmappedSignificantTerms) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(UnmappedTerms) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalAvg) - Static method in class org.elasticsearch.search.aggregations.metrics.MetricInspectionHelper
- hasValue(InternalAvg) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalCardinality) - Static method in class org.elasticsearch.search.aggregations.metrics.MetricInspectionHelper
- hasValue(InternalCardinality) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalExtendedStats) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalGeoBounds) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalGeoCentroid) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalHDRPercentileRanks) - Static method in class org.elasticsearch.search.aggregations.metrics.MetricInspectionHelper
- hasValue(InternalHDRPercentileRanks) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalHDRPercentiles) - Static method in class org.elasticsearch.search.aggregations.metrics.MetricInspectionHelper
- hasValue(InternalHDRPercentiles) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalMax) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalMedianAbsoluteDeviation) - Static method in class org.elasticsearch.search.aggregations.metrics.MetricInspectionHelper
- hasValue(InternalMedianAbsoluteDeviation) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalMin) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalScriptedMetric) - Static method in class org.elasticsearch.search.aggregations.metrics.MetricInspectionHelper
- hasValue(InternalScriptedMetric) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalStats) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalSum) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalTDigestPercentileRanks) - Static method in class org.elasticsearch.search.aggregations.metrics.MetricInspectionHelper
- hasValue(InternalTDigestPercentileRanks) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalTDigestPercentiles) - Static method in class org.elasticsearch.search.aggregations.metrics.MetricInspectionHelper
- hasValue(InternalTDigestPercentiles) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalTopHits) - Static method in class org.elasticsearch.search.aggregations.metrics.MetricInspectionHelper
- hasValue(InternalTopHits) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalValueCount) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalWeightedAvg) - Static method in class org.elasticsearch.search.aggregations.metrics.MetricInspectionHelper
- hasValue(InternalWeightedAvg) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalBucketMetricValue) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalDerivative) - Static method in class org.elasticsearch.search.aggregations.metrics.MetricInspectionHelper
- hasValue(InternalPercentilesBucket) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValue(InternalSimpleValue) - Static method in class org.elasticsearch.search.aggregations.support.AggregationInspectionHelper
- hasValues() - Method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo.Builder
- hasValues() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
Returns true if the values source configured by this object can yield values.
- haveEmptyIntersection(Set<T>, Set<T>) - Static method in class org.elasticsearch.common.util.set.Sets
- haveNonEmptyIntersection(Set<T>, Set<T>) - Static method in class org.elasticsearch.common.util.set.Sets
- Hdr() - Constructor for class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.Hdr
- Hdr(int) - Constructor for class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.Hdr
- HDR - Enum constant in enum class org.elasticsearch.search.aggregations.metrics.PercentilesMethod
-
The HDRHistogram method of calculating percentiles
- HDR_PARSER - Static variable in enum class org.elasticsearch.search.aggregations.metrics.PercentilesMethod
- HEAD - Enum constant in enum class org.elasticsearch.rest.RestRequest.Method
- header - Variable in class org.elasticsearch.index.translog.BaseTranslogReader
- header(String) - Method in interface org.elasticsearch.http.HttpRequest
- header(String) - Method in class org.elasticsearch.rest.RestRequest
-
Get the value of the header or
null
if not found. - Header - Class in org.elasticsearch.transport
- HEADER_SIZE - Static variable in class org.elasticsearch.common.compress.DeflateCompressor
- headerLength() - Method in interface org.elasticsearch.common.compress.Compressor
- headerLength() - Method in class org.elasticsearch.common.compress.DeflateCompressor
- headerReceived(Header) - Method in class org.elasticsearch.transport.InboundAggregator
- headers() - Method in class org.elasticsearch.tasks.Task
- HEADERS_TO_COPY - Static variable in class org.elasticsearch.tasks.Task
- headerSize(Version) - Static method in class org.elasticsearch.transport.TcpHeader
- HeaderWarning - Class in org.elasticsearch.common.logging
-
This is a simplistic logger that adds warning messages to HTTP headers.
- HeaderWarning() - Constructor for class org.elasticsearch.common.logging.HeaderWarning
- HeaderWarningAppender - Class in org.elasticsearch.common.logging
- HeaderWarningAppender(String, Filter) - Constructor for class org.elasticsearch.common.logging.HeaderWarningAppender
- health(ClusterHealthRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
The health of the cluster.
- health(ClusterHealthRequest, ActionListener<ClusterHealthResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
The health of the cluster.
- HEALTHY - Enum constant in enum class org.elasticsearch.monitor.StatusInfo.Status
- HEAP_BUFFER_SIZE - Static variable in class org.elasticsearch.common.io.DiskIoBufferPool
- hear(TypeLiteral<I>, TypeEncounter<I>) - Method in interface org.elasticsearch.common.inject.spi.TypeListener
-
Invoked when Guice encounters a new type eligible for constructor or members injection.
- HIDDEN - Enum constant in enum class org.elasticsearch.action.support.IndicesOptions.WildcardStates
- HIDDEN_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- HIDDEN_INDEX_SETTINGS - Static variable in class org.elasticsearch.action.admin.indices.rollover.MetadataRolloverService
- HIDE_GENERATIONS_PARAM - Static variable in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
-
Serialization parameter used to hide the
RepositoryMetadata.generation()
andRepositoryMetadata.pendingGeneration()
inGetRepositoriesResponse
. - hideStateIfNotRecovered(ClusterState) - Static method in class org.elasticsearch.gateway.ClusterStateUpdaters
- HierarchyCircuitBreakerService - Class in org.elasticsearch.indices.breaker
-
CircuitBreakerService that attempts to redistribute space between breakers if tripped
- HierarchyCircuitBreakerService(Settings, List<BreakerSettings>, ClusterSettings) - Constructor for class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- HIGH - Enum constant in enum class org.elasticsearch.common.Priority
- HIGH - Enum constant in enum class org.elasticsearch.watcher.ResourceWatcherService.Frequency
-
Defaults to 5 seconds
- higherThan(Decision.Type) - Method in enum class org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
- highFreqMinimumShouldMatch() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- highFreqMinimumShouldMatch(String) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.Sets the minimum number of high frequent query terms that need to match in order to produce a hit when there are no low frequent terms.
- highFreqOperator() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- highFreqOperator(Operator) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.Sets the operator to use for terms with a high document frequency (greater than or equal to
CommonTermsQueryBuilder.cutoffFrequency(float)
. - highlight() - Static method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
A static factory method to construct new search highlights.
- highlight() - Method in class org.elasticsearch.search.fetch.FetchContext
-
Configuration for highlighting
- highlight() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- highlight() - Method in class org.elasticsearch.search.internal.SearchContext
- highlight() - Method in class org.elasticsearch.search.internal.SubSearchContext
- highlight(String, String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Setup highlighting for suggestions.
- highlight(FieldHighlightContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.FastVectorHighlighter
- highlight(FieldHighlightContext) - Method in interface org.elasticsearch.search.fetch.subphase.highlight.Highlighter
- highlight(FieldHighlightContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.PlainHighlighter
- highlight(FieldHighlightContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- highlight(SearchHighlightContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- highlight(SearchHighlightContext) - Method in class org.elasticsearch.search.internal.SearchContext
- highlight(SearchHighlightContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
- HIGHLIGHT_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- HIGHLIGHT_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- HIGHLIGHT_FILTER_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- HIGHLIGHT_QUERY_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- HighlightBuilder - Class in org.elasticsearch.search.fetch.subphase.highlight
-
A builder for search highlighting.
- HighlightBuilder() - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- HighlightBuilder(StreamInput) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Read from a stream.
- HighlightBuilder(HighlightBuilder, QueryBuilder, List<HighlightBuilder.Field>) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- HighlightBuilder.BoundaryScannerType - Enum Class in org.elasticsearch.search.fetch.subphase.highlight
- HighlightBuilder.Field - Class in org.elasticsearch.search.fetch.subphase.highlight
- HighlightBuilder.Order - Enum Class in org.elasticsearch.search.fetch.subphase.highlight
- HIGHLIGHTED - Static variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- highlighter() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Gets the highlighter builder for this request.
- highlighter() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the highlighter builder for this request.
- highlighter(HighlightBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
- highlighter(HighlightBuilder) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Adds highlight to perform as part of the search.
- highlighter(HighlightBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds highlight to perform as part of the search.
- Highlighter - Interface in org.elasticsearch.search.fetch.subphase.highlight
-
Highlights a search result.
- highlighterType - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- highlighterType() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- highlighterType() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- highlighterType(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set type of highlighter to use.
- highlightField(LeafReader, int, CheckedSupplier<String, IOException>) - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
-
Highlights the field value.
- HighlightField - Class in org.elasticsearch.search.fetch.subphase.highlight
-
A field highlighted with its highlighted fragments.
- HighlightField(String, Text[]) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- HighlightField(StreamInput) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- highlightFields(Map<String, HighlightField>) - Method in class org.elasticsearch.search.SearchHit
- highlightFilter - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- highlightFilter() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- highlightFilter() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- highlightFilter(Boolean) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set this to true when using the highlighterType
fvh
and you want to provide highlighting on filter clauses in your query. - highlightFilters - Static variable in class org.apache.lucene.search.vectorhighlight.CustomFieldQuery
- HighlightPhase - Class in org.elasticsearch.search.fetch.subphase.highlight
- HighlightPhase(Map<String, Highlighter>) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.HighlightPhase
- highlightQuery - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- highlightQuery() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- highlightQuery() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- highlightQuery(QueryBuilder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Sets a query to be used for highlighting instead of the search query.
- HighlightUtils - Class in org.elasticsearch.search.fetch.subphase.highlight
- HighlightUtils.Encoders - Class in org.elasticsearch.search.fetch.subphase.highlight
- histogram - Enum constant in enum class org.elasticsearch.index.mapper.TimeSeriesParams.MetricType
- histogram() - Method in class org.elasticsearch.index.fielddata.HistogramValues
-
Get the
HistogramValue
associated with the current document. - histogram(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Histogram
aggregation with the given name. - Histogram - Interface in org.elasticsearch.search.aggregations.bucket.histogram
-
A
histogram
aggregation. - Histogram.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.histogram
-
A bucket in the histogram where documents fall in
- HistogramAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
A builder for histograms on numeric fields.
- HistogramAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Create a new builder with the given name.
- HistogramAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Read from a stream, for internal use only.
- HistogramAggregationBuilder(HistogramAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- HistogramAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
Constructs the per-shard aggregator instance for histogram aggregation.
- HistogramAggregatorFactory(String, ValuesSourceConfig, double, double, BucketOrder, boolean, long, DoubleBounds, DoubleBounds, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>, HistogramAggregatorSupplier) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregatorFactory
- HistogramAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.bucket.histogram
- HistogramFactory - Interface in org.elasticsearch.search.aggregations.bucket.histogram
-
Implemented by histogram aggregations and used by pipeline aggregations to insert buckets.
- HistogramValue - Class in org.elasticsearch.index.fielddata
-
Per-document histogram value.
- HistogramValue() - Constructor for class org.elasticsearch.index.fielddata.HistogramValue
- HistogramValues - Class in org.elasticsearch.index.fielddata
-
Per-segment histogram values.
- HistogramValues() - Constructor for class org.elasticsearch.index.fielddata.HistogramValues
- HistogramValuesSourceBuilder - Class in org.elasticsearch.search.aggregations.bucket.composite
-
A
CompositeValuesSourceBuilder
that builds aHistogramValuesSource
from another numeric values source using the provided interval. - HistogramValuesSourceBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- HistogramValuesSourceBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- HistogramValuesSourceBuilder.HistogramCompositeSupplier - Interface in org.elasticsearch.search.aggregations.bucket.composite
- HISTORY_UUID_KEY - Static variable in class org.elasticsearch.index.engine.Engine
- hit() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- hitContext - Variable in class org.elasticsearch.search.fetch.subphase.highlight.FieldHighlightContext
- HitContext(SearchHit, LeafReaderContext, int) - Constructor for class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- hits - Variable in class org.elasticsearch.action.search.SearchResponseSections
- hits() - Method in class org.elasticsearch.action.search.SearchResponseSections
- hits() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- HITS - Static variable in class org.elasticsearch.search.SearchHits.Fields
- holdsLock() - Method in class org.elasticsearch.discovery.PeerFinder
- holt(double[], double, double) - Static method in class org.elasticsearch.search.aggregations.pipeline.MovingFunctions
-
Calculate a doubly exponential weighted moving average Alpha controls the smoothing of the data.
- holtForecast(double[], double, double, int) - Static method in class org.elasticsearch.search.aggregations.pipeline.MovingFunctions
-
Version of holt that can "forecast", not exposed as a whitelisted function for moving_fn scripts, but here as compatibility/code sharing for existing moving_avg agg.
- HoltLinearModel - Class in org.elasticsearch.search.aggregations.pipeline
-
Calculate a doubly exponential weighted moving average
- HoltLinearModel() - Constructor for class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
- HoltLinearModel(double, double) - Constructor for class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
- HoltLinearModel(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
-
Read from a stream.
- HoltLinearModel.HoltLinearModelBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- HoltLinearModelBuilder() - Constructor for class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel.HoltLinearModelBuilder
- holtWinters(double[], double, double, double, int, boolean) - Static method in class org.elasticsearch.search.aggregations.pipeline.MovingFunctions
-
Calculate a triple exponential weighted moving average Alpha controls the smoothing of the data.
- holtWintersForecast(double[], double, double, double, int, double, boolean, int) - Static method in class org.elasticsearch.search.aggregations.pipeline.MovingFunctions
-
Version of holt-winters that can "forecast", not exposed as a whitelisted function for moving_fn scripts, but here as compatibility/code sharing for existing moving_avg agg.
- HoltWintersModel - Class in org.elasticsearch.search.aggregations.pipeline
-
Calculate a triple exponential weighted moving average
- HoltWintersModel() - Constructor for class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- HoltWintersModel(double, double, double, int, HoltWintersModel.SeasonalityType, boolean) - Constructor for class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- HoltWintersModel(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
-
Read from a stream.
- HoltWintersModel.HoltWintersModelBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- HoltWintersModel.SeasonalityType - Enum Class in org.elasticsearch.search.aggregations.pipeline
- HoltWintersModelBuilder() - Constructor for class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
- HOST - Static variable in class org.elasticsearch.http.CorsHandler
- HOST - Static variable in class org.elasticsearch.transport.TransportSettings
- HotThreads - Class in org.elasticsearch.monitor.jvm
- HotThreads() - Constructor for class org.elasticsearch.monitor.jvm.HotThreads
- HotThreads.ReportType - Enum Class in org.elasticsearch.monitor.jvm
- HotThreads.SleepFunction<T,
R> - Interface in org.elasticsearch.monitor.jvm - HotThreads.SortOrder - Enum Class in org.elasticsearch.monitor.jvm
- hour() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day.
- HOUR - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- HOUR - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- HOUR_MINUTE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- HOUR_MINUTE_SECOND - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- HOUR_MINUTE_SECOND_FRACTION - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- HOUR_MINUTE_SECOND_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- HOUR_OF_DAY - Enum constant in enum class org.elasticsearch.common.rounding.DateTimeUnit
- HOUR_OF_DAY - Enum constant in enum class org.elasticsearch.common.Rounding.DateTimeUnit
- hourMinute() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day and two digit minute of hour.
- hourMinuteSecond() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, and two digit second of minute.
- hourMinuteSecondFraction() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and three digit fraction of second (HH:mm:ss.SSS).
- hourMinuteSecondMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and three digit fraction of second (HH:mm:ss.SSS).
- hours(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- HppcMaps - Class in org.elasticsearch.common.collect
- HppcMaps.Object - Class in org.elasticsearch.common.collect
- HppcMaps.Object.Integer - Class in org.elasticsearch.common.collect
- HTML - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightUtils.Encoders
- HTTP - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
- HTTP - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- HTTP_1_0 - Enum constant in enum class org.elasticsearch.http.HttpRequest.HttpVersion
- HTTP_1_1 - Enum constant in enum class org.elasticsearch.http.HttpRequest.HttpVersion
- HTTP_DEFAULT_TYPE_SETTING - Static variable in class org.elasticsearch.common.network.NetworkModule
- HTTP_SERVER_WORKER_THREAD_NAME_PREFIX - Static variable in interface org.elasticsearch.http.HttpServerTransport
- HTTP_TYPE_DEFAULT_KEY - Static variable in class org.elasticsearch.common.network.NetworkModule
- HTTP_TYPE_KEY - Static variable in class org.elasticsearch.common.network.NetworkModule
- HTTP_TYPE_SETTING - Static variable in class org.elasticsearch.common.network.NetworkModule
- HTTP_VERSION_NOT_SUPPORTED - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server does not support, or refuses to support, the HTTP protocol version that was used in the request message.
- HttpChannel - Interface in org.elasticsearch.http
- HttpClientStatsTracker - Class in org.elasticsearch.http
-
Tracks a collection of
HttpStats.ClientStats
for current and recently-closed HTTP connections. - HttpException - Exception in org.elasticsearch.http
- HttpException(String) - Constructor for exception org.elasticsearch.http.HttpException
- HttpException(String, Throwable) - Constructor for exception org.elasticsearch.http.HttpException
- HttpException(StreamInput) - Constructor for exception org.elasticsearch.http.HttpException
- HttpHandlingSettings - Class in org.elasticsearch.http
- HttpHandlingSettings(int, int, int, int, boolean, boolean, int, boolean, int, long, boolean) - Constructor for class org.elasticsearch.http.HttpHandlingSettings
- HttpInfo - Class in org.elasticsearch.http
- HttpInfo(StreamInput) - Constructor for class org.elasticsearch.http.HttpInfo
- HttpInfo(BoundTransportAddress, long) - Constructor for class org.elasticsearch.http.HttpInfo
- HttpPipelinedMessage - Interface in org.elasticsearch.http
- HttpPipelinedRequest - Class in org.elasticsearch.http
- HttpPipelinedRequest(int, HttpRequest) - Constructor for class org.elasticsearch.http.HttpPipelinedRequest
- HttpPipelinedResponse - Class in org.elasticsearch.http
- HttpPipelinedResponse(int, HttpResponse) - Constructor for class org.elasticsearch.http.HttpPipelinedResponse
- HttpPipeliningAggregator<Listener> - Class in org.elasticsearch.http
- HttpPipeliningAggregator(int) - Constructor for class org.elasticsearch.http.HttpPipeliningAggregator
- HttpReadTimeoutException - Exception in org.elasticsearch.http
- HttpReadTimeoutException(long) - Constructor for exception org.elasticsearch.http.HttpReadTimeoutException
- HttpReadTimeoutException(long, Exception) - Constructor for exception org.elasticsearch.http.HttpReadTimeoutException
- HttpRequest - Interface in org.elasticsearch.http
-
A basic http request abstraction.
- HttpRequest.HttpVersion - Enum Class in org.elasticsearch.http
- HttpRequestOnTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.TcpTransport.HttpRequestOnTransportException
- HttpResponse - Interface in org.elasticsearch.http
-
A basic http response abstraction.
- HttpServerChannel - Interface in org.elasticsearch.http
- HttpServerTransport - Interface in org.elasticsearch.http
- HttpServerTransport.Dispatcher - Interface in org.elasticsearch.http
-
Dispatches HTTP requests.
- HttpStats - Class in org.elasticsearch.http
- HttpStats(long, long) - Constructor for class org.elasticsearch.http.HttpStats
- HttpStats(List<HttpStats.ClientStats>, long, long) - Constructor for class org.elasticsearch.http.HttpStats
- HttpStats(StreamInput) - Constructor for class org.elasticsearch.http.HttpStats
- HttpStats.ClientStats - Class in org.elasticsearch.http
- HttpTransportSettings - Class in org.elasticsearch.http
- HttpUtils - Class in org.elasticsearch.http
- HttpUtils() - Constructor for class org.elasticsearch.http.HttpUtils
- humanReadable() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- humanReadable() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- humanReadable(boolean) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- humanReadable(boolean) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- HUNSPELL_DICTIONARY_OPTIONS - Static variable in class org.elasticsearch.indices.analysis.HunspellService
- HUNSPELL_IGNORE_CASE - Static variable in class org.elasticsearch.indices.analysis.HunspellService
- HUNSPELL_LAZY_LOAD - Static variable in class org.elasticsearch.indices.analysis.HunspellService
- HunspellService - Class in org.elasticsearch.indices.analysis
-
Serves as a node level registry for hunspell dictionaries.
- HunspellService(Settings, Environment, Map<String, Dictionary>) - Constructor for class org.elasticsearch.indices.analysis.HunspellService
- HunspellTokenFilterFactory - Class in org.elasticsearch.index.analysis
- HunspellTokenFilterFactory(IndexSettings, String, Settings, HunspellService) - Constructor for class org.elasticsearch.index.analysis.HunspellTokenFilterFactory
- HYBRIDFS - Enum constant in enum class org.elasticsearch.index.IndexModule.Type
- HYPERLOGLOG - Static variable in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
- HyperLogLogPlusPlus - 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 This implementation is different from the original implementation in that it uses a hash table instead of a sorted list for linear counting.
- HyperLogLogPlusPlus(int, BigArrays, long) - Constructor for class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
I
- id - Variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- id - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- id - Variable in class org.elasticsearch.discovery.zen.UnicastZenPing.UnicastPingRequest
- id - Variable in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- id - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- id - Variable in class org.elasticsearch.Version
- id() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- id() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- id() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- id() - Method in enum class org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
- id() - Method in class org.elasticsearch.action.bulk.BulkItemRequest
- id() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
The id of the document to delete.
- id() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the id of the document for this request
- id() - Method in class org.elasticsearch.action.explain.ExplainRequest
- id() - Method in class org.elasticsearch.action.get.GetRequest
- id() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- id() - Method in class org.elasticsearch.action.index.IndexRequest
-
The id of the indexed document.
- id() - Method in enum class org.elasticsearch.action.search.SearchType
-
The internal id of the type.
- id() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Returns the id of document the term vector is requested for.
- id() - Method in enum class org.elasticsearch.action.ThreadingModel
- id() - Method in class org.elasticsearch.action.update.UpdateRequest
-
The id of the indexed document.
- id() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- id() - Method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.State
- id() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard id.
- id() - Method in enum class org.elasticsearch.common.rounding.DateTimeUnit
- id() - Method in class org.elasticsearch.common.Rounding
- id() - Method in class org.elasticsearch.common.rounding.Rounding
-
Deprecated.
- id() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.PingingRound
- id() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingResponse
-
an always increasing unique identifier for this ping response.
- id() - Method in class org.elasticsearch.index.engine.Engine.Delete
- id() - Method in class org.elasticsearch.index.engine.Engine.Get
- id() - Method in class org.elasticsearch.index.engine.Engine.Index
- id() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- id() - Method in class org.elasticsearch.index.mapper.SourceToParse
- id() - Method in class org.elasticsearch.index.mapper.Uid
- id() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- id() - Method in class org.elasticsearch.index.seqno.RetentionLease
-
The identifier for this retention lease.
- id() - Method in enum class org.elasticsearch.index.shard.IndexShardState
- id() - Method in class org.elasticsearch.index.shard.ShardId
- id() - Method in class org.elasticsearch.index.translog.Translog.Delete
- id() - Method in class org.elasticsearch.index.translog.Translog.Index
- id() - Method in enum class org.elasticsearch.index.translog.Translog.Operation.Type
- id() - Method in enum class org.elasticsearch.indices.recovery.RecoveryState.Stage
- id() - Method in class org.elasticsearch.indices.TermsLookup
- id() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- id() - Method in class org.elasticsearch.search.internal.ReaderContext
- id() - Method in class org.elasticsearch.search.internal.SearchContext
- id(long) - Method in class org.elasticsearch.common.util.LongLongHash
-
Get the id associated with key at
0 <= index <= capacity()
or -1 if this slot is unused. - id(long, long) - Method in class org.elasticsearch.common.util.LongLongHash
- id(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- id(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- id(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- id(String) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Sets the id of the document to delete.
- id(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
- id(String) - Method in class org.elasticsearch.action.get.GetRequest
-
Sets the id of the document to fetch.
- id(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the id of the indexed document.
- id(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Sets the id of document the term vector is requested for.
- id(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the id of the indexed document.
- ID - Enum constant in enum class org.elasticsearch.ingest.IngestDocument.Metadata
- ID - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- ID - Static variable in class org.elasticsearch.repositories.IndexId
- ID_FIELD - Static variable in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- ID_FIELD - Static variable in class org.elasticsearch.search.slice.SliceBuilder
- identical - Variable in class org.elasticsearch.index.store.Store.RecoveryDiff
-
Files that exist in both snapshots and they can be considered the same ie.
- identicalTo(Object) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches only the given object.
- identity(String, SearchExecutionContext, String) - Static method in class org.elasticsearch.index.mapper.SourceValueFetcher
-
Creates a
SourceValueFetcher
that passes through source values unmodified. - IDENTITY_FILTER - Static variable in interface org.elasticsearch.index.analysis.TokenFilterFactory
-
A TokenFilterFactory that does no filtering to its TokenStream
- idField(String) - Static method in class org.elasticsearch.index.mapper.IdFieldMapper
- idFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- IdFieldMapper - Class in org.elasticsearch.index.mapper
-
A mapper for the _id field.
- IdFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- ids() - Method in class org.elasticsearch.index.query.IdsQueryBuilder
-
Returns the ids for the query.
- ids(String[]) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- idsEqual(byte[]) - Method in class org.elasticsearch.index.engine.Engine.CommitId
- idsQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Constructs a query that will match only specific ids within all types.
- idsQuery(String...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Deprecated.Types are in the process of being removed, use
QueryBuilders.idsQuery()
instead. - IdsQueryBuilder - Class in org.elasticsearch.index.query
-
A query that will return only documents matching specific ids (and a type).
- IdsQueryBuilder() - Constructor for class org.elasticsearch.index.query.IdsQueryBuilder
-
Creates a new IdsQueryBuilder with no types specified upfront
- IdsQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.IdsQueryBuilder
-
Read from a stream.
- IF_PRIMARY_TERM - Enum constant in enum class org.elasticsearch.ingest.IngestDocument.Metadata
- IF_SEQ_NO - Enum constant in enum class org.elasticsearch.ingest.IngestDocument.Metadata
- IfConfig - Class in org.elasticsearch.common.network
-
Simple class to log
ifconfig
-style output at DEBUG logging. - IfConfig() - Constructor for class org.elasticsearch.common.network.IfConfig
- ifPrimaryTerm() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
If set, only perform this delete request if the document was last modification was assigned this primary term.
- ifPrimaryTerm() - Method in interface org.elasticsearch.action.DocWriteRequest
-
If set, only perform this request if the document was last modification was assigned this primary term.
- ifPrimaryTerm() - Method in class org.elasticsearch.action.index.IndexRequest
-
If set, only perform this indexing request if the document was last modification was assigned this primary term.
- ifPrimaryTerm() - Method in class org.elasticsearch.action.update.UpdateRequest
-
If set, only perform this update request if the document was last modification was assigned this primary term.
- ifSeqNo() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
If set, only perform this delete request if the document was last modification was assigned this sequence number.
- ifSeqNo() - Method in interface org.elasticsearch.action.DocWriteRequest
-
If set, only perform this request if the document was last modification was assigned this sequence number.
- ifSeqNo() - Method in class org.elasticsearch.action.index.IndexRequest
-
If set, only perform this indexing request if the document was last modification was assigned this sequence number.
- ifSeqNo() - Method in class org.elasticsearch.action.update.UpdateRequest
-
If set, only perform this update request if the document was last modification was assigned this sequence number.
- IGNORE_ALIASES - Enum constant in enum class org.elasticsearch.action.support.IndicesOptions.Option
- IGNORE_FAILURE_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- IGNORE_MALFORMED - Enum constant in enum class org.elasticsearch.index.query.GeoValidationMethod
- IGNORE_MALFORMED_SETTING - Static variable in class org.elasticsearch.index.mapper.FieldMapper
- IGNORE_THROTTLED - Enum constant in enum class org.elasticsearch.action.support.IndicesOptions.Option
- IGNORE_UNAVAILABLE - Enum constant in enum class org.elasticsearch.action.support.IndicesOptions.Option
- IGNORE_UNMAPPED - Static variable in class org.elasticsearch.index.query.InnerHitBuilder
- IGNORE_UNMAPPED_FIELD - Static variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- ignoreAbove() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
-
Values that have more chars than the return value of this method will be skipped at parsing time.
- ignoreAbove(int) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.Builder
- ignoreAliases() - Method in class org.elasticsearch.action.support.IndicesOptions
- ignoreCase() - Method in class org.elasticsearch.index.analysis.StopTokenFilterFactory
- ignored() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
The list of ignored unassigned shards (read only).
- IgnoredFieldMapper - Class in org.elasticsearch.index.mapper
-
A field mapper that records fields that have been ignored because they were malformed.
- IgnoredFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- IgnoredFieldMapper.IgnoredFieldType - Class in org.elasticsearch.index.mapper
- ignoreDisable() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- ignoreDisable(boolean) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- ignoreDiskWatermarks() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- ignoreException() - Method in class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext.ScriptField
- ignoreFailure() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- ignoreIdleThreads() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- ignoreIdleThreads(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- ignoreIdleThreads(boolean) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- ignoreIndexSettings() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns the list of index settings and index settings groups that shouldn't be restored from snapshot
- ignoreIndexSettings(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets the list of index settings and index settings groups that shouldn't be restored from snapshot
- ignoreIndexSettings(List<String>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets the list of index settings and index settings groups that shouldn't be restored from snapshot
- ignoreMalformed - Variable in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.PointParser
- ignoreMalformed() - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- ignoreMalformedParam(Function<FieldMapper, Explicit<Boolean>>, boolean) - Static method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- ignoreRecoveryAttempt() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns
true
if this shard can ignore a recovery attempt made to it (since the already doing/done it) - ignoreShard(ShardRouting, UnassignedInfo.AllocationStatus, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Marks a shard as temporarily ignored and adds it to the ignore unassigned list.
- ignoreThrottled() - Method in class org.elasticsearch.action.support.IndicesOptions
- ignoreUnavailable() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- ignoreUnavailable() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Returns whether the request permits unavailable snapshots to be ignored.
- ignoreUnavailable() - Method in class org.elasticsearch.action.support.IndicesOptions
- ignoreUnavailable(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Set to true to ignore unavailable snapshots
- ignoreUnavailable(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Set to
true
to ignore unavailable snapshots, instead of throwing an exception. - ignoreUnmapped - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- ignoreUnmapped - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- ignoreUnmapped() - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Gets whether the query builder will ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Gets whether the query builder will ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped() - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Gets whether the query builder will ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped() - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.Gets whether the query builder will ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped() - Method in class org.elasticsearch.index.query.NestedQueryBuilder
-
Gets whether the query builder will ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the path is unmapped. - ignoreUnmapped() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns true if unmapped geo fields should be treated as located at an infinite distance
- ignoreUnmapped(boolean) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Sets whether the query builder should ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped(boolean) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Sets whether the query builder should ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped(boolean) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Sets whether the query builder should ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped(boolean) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.Sets whether the query builder should ignore unmapped fields (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the field is unmapped. - ignoreUnmapped(boolean) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
-
Sets whether the query builder should ignore unmapped paths (and run a
MatchNoDocsQuery
in place of this query) or throw an exception if the path is unmapped. - ignoreUnmapped(boolean) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- ignoreZValue() - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- ignoreZValue(boolean) - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper.Builder
- ignoreZValueParam(Function<FieldMapper, Explicit<Boolean>>) - Static method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- IllegalIndexShardStateException - Exception in org.elasticsearch.index.shard
- IllegalIndexShardStateException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IllegalIndexShardStateException
- IllegalIndexShardStateException(ShardId, IndexShardState, String, Object...) - Constructor for exception org.elasticsearch.index.shard.IllegalIndexShardStateException
- IllegalIndexShardStateException(ShardId, IndexShardState, String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.shard.IllegalIndexShardStateException
- IllegalShardRoutingStateException - Exception in org.elasticsearch.cluster.routing
-
This exception defines illegal states of shard routing
- IllegalShardRoutingStateException(ShardRouting, String) - Constructor for exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
- IllegalShardRoutingStateException(ShardRouting, String, Throwable) - Constructor for exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
- IllegalShardRoutingStateException(StreamInput) - Constructor for exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
- IMMEDIATE - Enum constant in enum class org.elasticsearch.action.support.WriteRequest.RefreshPolicy
-
Force a refresh as part of this request.
- IMMEDIATE - Enum constant in enum class org.elasticsearch.common.Priority
- ImmutableDirectoryException - Exception in org.elasticsearch.index.store
-
Exception thrown if trying to mutate files in an immutable directory.
- ImmutableDirectoryException(String) - Constructor for exception org.elasticsearch.index.store.ImmutableDirectoryException
- immutableMap() - Method in class org.elasticsearch.common.collect.MapBuilder
-
Build an immutable copy of the map under construction.
- ImmutableOpenIntMap<VType> - Class in org.elasticsearch.common.collect
-
An immutable map implementation based on open hash map.
- ImmutableOpenIntMap.Builder<VType> - Class in org.elasticsearch.common.collect
- ImmutableOpenMap<KType,
VType> - Class in org.elasticsearch.common.collect -
An immutable map implementation based on open hash map.
- ImmutableOpenMap.Builder<KType,
VType> - Class in org.elasticsearch.common.collect - ImmutableOpenMapDiff(ImmutableOpenMap<K, T>, ImmutableOpenMap<K, T>, DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Constructor for class org.elasticsearch.cluster.DiffableUtils.ImmutableOpenMapDiff
- ImmutableOpenMapDiff(StreamInput, DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Constructor for class org.elasticsearch.cluster.DiffableUtils.ImmutableOpenMapDiff
- impacts(int) - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- IMPLEMENTATION_ALREADY_SET - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- ImplementedBy - Annotation Interface in org.elasticsearch.common.inject
-
A pointer to the default implementation of a type.
- implicitContextCache() - Method in class org.elasticsearch.script.ScriptService.ContextSettings
-
Implicitly use the script context cache.
- implies(Permission) - Method in class org.elasticsearch.script.ClassPermission
- importDanglingIndex(ImportDanglingIndexRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Restore specified dangling indices.
- importDanglingIndex(ImportDanglingIndexRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Restore specified dangling indices.
- ImportDanglingIndexAction - Class in org.elasticsearch.action.admin.indices.dangling.import_index
-
Represents a request to import a particular dangling index.
- ImportDanglingIndexRequest - Class in org.elasticsearch.action.admin.indices.dangling.import_index
-
Represents a request to import a particular dangling index, specified by its UUID.
- ImportDanglingIndexRequest(String, boolean) - Constructor for class org.elasticsearch.action.admin.indices.dangling.import_index.ImportDanglingIndexRequest
- ImportDanglingIndexRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.dangling.import_index.ImportDanglingIndexRequest
- in - Variable in class org.elasticsearch.client.FilterClient
- in - Variable in class org.elasticsearch.common.lucene.FilterIndexCommit
- in() - Method in class org.elasticsearch.client.FilterClient
-
Returns the delegate
Client
- in(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.binder.ScopedBindingBuilder
-
See the EDSL examples at
Binder
. - in(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- in(Scope) - Method in interface org.elasticsearch.common.inject.binder.ScopedBindingBuilder
-
See the EDSL examples at
Binder
. - in(Scope) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- IN_FLIGHT_REQUESTS - Static variable in interface org.elasticsearch.common.breaker.CircuitBreaker
-
The in-flight request breaker tracks bytes allocated for reading and writing requests on the network layer.
- IN_FLIGHT_REQUESTS_CIRCUIT_BREAKER_LIMIT_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- IN_FLIGHT_REQUESTS_CIRCUIT_BREAKER_OVERHEAD_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- IN_FLIGHT_REQUESTS_CIRCUIT_BREAKER_TYPE_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- IN_PROGRESS - Enum constant in enum class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.UpgradeStatus
- IN_PROGRESS - Enum constant in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Status
- IN_PROGRESS - Enum constant in enum class org.elasticsearch.snapshots.SnapshotState
-
Snapshot process has started
- InboundAggregator - Class in org.elasticsearch.transport
- InboundAggregator(Supplier<CircuitBreaker>, Function<String, RequestHandlerRegistry<TransportRequest>>) - Constructor for class org.elasticsearch.transport.InboundAggregator
- InboundDecoder - Class in org.elasticsearch.transport
- InboundDecoder(Version, PageCacheRecycler) - Constructor for class org.elasticsearch.transport.InboundDecoder
- InboundHandler - Class in org.elasticsearch.transport
-
Handles inbound messages by first deserializing a
TransportMessage
from anInboundMessage
and then passing it to the appropriate handler. - inboundMessage(TcpChannel, InboundMessage) - Method in class org.elasticsearch.transport.TcpTransport
-
Handles inbound message that has been decoded.
- InboundMessage - Class in org.elasticsearch.transport
- InboundMessage(Header, boolean) - Constructor for class org.elasticsearch.transport.InboundMessage
- InboundMessage(Header, Exception) - Constructor for class org.elasticsearch.transport.InboundMessage
- InboundMessage(Header, ReleasableBytesReference, Releasable) - Constructor for class org.elasticsearch.transport.InboundMessage
- InboundPipeline - Class in org.elasticsearch.transport
- InboundPipeline(StatsTracker, LongSupplier, InboundDecoder, InboundAggregator, BiConsumer<TcpChannel, InboundMessage>) - Constructor for class org.elasticsearch.transport.InboundPipeline
- InboundPipeline(Version, StatsTracker, PageCacheRecycler, LongSupplier, Supplier<CircuitBreaker>, Function<String, RequestHandlerRegistry<TransportRequest>>, BiConsumer<TcpChannel, InboundMessage>) - Constructor for class org.elasticsearch.transport.InboundPipeline
- inc() - Method in class org.elasticsearch.common.metrics.CounterMetric
- inc(long) - Method in class org.elasticsearch.common.metrics.CounterMetric
- inc(long) - Method in class org.elasticsearch.common.metrics.MeanMetric
- incAggregationUsage(String, String) - Method in class org.elasticsearch.search.aggregations.support.AggregationUsageService
- incCurrentAsSource() - Method in class org.elasticsearch.index.recovery.RecoveryStats
- incCurrentAsTarget() - Method in class org.elasticsearch.index.recovery.RecoveryStats
- INCH - Enum constant in enum class org.elasticsearch.common.unit.DistanceUnit
- include() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- include(boolean) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Whether to include the input documents.
- INCLUDE_CREATED - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
XContent param name to indicate if "created" count must be included in the response.
- INCLUDE_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- INCLUDE_NEGATIVES_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
- INCLUDE_REPOSITORY_XCONTENT_PARAM - Static variable in class org.elasticsearch.snapshots.SnapshotInfo
- INCLUDE_TYPE_NAME_PARAMETER - Static variable in class org.elasticsearch.rest.BaseRestHandler
-
Parameter that controls whether certain REST apis should include type names in their requests or responses.
- INCLUDE_UPDATED - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
XContent param name to indicate if "updated" count must be included in the response.
- includeAliases() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns true if aliases should be restored from this snapshot
- includeAliases(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
If set to true the restore procedure will restore aliases
- includeDataStreams() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- includeDataStreams() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- includeDataStreams() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- includeDataStreams() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- includeDataStreams() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- includeDataStreams() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- includeDataStreams() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- includeDataStreams() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- includeDataStreams() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- includeDataStreams() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
- includeDataStreams() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Request
- includeDataStreams() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- includeDataStreams() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- includeDataStreams() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- includeDataStreams() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- includeDataStreams() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- includeDataStreams() - Method in class org.elasticsearch.action.datastreams.ModifyDataStreamsAction.Request
- includeDataStreams() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- includeDataStreams() - Method in class org.elasticsearch.action.index.IndexRequest
- includeDataStreams() - Method in interface org.elasticsearch.action.IndicesRequest
-
Determines whether the request should be applied to data streams.
- includeDataStreams() - Method in class org.elasticsearch.action.OriginalIndices
- includeDataStreams() - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- includeDataStreams() - Method in class org.elasticsearch.action.search.SearchRequest
- includeDataStreams() - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- includeDataStreams() - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- includeDataStreams() - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.Context
- includeDefaults() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsRequest
- includeDefaults() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
-
Whether to return all default settings for each of the indices.
- includeDefaults() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- includeDefaults() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- includeDefaults() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- includeDefaults(boolean) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsRequest
-
When include_defaults is set, return default settings which are normally suppressed.
- includeDefaults(boolean) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
-
Sets the value of "include_defaults".
- includeDefaults(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
-
Indicates whether default mapping settings should be returned
- includeDefaults(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
-
Indicates whether default mapping settings should be returned
- includeDefaults(boolean) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
-
When include_defaults is set, return default values which are normally suppressed.
- includeDiskInfo() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Returns
true
if information about disk usage and shard sizes should also be returned. - includeDiskInfo(boolean) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Set to
true
to include information about the gathered disk information of nodes in the cluster. - includeExclude() - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
-
Get terms to include and exclude from the aggregation results
- includeExclude() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
-
Get terms to include and exclude from the aggregation results
- includeExclude() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
-
Get terms to include and exclude from the aggregation results
- includeExclude() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Get terms to include and exclude from the aggregation results
- includeExclude(IncludeExclude) - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
-
Set terms to include and exclude from the aggregation results
- includeExclude(IncludeExclude) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
-
Set terms to include and exclude from the aggregation results
- includeExclude(IncludeExclude) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
-
Set terms to include and exclude from the aggregation results
- includeExclude(IncludeExclude) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Set terms to include and exclude from the aggregation results
- IncludeExclude - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Defines the include/exclude regular expression filtering for string terms aggregation.
- IncludeExclude(double[], double[]) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(int, int) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(long[], long[]) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(String[], String[]) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(String, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(String, String, String[], String[]) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(SortedSet<BytesRef>, SortedSet<BytesRef>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
-
Read from a stream.
- IncludeExclude(RegExp, RegExp) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude(RegExp, RegExp, SortedSet<BytesRef>, SortedSet<BytesRef>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- IncludeExclude.Filter - Class in org.elasticsearch.search.aggregations.bucket.terms
- IncludeExclude.LongFilter - Class in org.elasticsearch.search.aggregations.bucket.terms
- IncludeExclude.OrdinalsFilter - Class in org.elasticsearch.search.aggregations.bucket.terms
- IncludeExclude.PartitionedLongFilter - Class in org.elasticsearch.search.aggregations.bucket.terms
- IncludeExclude.SetBackedLongFilter - Class in org.elasticsearch.search.aggregations.bucket.terms
- IncludeExclude.StringFilter - Class in org.elasticsearch.search.aggregations.bucket.terms
- includeFileInfoWriterUUID(Version) - Static method in class org.elasticsearch.snapshots.SnapshotsService
- includeFilters() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- includeGlobalState() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns true if global state should be stored as part of the snapshot
- includeGlobalState() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns true if global state should be restored from this snapshot
- includeGlobalState() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
-
Returns true if global state is included in the snapshot, false otherwise.
- includeGlobalState() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- includeGlobalState() - Method in class org.elasticsearch.snapshots.SnapshotInfo
- includeGlobalState(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Set to true if global state should be stored as part of the snapshot
- includeGlobalState(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
If set to true the restore procedure will restore global cluster state.
- includeLower() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Gets the includeLower flag for this query.
- includeLower(boolean) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Should the lower bound be included or not.
- includeNegatives - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
-
Some heuristics do not differentiate between terms that are descriptive for subset or for the background without the subset.
- includeNegatives - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.NXYBuilder
- includeQuery() - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- includeRelocations() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- includes() - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- INCLUDES_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- includeSegmentFileSizes() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- includeSegmentFileSizes() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- includeSegmentFileSizes(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- includeSegmentFileSizes(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- includesUUIDs(Version) - Static method in class org.elasticsearch.snapshots.SnapshotsService
-
Checks whether the metadata version supports writing the cluster- and repository-uuid to the repository.
- includeUnloadedSegments() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- includeUnloadedSegments(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- includeUnloadedSegments(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- includeUnmapped - Variable in class org.elasticsearch.search.fetch.subphase.FieldAndFormat
-
Whether to include unmapped fields or not.
- includeUnmapped() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- includeUnmapped(boolean) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- includeUpper() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Gets the includeUpper flag for this query.
- includeUpper(boolean) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Should the upper bound be included or not.
- includeYesDecisions() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Returns
true
if yes decisions should be included. - includeYesDecisions(boolean) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Set to
true
to include yes decisions for a particular node. - incomingRequest(HttpRequest, HttpChannel) - Method in class org.elasticsearch.http.AbstractHttpServerTransport
-
This method handles an incoming http request.
- INCOMPATIBLE - Enum constant in enum class org.elasticsearch.snapshots.SnapshotState
-
Snapshot is incompatible with the current version of the cluster
- IncompatibleClusterStateVersionException - Exception in org.elasticsearch.cluster
-
Thrown by
Diff.apply(T)
method - IncompatibleClusterStateVersionException(long, String, long, String) - Constructor for exception org.elasticsearch.cluster.IncompatibleClusterStateVersionException
- IncompatibleClusterStateVersionException(String) - Constructor for exception org.elasticsearch.cluster.IncompatibleClusterStateVersionException
- IncompatibleClusterStateVersionException(StreamInput) - Constructor for exception org.elasticsearch.cluster.IncompatibleClusterStateVersionException
- incompatibleSettings() - Method in class org.elasticsearch.script.ScriptService.ContextSettings
-
Is the set of settings incompatible? This is the case if: 1)
script.max_compilations_rate
,ScriptService.SCRIPT_GENERAL_MAX_COMPILATIONS_RATE_SETTING
is set but not set to "use-context". - incompatibleSettingsMessage() - Method in class org.elasticsearch.script.ScriptService.ContextSettings
-
Error message if there are incompatible settings.
- incRef() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- incRef() - Method in class org.elasticsearch.index.store.Store
-
Increments the refCount of this Store instance.
- incRef() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- incRef() - Method in class org.elasticsearch.transport.BytesTransportRequest
- incRef() - Method in class org.elasticsearch.transport.TransportMessage
- increment(long, double) - Method in interface org.elasticsearch.common.util.DoubleArray
-
Increment value at the given index by
inc
and return the value. - increment(long, float) - Method in interface org.elasticsearch.common.util.FloatArray
-
Increment value at the given index by
inc
and return the value. - increment(long, int) - Method in interface org.elasticsearch.common.util.IntArray
-
Increment value at the given index by
inc
and return the value. - increment(long, long) - Method in interface org.elasticsearch.common.util.LongArray
-
Increment value at the given index by
inc
and return the value. - IncrementalClusterStateWriter - Class in org.elasticsearch.gateway
-
Tracks the metadata written to disk, allowing updated metadata to be written incrementally (i.e.
- incrementalFileCount() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns incremental of files that were snapshotted
- incrementalSize() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns incremental of files size that were snapshotted
- incrementBucketDocCount(long, long) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Utility method to increment the doc counts of the given bucket (identified by the bucket ordinal)
- incrementRecoveredOperations() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- incrementRecoveredOperations(int) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- incrementRejections() - Method in class org.elasticsearch.common.util.concurrent.EsRejectedExecutionHandler
- incrementVersion() - Method in class org.elasticsearch.cluster.ClusterState.Builder
- incrementVersion(ClusterState) - Method in class org.elasticsearch.cluster.service.MasterService
- index - Variable in exception org.elasticsearch.action.ShardOperationFailedException
- index - Variable in class org.elasticsearch.action.support.replication.ReplicationRequest
- index - Variable in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- index - Variable in class org.elasticsearch.action.support.single.shard.SingleShardRequest
-
The concrete index name Whether index property is optional depends on the concrete implementation.
- index - Variable in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- index - Variable in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- index - Variable in class org.elasticsearch.common.util.LongObjectPagedHashMap.Cursor
- index - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- index() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- index() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The index name to create.
- index() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- index() - Method in class org.elasticsearch.action.bulk.BulkItemRequest
- index() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the index that this request operates on
- index() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- index() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- index() - Method in exception org.elasticsearch.action.ShardOperationFailedException
-
The index the operation failed on.
- index() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- index() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- index() - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
- index() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Get the index name
- index() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
-
Get the index of the shard which allocation should be canceled
- index() - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- index() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
-
Gets the
IndexId
of the recovery source. - index() - Method in class org.elasticsearch.cluster.routing.ShardRouting
- index() - Method in class org.elasticsearch.index.AbstractIndexComponent
- index() - Method in interface org.elasticsearch.index.IndexComponent
- index() - Method in class org.elasticsearch.index.mapper.SourceToParse
- index() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- index() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- index() - Method in class org.elasticsearch.indices.TermsLookup
- index() - Method in class org.elasticsearch.repositories.RepositoryShardId
- index() - Method in class org.elasticsearch.snapshots.InternalSnapshotsInfoService.SnapshotShard
- index(boolean) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- index(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Set the index this action is operating on.
- index(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- index(String) - Method in interface org.elasticsearch.action.DocWriteRequest
-
Set the index for this request
- index(String) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- index(String) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- index(String) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- index(String) - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
-
Sets the index.
- index(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- index(String) - Method in class org.elasticsearch.cluster.metadata.Metadata
- index(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- index(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- index(IndexRequest) - Method in interface org.elasticsearch.client.Client
-
Index a JSON source associated with a given index and type.
- index(IndexRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- index(IndexRequest, ActionListener<IndexResponse>) - Method in interface org.elasticsearch.client.Client
-
Index a document associated with a given index and type.
- index(IndexRequest, ActionListener<IndexResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- index(Engine.Index) - Method in class org.elasticsearch.index.engine.Engine
-
Perform document index operation on the engine
- index(Engine.Index) - Method in class org.elasticsearch.index.engine.InternalEngine
- index(Engine.Index) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- index(Index) - Method in class org.elasticsearch.cluster.metadata.Metadata
- index(Index) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- index(DocumentParserContext, GeoPoint) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- index(DocumentParserContext, Geometry) - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper
- index(DocumentParserContext, T) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
-
Build an index document using a parsed geometry
- Index - Class in org.elasticsearch.index
-
A value class representing the basic required properties of an Elasticsearch index.
- Index() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Index
- Index(String, String) - Constructor for class org.elasticsearch.index.Index
- Index(String, String, long, long, byte[]) - Constructor for class org.elasticsearch.index.translog.Translog.Index
- Index(String, String, long, long, long, byte[], String, long) - Constructor for class org.elasticsearch.index.translog.Translog.Index
- Index(Term, long, ParsedDocument) - Constructor for class org.elasticsearch.index.engine.Engine.Index
- Index(Term, ParsedDocument, long, long, long, VersionType, Engine.Operation.Origin, long, long, boolean, long, long) - Constructor for class org.elasticsearch.index.engine.Engine.Index
- Index(StreamInput) - Constructor for class org.elasticsearch.index.Index
-
Read from a stream.
- Index(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Index
- Index(Engine.Index, Engine.IndexResult) - Constructor for class org.elasticsearch.index.translog.Translog.Index
- Index(RecoveryState.RecoveryFilesDetails) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Index
- INDEX - Enum constant in enum class org.elasticsearch.action.DocWriteRequest.OpType
-
Index the source.
- INDEX - Enum constant in enum class org.elasticsearch.index.analysis.AnalyzerScope
- INDEX - Enum constant in enum class org.elasticsearch.index.engine.Engine.HistorySource
- INDEX - Enum constant in enum class org.elasticsearch.index.engine.Engine.Operation.TYPE
- INDEX - Enum constant in enum class org.elasticsearch.index.translog.Translog.Operation.Type
- INDEX - Enum constant in enum class org.elasticsearch.indices.recovery.RecoveryState.Stage
-
recovery of lucene files, either reusing local ones are copying new ones
- INDEX - Enum constant in enum class org.elasticsearch.ingest.IngestDocument.Metadata
- INDEX - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- INDEX_ANALYSIS_CHAR_FILTER - Static variable in class org.elasticsearch.index.analysis.AnalysisRegistry
- INDEX_ANALYSIS_FILTER - Static variable in class org.elasticsearch.index.analysis.AnalysisRegistry
- INDEX_ANALYSIS_TOKENIZER - Static variable in class org.elasticsearch.index.analysis.AnalysisRegistry
- INDEX_AUTO_EXPAND_REPLICAS_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_BALANCE_FACTOR_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- INDEX_BLOCKS_METADATA_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_BLOCKS_READ_ONLY_ALLOW_DELETE_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_BLOCKS_READ_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_BLOCKS_WRITE_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_BUFFER_SIZE_SETTING - Static variable in class org.elasticsearch.indices.IndexingMemoryController
-
How much heap (% or bytes) we will share across all actively indexing shards on this node (default: 10%).
- INDEX_CACHE_REQUEST_ENABLED_SETTING - Static variable in class org.elasticsearch.indices.IndicesRequestCache
-
A setting to enable or disable request caching on an index level.
- INDEX_CHECK_ON_STARTUP - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_CLOSED - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of closing an index.
- INDEX_CLOSED_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.MetadataIndexStateService
- INDEX_CLOSED_BLOCK_ID - Static variable in class org.elasticsearch.cluster.metadata.MetadataIndexStateService
- INDEX_CODEC_SETTING - Static variable in class org.elasticsearch.index.engine.EngineConfig
-
Index setting to change the low level lucene codec used for writing new segments.
- INDEX_COMPOUND_FORMAT_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_CONTENT_TYPE - Static variable in class org.elasticsearch.client.Requests
-
The default content type to use to generate source documents when indexing.
- INDEX_CREATED - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of an API creation of an index.
- INDEX_DATA_PATH_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_DELAYED_NODE_LEFT_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.routing.UnassignedInfo
- INDEX_DETAILS_INTRODUCED - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- INDEX_DETAILS_XCONTENT_PARAM - Static variable in class org.elasticsearch.snapshots.SnapshotInfo
- INDEX_FIELD - Static variable in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- INDEX_FIELD - Static variable in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- INDEX_FIELD - Static variable in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- INDEX_FIELDDATA_CACHE_KEY - Static variable in class org.elasticsearch.index.fielddata.IndexFieldDataService
- INDEX_FILE_PREFIX - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- INDEX_FLUSH_AFTER_MERGE_THRESHOLD_SIZE_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
The minimum size of a merge that triggers a flush in order to free resources
- INDEX_FOLDER_NAME - Static variable in class org.elasticsearch.index.shard.ShardPath
- INDEX_FORMAT_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_GC_DELETES_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_GEN_IN_REPO_DATA_VERSION - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- INDEX_HIDDEN_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Whether the index is considered hidden or not.
- INDEX_INDEXING_SLOWLOG_LEVEL_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
- INDEX_INDEXING_SLOWLOG_MAX_SOURCE_CHARS_TO_LOG_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
-
Reads how much of the source to log.
- INDEX_INDEXING_SLOWLOG_PREFIX - Static variable in class org.elasticsearch.index.IndexingSlowLog
- INDEX_INDEXING_SLOWLOG_REFORMAT_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
- INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_DEBUG_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
- INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_INFO_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
- INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_TRACE_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
- INDEX_INDEXING_SLOWLOG_THRESHOLD_INDEX_WARN_SETTING - Static variable in class org.elasticsearch.index.IndexingSlowLog
- INDEX_LATEST_BLOB - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- INDEX_LOAD_RANDOM_ACCESS_FILTERS_EAGERLY_SETTING - Static variable in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- INDEX_LOCK_FACTOR_SETTING - Static variable in class org.elasticsearch.index.store.FsDirectoryFactory
- INDEX_MAPPER_DYNAMIC_DEFAULT - Static variable in class org.elasticsearch.index.mapper.MapperService
- INDEX_MAPPER_DYNAMIC_SETTING - Static variable in class org.elasticsearch.index.mapper.MapperService
-
Deprecated.
- INDEX_MAPPING_DEPTH_LIMIT_SETTING - Static variable in class org.elasticsearch.index.mapper.MapperService
- INDEX_MAPPING_DIMENSION_FIELDS_LIMIT_SETTING - Static variable in class org.elasticsearch.index.mapper.MapperService
- INDEX_MAPPING_FIELD_NAME_LENGTH_LIMIT_SETTING - Static variable in class org.elasticsearch.index.mapper.MapperService
- INDEX_MAPPING_NESTED_DOCS_LIMIT_SETTING - Static variable in class org.elasticsearch.index.mapper.MapperService
- INDEX_MAPPING_NESTED_FIELDS_LIMIT_SETTING - Static variable in class org.elasticsearch.index.mapper.MapperService
- INDEX_MAPPING_TOTAL_FIELDS_LIMIT_SETTING - Static variable in class org.elasticsearch.index.mapper.MapperService
- INDEX_MERGE_ENABLED - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_DELETES_PCT_ALLOWED_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_EXPUNGE_DELETES_ALLOWED_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_FLOOR_SEGMENT_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_MAX_MERGE_AT_ONCE_EXPLICIT_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_MAX_MERGE_AT_ONCE_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_MAX_MERGED_SEGMENT_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_MERGE_POLICY_SEGMENTS_PER_TIER_SETTING - Static variable in class org.elasticsearch.index.MergePolicyConfig
- INDEX_METADATA_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_METADATA_FORMAT - Variable in class org.elasticsearch.gateway.MetaStateService
- INDEX_METADATA_FORMAT - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- INDEX_NUMBER_OF_REPLICAS_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_NUMBER_OF_ROUTING_SHARDS_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_NUMBER_OF_SHARDS_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_OPTIMIZE_AUTO_GENERATED_IDS - Static variable in class org.elasticsearch.index.engine.EngineConfig
-
Configures an index to optimize documents with auto generated ids for append only.
- INDEX_OPTIONS_DOCS - Static variable in class org.elasticsearch.index.mapper.TypeParsers
- INDEX_OPTIONS_FREQS - Static variable in class org.elasticsearch.index.mapper.TypeParsers
- INDEX_OPTIONS_OFFSETS - Static variable in class org.elasticsearch.index.mapper.TypeParsers
- INDEX_OPTIONS_POSITIONS - Static variable in class org.elasticsearch.index.mapper.TypeParsers
- INDEX_PREFIX_MAX_CHARS - Static variable in class org.elasticsearch.index.mapper.TextFieldMapper.Defaults
- INDEX_PREFIX_MIN_CHARS - Static variable in class org.elasticsearch.index.mapper.TextFieldMapper.Defaults
- INDEX_PRIORITY_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_QUERY_CACHE_ENABLED_SETTING - Static variable in class org.elasticsearch.index.IndexModule
- INDEX_QUERY_CACHE_EVERYTHING_SETTING - Static variable in class org.elasticsearch.index.IndexModule
- INDEX_READ_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_READ_ONLY_ALLOW_DELETE_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_READ_ONLY_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_READ_ONLY_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_RECOVERY_TYPE_SETTING - Static variable in class org.elasticsearch.index.IndexModule
- INDEX_REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_REOPENED - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of opening a closed index.
- INDEX_RESIZE_SOURCE_NAME - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_RESIZE_SOURCE_NAME_KEY - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_RESIZE_SOURCE_UUID - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_RESIZE_SOURCE_UUID_KEY - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_ROLLUP_SOURCE_NAME - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_ROLLUP_SOURCE_NAME_KEY - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_ROLLUP_SOURCE_UUID - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_ROLLUP_SOURCE_UUID_KEY - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_ROUTING_ALLOCATION_ENABLE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
- INDEX_ROUTING_EXCLUDE_GROUP_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_ROUTING_EXCLUDE_GROUP_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_ROUTING_INCLUDE_GROUP_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_ROUTING_INCLUDE_GROUP_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_ROUTING_INITIAL_RECOVERY_GROUP_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_ROUTING_PARTITION_SIZE_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_ROUTING_REBALANCE_ENABLE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
- INDEX_ROUTING_REQUIRE_GROUP_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_ROUTING_REQUIRE_GROUP_SETTING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_SEARCH_IDLE_AFTER - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_SEARCH_SLOWLOG_LEVEL - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_DEBUG_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_INFO_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_TRACE_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_FETCH_WARN_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_DEBUG_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_INFO_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_TRACE_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_SLOWLOG_THRESHOLD_QUERY_WARN_SETTING - Static variable in class org.elasticsearch.index.SearchSlowLog
- INDEX_SEARCH_THROTTLED - Static variable in class org.elasticsearch.index.IndexSettings
-
Marks an index to be searched throttled.
- INDEX_SETTING_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_SETTING_SHARD_LIMIT_GROUP - Static variable in class org.elasticsearch.indices.ShardLimitValidator
- INDEX_SHARD_SNAPSHOT_FORMAT - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- INDEX_SHARD_SNAPSHOTS_FORMAT - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- INDEX_SOFT_DELETES_RETENTION_LEASE_PERIOD_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Controls the maximum length of time since a retention lease is created or renewed before it is considered expired.
- INDEX_SOFT_DELETES_RETENTION_OPERATIONS_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Controls how many soft-deleted documents will be kept around before being merged away.
- INDEX_SOFT_DELETES_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Specifies if the index should use soft-delete instead of hard-delete for update/delete operations.
- INDEX_SORT_FIELD_SETTING - Static variable in class org.elasticsearch.index.IndexSortConfig
-
The list of field names
- INDEX_SORT_MISSING_SETTING - Static variable in class org.elasticsearch.index.IndexSortConfig
-
The missing value for each specified sort field (ie.
- INDEX_SORT_MODE_SETTING - Static variable in class org.elasticsearch.index.IndexSortConfig
-
The
MultiValueMode
for each specified sort field (ie. - INDEX_SORT_ORDER_SETTING - Static variable in class org.elasticsearch.index.IndexSortConfig
-
The
SortOrder
for each specified sort field (ie. - INDEX_STATE_FILE_PREFIX - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_STORE_PRE_LOAD_SETTING - Static variable in class org.elasticsearch.index.IndexModule
-
On which extensions to load data into the file-system cache upon opening of files.
- INDEX_STORE_STATS_REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.index.store.Store
- INDEX_STORE_TYPE_SETTING - Static variable in class org.elasticsearch.index.IndexModule
- INDEX_TEMPLATE - Enum constant in enum class org.elasticsearch.index.mapper.MapperService.MergeReason
-
Merge mappings from a composable index template.
- INDEX_TEMPLATE - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Response
- INDEX_TEMPLATES - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Response
- INDEX_TIME - Enum constant in enum class org.elasticsearch.index.analysis.AnalysisMode
-
AnalysisMode representing analysis components that can be used only at index time
- INDEX_TOTAL_SHARDS_PER_NODE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
-
Controls the maximum number of shards per index on a single Elasticsearch node.
- INDEX_TRANSLOG_DURABILITY_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_TRANSLOG_FLUSH_THRESHOLD_SIZE_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_TRANSLOG_GENERATION_THRESHOLD_SIZE_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
The maximum size of a translog generation.
- INDEX_TRANSLOG_RETENTION_AGE_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Controls how long translog files that are no longer needed for persistence reasons will be kept around before being deleted.
- INDEX_TRANSLOG_RETENTION_SIZE_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Controls how many translog files that are no longer needed for persistence reasons will be kept around before being deleted.
- INDEX_TRANSLOG_RETENTION_TOTAL_FILES_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Controls the number of translog files that are no longer needed for persistence reasons will be kept around before being deleted.
- INDEX_TRANSLOG_SYNC_INTERVAL_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_UUID_NA_VALUE - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- INDEX_WARMER_ENABLED_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- INDEX_WRITE_BLOCK - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- IndexAbstraction - Interface in org.elasticsearch.cluster.metadata
-
An index abstraction is a reference to one or more concrete indices.
- IndexAbstraction.Alias - Class in org.elasticsearch.cluster.metadata
-
Represents an alias and groups all
IndexMetadata
instances sharing the same alias name together. - IndexAbstraction.ConcreteIndex - Class in org.elasticsearch.cluster.metadata
-
Represents an concrete index and encapsulates its
IndexMetadata
- IndexAbstraction.DataStream - Class in org.elasticsearch.cluster.metadata
- IndexAbstraction.Type - Enum Class in org.elasticsearch.cluster.metadata
-
An index abstraction type.
- IndexAbstractionResolver - Class in org.elasticsearch.cluster.metadata
- IndexAbstractionResolver(IndexNameExpressionResolver) - Constructor for class org.elasticsearch.cluster.metadata.IndexAbstractionResolver
- IndexAction - Class in org.elasticsearch.action.index
- indexAliases(ClusterState, String, Predicate<AliasMetadata>, Predicate<DataStreamAlias>, boolean, Set<String>) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Iterates through the list of indices and selects the effective list of required aliases for the given index.
- indexAliasesRequest() - Static method in class org.elasticsearch.client.Requests
-
Creates an index aliases request allowing to add and remove aliases.
- indexAnalyzer - Variable in class org.elasticsearch.index.mapper.TextParams.Analyzers
- indexAnalyzer(String, Function<String, NamedAnalyzer>) - Method in class org.elasticsearch.index.mapper.MapperService
-
Return the index-time analyzer associated with a particular field
- indexAnalyzer(String, Function<String, NamedAnalyzer>) - Method in class org.elasticsearch.index.mapper.MappingLookup
- indexAnalyzers - Variable in class org.elasticsearch.index.mapper.FieldMapper
- indexAnalyzers - Variable in class org.elasticsearch.index.mapper.TextParams.Analyzers
- indexAnalyzers() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- indexAnalyzers() - Method in class org.elasticsearch.index.mapper.FieldMapper
- indexAnalyzers(String, TextFieldMapper.SubFieldInfo, TextFieldMapper.SubFieldInfo) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- IndexAnalyzers - Class in org.elasticsearch.index.analysis
-
IndexAnalyzers contains a name to analyzer mapping for a specific index.
- IndexAnalyzers(Map<String, NamedAnalyzer>, Map<String, NamedAnalyzer>, Map<String, NamedAnalyzer>) - Constructor for class org.elasticsearch.index.analysis.IndexAnalyzers
- indexBlocked(ClusterBlockLevel, String) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- indexBlockedException(ClusterBlockLevel, String) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- indexBlockedRaiseException(ClusterBlockLevel, String) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- indexBlockLevel() - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- indexBlockLevel() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Index level block to check before request execution.
- indexBlockLevel() - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- indexBlockLevel() - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- indexBoost() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- indexBoost(String, float) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets the boost a specific index or alias will receive when the query is executed against it.
- indexBoosts() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the boost a specific indices or aliases will receive when the query is executed against them.
- indexByName(String) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- indexCache - Variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
- IndexCache - Class in org.elasticsearch.index.cache
- IndexCache(IndexSettings, QueryCache, BitsetFilterCache) - Constructor for class org.elasticsearch.index.cache.IndexCache
- IndexClosedException - Exception in org.elasticsearch.indices
-
Exception indicating that one or more requested indices are closed.
- IndexClosedException(StreamInput) - Constructor for exception org.elasticsearch.indices.IndexClosedException
- IndexClosedException(Index) - Constructor for exception org.elasticsearch.indices.IndexClosedException
- indexCommit() - Method in class org.elasticsearch.repositories.SnapshotShardContext
- IndexCommitRef(IndexCommit, CheckedRunnable<IOException>) - Constructor for class org.elasticsearch.index.engine.Engine.IndexCommitRef
- IndexComponent - Interface in org.elasticsearch.index
- indexCreated - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition.Stats
- IndexCreationException - Exception in org.elasticsearch.indices
- IndexCreationException(String, Throwable) - Constructor for exception org.elasticsearch.indices.IndexCreationException
- IndexCreationException(StreamInput) - Constructor for exception org.elasticsearch.indices.IndexCreationException
- IndexDiskUsageStats - Class in org.elasticsearch.action.admin.indices.diskusage
-
The result of analyzing disk usage of each field in a shard/index
- IndexDiskUsageStats(long) - Constructor for class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- IndexDiskUsageStats(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- IndexDiskUsageStats.PerFieldDiskUsage - Class in org.elasticsearch.action.admin.indices.diskusage
-
Disk usage stats for a single field
- INDEXED - Enum constant in enum class org.elasticsearch.index.query.GeoExecType
- INDEXED_SHAPE_FIELD - Static variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- indexedShapeId - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- indexedShapeId() - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- indexedShapeIndex - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- indexedShapeIndex() - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- indexedShapeIndex(String) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Sets the name of the index where the indexed Shape can be found
- indexedShapePath - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- indexedShapePath() - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- indexedShapePath(String) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Sets the path of the field in the indexed Shape document that has the Shape itself
- indexedShapeRouting - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- indexedShapeRouting() - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- indexedShapeRouting(String) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Sets the optional routing to the indexed Shape that will be used in the query
- indexedShapeType - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- indexedShapeType() - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Deprecated.Types are in the process of being removed.
- indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldType
- indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- indexedValueForSearch(Object) - Method in class org.elasticsearch.index.mapper.TermBasedFieldType
-
Returns the indexed value used to construct search "values".
- IndexEventListener - Interface in org.elasticsearch.index.shard
-
An index event listener is the primary extension point for plugins and build-in services to react / listen to per-index and per-shard events.
- indexExists(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- indexExists(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- indexExists(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
- IndexFeatureStats - Class in org.elasticsearch.action.admin.cluster.stats
-
Statistics about an index feature.
- IndexFieldCapabilities - Class in org.elasticsearch.action.fieldcaps
-
Describes the capabilities of a field in a single index.
- indexFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.FieldData
- indexFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
- indexFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint.Fielddata
- indexFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
- indexFieldData - Variable in class org.elasticsearch.search.aggregations.support.ValuesSource.Range
- indexFieldData() - Method in class org.elasticsearch.search.aggregations.support.FieldContext
- IndexFieldData<FD extends LeafFieldData> - Interface in org.elasticsearch.index.fielddata
-
Thread-safe utility class that allows to get per-segment values via the
IndexFieldData.load(LeafReaderContext)
method. - IndexFieldData.Builder - Interface in org.elasticsearch.index.fielddata
- IndexFieldData.Global<FD extends LeafFieldData> - Interface in org.elasticsearch.index.fielddata
- IndexFieldData.XFieldComparatorSource - Class in org.elasticsearch.index.fielddata
- IndexFieldData.XFieldComparatorSource.Nested - Class in org.elasticsearch.index.fielddata
-
Simple wrapper class around a filter that matches parent documents and a filter that matches child documents.
- IndexFieldDataCache - Interface in org.elasticsearch.index.fielddata
-
A simple field data cache abstraction on the *index* level.
- IndexFieldDataCache.Listener - Interface in org.elasticsearch.index.fielddata
- IndexFieldDataCache.None - Class in org.elasticsearch.index.fielddata
- IndexFieldDataService - Class in org.elasticsearch.index.fielddata
- IndexFieldDataService(IndexSettings, IndicesFieldDataCache, CircuitBreakerService) - Constructor for class org.elasticsearch.index.fielddata.IndexFieldDataService
- IndexFieldMapper - Class in org.elasticsearch.index.mapper
- IndexFieldMapper() - Constructor for class org.elasticsearch.index.mapper.IndexFieldMapper
- IndexFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- indexFiles() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns list of files in the shard
- indexFiles() - Method in class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
-
Returns a list of file in the snapshot
- indexFilter() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- indexFilter() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- indexFilter(QueryBuilder) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
-
Allows to filter indices if the provided
QueryBuilder
rewrites to `match_none` on every shard. - IndexGeoPointFieldData - Interface in org.elasticsearch.index.fielddata
-
Specialization of
IndexFieldData
for geo points. - indexGet(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- indexGet(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- indexGraveyard() - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- indexGraveyard() - Method in class org.elasticsearch.cluster.metadata.Metadata
-
The collection of index deletions in the cluster.
- indexGraveyard(IndexGraveyard) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- IndexGraveyard - Class in org.elasticsearch.cluster.metadata
-
A collection of tombstones for explicitly marking indices as deleted in the cluster state.
- IndexGraveyard(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.IndexGraveyard
- IndexGraveyard.Builder - Class in org.elasticsearch.cluster.metadata
-
A class to build an IndexGraveyard.
- IndexGraveyard.IndexGraveyardDiff - Class in org.elasticsearch.cluster.metadata
-
A class representing a diff of two IndexGraveyard objects.
- IndexGraveyard.Tombstone - Class in org.elasticsearch.cluster.metadata
-
An individual tombstone entry for representing a deleted index.
- IndexHistogramFieldData - Class in org.elasticsearch.index.fielddata
-
Specialization of
IndexFieldData
for histograms. - IndexHistogramFieldData(String, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.IndexHistogramFieldData
- indexId() - Method in class org.elasticsearch.repositories.SnapshotShardContext
- IndexId - Class in org.elasticsearch.repositories
-
Represents a single snapshotted index in the repository.
- IndexId(String, String) - Constructor for class org.elasticsearch.repositories.IndexId
- IndexId(StreamInput) - Constructor for class org.elasticsearch.repositories.IndexId
- IndexInfo(String, Version, Exception) - Constructor for class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.IndexInfo
- IndexInfo(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.IndexInfo
- indexing - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- indexing() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- indexing(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- Indexing - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- INDEXING_DATA - Enum constant in enum class org.elasticsearch.transport.Compression.Enabled
- INDEXING_PRESSURE - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- IndexingMemoryController - Class in org.elasticsearch.indices
- IndexingOperationListener - Interface in org.elasticsearch.index.shard
-
An indexing listener for indexing, delete, events.
- IndexingOperationListener.CompositeListener - Class in org.elasticsearch.index.shard
-
A Composite listener that multiplexes calls to each of the listeners methods.
- indexingPressure - Variable in class org.elasticsearch.action.support.replication.TransportWriteAction
- IndexingPressure - Class in org.elasticsearch.index
- IndexingPressure(Settings) - Constructor for class org.elasticsearch.index.IndexingPressure
- IndexingPressureStats - Class in org.elasticsearch.index.stats
- IndexingPressureStats(long, long, long, long, long, long, long, long, long, long, long, long) - Constructor for class org.elasticsearch.index.stats.IndexingPressureStats
- IndexingPressureStats(StreamInput) - Constructor for class org.elasticsearch.index.stats.IndexingPressureStats
- IndexingSlowLog - Class in org.elasticsearch.index
- indexingStats(String...) - Method in class org.elasticsearch.index.shard.IndexShard
- IndexingStats - Class in org.elasticsearch.index.shard
- IndexingStats() - Constructor for class org.elasticsearch.index.shard.IndexingStats
- IndexingStats(StreamInput) - Constructor for class org.elasticsearch.index.shard.IndexingStats
- IndexingStats(IndexingStats.Stats, Map<String, IndexingStats.Stats>) - Constructor for class org.elasticsearch.index.shard.IndexingStats
- IndexingStats.Stats - Class in org.elasticsearch.index.shard
- indexingStrategyForOperation(Engine.Index) - Method in class org.elasticsearch.index.engine.InternalEngine
- indexInsert(int, int, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- indexInsert(int, KType, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- IndexLongFieldRange - Class in org.elasticsearch.index.shard
-
Class representing an (inclusive) range of
long
values in a field in an index which may comprise multiple shards. - indexMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- indexMatches(String) - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Given an index pattern, checks whether it matches against the current shard.
- indexMetaBlobId(SnapshotId, IndexId) - Method in class org.elasticsearch.repositories.IndexMetaDataGenerations
-
Get the blob id by
SnapshotId
andIndexId
and fall back to the value ofSnapshotId.getUUID()
if none is known to enable backwards compatibility with versions older thanSnapshotsService.SHARD_GEN_IN_REPO_DATA_VERSION
which used the snapshot uuid as index metadata blob uuid. - IndexMetadata - Class in org.elasticsearch.cluster.metadata
- IndexMetadata.APIBlock - Enum Class in org.elasticsearch.cluster.metadata
- IndexMetadata.Builder - Class in org.elasticsearch.cluster.metadata
- IndexMetadata.State - Enum Class in org.elasticsearch.cluster.metadata
- indexMetadataChanged(IndexMetadata, IndexMetadata) - Static method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff theIndexMetadata
for a given index has changed between the previous cluster state and the new cluster state. - indexMetaDataGenerations() - Method in class org.elasticsearch.repositories.RepositoryData
- IndexMetaDataGenerations - Class in org.elasticsearch.repositories
-
Tracks the blob uuids of blobs containing
IndexMetadata
for snapshots as well an identifier for each of these blobs. - indexMetaDataToRemoveAfterRemovingSnapshots(Collection<SnapshotId>) - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns a map of
IndexId
to a collection ofString
containing all theIndexId
and theIndexMetadata
blob name in it that can be removed after removing the given snapshot from the repository. - IndexMetadataUpdater - Class in org.elasticsearch.cluster.routing.allocation
-
Observer that tracks changes made to RoutingNodes in order to update the primary terms and in-sync allocation ids in
IndexMetadata
once the allocation round has completed. - IndexMetadataUpdater() - Constructor for class org.elasticsearch.cluster.routing.allocation.IndexMetadataUpdater
- IndexMetadataVerifier - Class in org.elasticsearch.cluster.metadata
-
This service is responsible for verifying index metadata when an index is introduced to the cluster, for example when restarting nodes, importing dangling indices, or restoring an index from a snapshot repository.
- IndexMetadataVerifier(Settings, NamedXContentRegistry, MapperRegistry, IndexScopedSettings, ScriptCompiler) - Constructor for class org.elasticsearch.cluster.metadata.IndexMetadataVerifier
- IndexModule - Class in org.elasticsearch.index
-
IndexModule represents the central extension point for index level custom implementations like:
Similarity
- NewSimilarity
implementations can be registered throughIndexModule.addSimilarity(String, TriFunction)
while existing Providers can be referenced through Settings under theIndexModule.SIMILARITY_SETTINGS_PREFIX
prefix along with the "type" value. - IndexModule(IndexSettings, AnalysisRegistry, EngineFactory, Map<String, IndexStorePlugin.DirectoryFactory>, BooleanSupplier, IndexNameExpressionResolver, Map<String, IndexStorePlugin.RecoveryStateFactory>) - Constructor for class org.elasticsearch.index.IndexModule
-
Construct the index module for the index with the specified index settings.
- IndexModule.Type - Enum Class in org.elasticsearch.index
- indexName() - Method in class org.elasticsearch.repositories.RepositoryShardId
- indexName(String) - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateRequest
- indexNameExpressionResolver - Variable in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- indexNameExpressionResolver - Variable in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- indexNameExpressionResolver - Variable in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- indexNameExpressionResolver - Variable in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- IndexNameExpressionResolver - Class in org.elasticsearch.cluster.metadata
- IndexNameExpressionResolver(ThreadContext, SystemIndices) - Constructor for class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- IndexNameExpressionResolver.Context - Class in org.elasticsearch.cluster.metadata
- IndexNameExpressionResolver.DateMathExpressionResolver - Class in org.elasticsearch.cluster.metadata
- IndexNameExpressionResolver.ResolverContext - Class in org.elasticsearch.cluster.metadata
-
This is a context for the DateMathExpressionResolver which does not require
IndicesOptions
orClusterState
since it uses only the start time to resolve expressions. - IndexNotFoundException - Exception in org.elasticsearch.index
- IndexNotFoundException(String) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
- IndexNotFoundException(String, String) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
-
Construct with a custom message.
- IndexNotFoundException(String, Throwable) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
- IndexNotFoundException(StreamInput) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
- IndexNotFoundException(Index) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
- IndexNotFoundException(Index, Throwable) - Constructor for exception org.elasticsearch.index.IndexNotFoundException
- IndexNumericFieldData - Class in org.elasticsearch.index.fielddata
-
Base class for numeric field data.
- IndexNumericFieldData() - Constructor for class org.elasticsearch.index.fielddata.IndexNumericFieldData
- IndexNumericFieldData.NumericType - Enum Class in org.elasticsearch.index.fielddata
-
The type of number.
- indexOf(byte, int) - Method in class org.elasticsearch.common.bytes.AbstractBytesReference
- indexOf(byte, int) - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Finds the index of the first occurrence of the given marker between within the given bounds.
- indexOf(byte, int) - Method in class org.elasticsearch.common.bytes.CompositeBytesReference
- indexOf(byte, int) - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- indexOf(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- indexOf(Iterable<T>, Predicate<T>) - Static method in class org.elasticsearch.common.util.iterable.Iterables
- indexOf(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- indexOptions(Function<FieldMapper, String>) - Static method in class org.elasticsearch.index.mapper.TextParams
- IndexOrdinalsFieldData - Interface in org.elasticsearch.index.fielddata
-
Specialization of
IndexFieldData
for data that is indexed with ordinals. - IndexOutputOutputStream - Class in org.elasticsearch.common.lucene.store
-
OutputStream
that writes into underlying IndexOutput - IndexOutputOutputStream(IndexOutput) - Constructor for class org.elasticsearch.common.lucene.store.IndexOutputOutputStream
- indexParam(Function<FieldMapper, Boolean>, boolean) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- indexPaths(Index) - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all index paths.
- IndexPatternMatcher - Interface in org.elasticsearch.indices
-
An IndexPatternMatcher holds an index pattern in a string and, given a
Metadata
object, can return a list of index names matching that pattern. - indexPatterns() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- indexPatterns(List<String>) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.Builder
- IndexPrimaryShardNotAllocatedException - Exception in org.elasticsearch.indices
-
Thrown when some action cannot be performed because the primary shard of some shard group in an index has not been allocated post api action.
- IndexPrimaryShardNotAllocatedException(StreamInput) - Constructor for exception org.elasticsearch.indices.IndexPrimaryShardNotAllocatedException
- IndexPrimaryShardNotAllocatedException(Index) - Constructor for exception org.elasticsearch.indices.IndexPrimaryShardNotAllocatedException
- IndexQueryCache - Class in org.elasticsearch.index.cache.query
-
The index-level query cache.
- IndexQueryCache(IndexSettings, IndicesQueryCache) - Constructor for class org.elasticsearch.index.cache.query.IndexQueryCache
- indexReplace(int, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- indexReplace(int, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- indexRequest() - Static method in class org.elasticsearch.client.Requests
- indexRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Create an index request against a specific index.
- IndexRequest - Class in org.elasticsearch.action.index
-
Index request to index a typed JSON document into a specific index and make it searchable.
- IndexRequest() - Constructor for class org.elasticsearch.action.index.IndexRequest
- IndexRequest(String) - Constructor for class org.elasticsearch.action.index.IndexRequest
-
Constructs a new index request against the specific index.
- IndexRequest(String, String) - Constructor for class org.elasticsearch.action.index.IndexRequest
-
Deprecated.Types are in the process of being removed. Use
IndexRequest(String)
instead. - IndexRequest(String, String, String) - Constructor for class org.elasticsearch.action.index.IndexRequest
-
Deprecated.Types are in the process of being removed. Use
IndexRequest(String)
withIndexRequest.id(String)
instead. - IndexRequest(StreamInput) - Constructor for class org.elasticsearch.action.index.IndexRequest
- IndexRequest(ShardId, StreamInput) - Constructor for class org.elasticsearch.action.index.IndexRequest
- IndexRequestBuilder - Class in org.elasticsearch.action.index
-
An index document action request builder.
- IndexRequestBuilder(ElasticsearchClient, IndexAction) - Constructor for class org.elasticsearch.action.index.IndexRequestBuilder
- IndexRequestBuilder(ElasticsearchClient, IndexAction, String) - Constructor for class org.elasticsearch.action.index.IndexRequestBuilder
- IndexResponse - Class in org.elasticsearch.action.index
-
A response of an index operation,
- IndexResponse(StreamInput) - Constructor for class org.elasticsearch.action.index.IndexResponse
- IndexResponse(ShardId, String, String, long, long, long, boolean) - Constructor for class org.elasticsearch.action.index.IndexResponse
- IndexResponse(ShardId, StreamInput) - Constructor for class org.elasticsearch.action.index.IndexResponse
- IndexResponse.Builder - Class in org.elasticsearch.action.index
-
Builder class for
IndexResponse
. - IndexResult(long, long, long, boolean) - Constructor for class org.elasticsearch.index.engine.Engine.IndexResult
- IndexResult(Exception, long) - Constructor for class org.elasticsearch.index.engine.Engine.IndexResult
-
use in case of the index operation failed before getting to internal engine
- IndexResult(Exception, long, long, long) - Constructor for class org.elasticsearch.index.engine.Engine.IndexResult
- IndexResult(Index) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.IndexResult
- IndexResult(Index, Exception) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.IndexResult
- IndexResult(Index, CloseIndexResponse.ShardResult[]) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.IndexResult
- IndexResult(Mapping) - Constructor for class org.elasticsearch.index.engine.Engine.IndexResult
- indexRouting() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Returns the index routing value associated with the alias
- indexRouting() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- indexRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- indexRouting(String) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Associates an index routing value to the alias
- indexRouting(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- indexRouting(String) - Method in class org.elasticsearch.cluster.metadata.AliasMetadata.Builder
- IndexRouting - Class in org.elasticsearch.cluster.routing
-
Generates the shard id for
(id, routing)
pairs. - indexRoutingTable(ClusterState, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- IndexRoutingTable - Class in org.elasticsearch.cluster.routing
-
The
IndexRoutingTable
represents routing information for a single index. - IndexRoutingTable.Builder - Class in org.elasticsearch.cluster.routing
- indexRoutingTableChanged(String) - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff the routing table has changed for the given index. - IndexScope - Enum constant in enum class org.elasticsearch.common.settings.Setting.Property
-
Index scope
- IndexScopedSettings - Class in org.elasticsearch.common.settings
-
Encapsulates all valid index level settings.
- IndexScopedSettings(Settings, Set<Setting<?>>) - Constructor for class org.elasticsearch.common.settings.IndexScopedSettings
- indexScriptValues(SearchLookup, LeafReaderContext, int, DocumentParserContext) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper
- indexScriptValues(SearchLookup, LeafReaderContext, int, DocumentParserContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper
- indexScriptValues(SearchLookup, LeafReaderContext, int, DocumentParserContext) - Method in class org.elasticsearch.index.mapper.FieldMapper
-
Run the script associated with the field and index the values that it emits This method should only be called if
FieldMapper.hasScript()
has returnedtrue
- indexScriptValues(SearchLookup, LeafReaderContext, int, DocumentParserContext) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- indexScriptValues(SearchLookup, LeafReaderContext, int, DocumentParserContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper
- indexScriptValues(SearchLookup, LeafReaderContext, int, DocumentParserContext) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper
- indexScriptValues(SearchLookup, LeafReaderContext, int, DocumentParserContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper
- IndexSegments - Class in org.elasticsearch.action.admin.indices.segments
- indexService() - Method in class org.elasticsearch.search.internal.ReaderContext
- indexService(Index) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
-
Returns an IndexService for the specified index if exists otherwise returns
null
. - indexService(Index) - Method in class org.elasticsearch.indices.IndicesService
-
Returns an IndexService for the specified index if exists otherwise returns
null
. - IndexService - Class in org.elasticsearch.index
- IndexService(IndexSettings, IndexService.IndexCreationContext, NodeEnvironment, NamedXContentRegistry, SimilarityService, IndexService.ShardStoreDeleter, IndexAnalyzers, EngineFactory, CircuitBreakerService, BigArrays, ThreadPool, ScriptService, ClusterService, Client, QueryCache, IndexStorePlugin.DirectoryFactory, IndexEventListener, Function<IndexService, CheckedFunction<DirectoryReader, DirectoryReader, IOException>>, MapperRegistry, IndicesFieldDataCache, List<SearchOperationListener>, List<IndexingOperationListener>, NamedWriteableRegistry, BooleanSupplier, BooleanSupplier, IndexNameExpressionResolver, ValuesSourceRegistry, IndexStorePlugin.RecoveryStateFactory, IndexStorePlugin.IndexFoldersDeletionListener, IndexStorePlugin.SnapshotCommitSupplier) - Constructor for class org.elasticsearch.index.IndexService
- IndexService.IndexCreationContext - Enum Class in org.elasticsearch.index
- IndexService.ShardStoreDeleter - Interface in org.elasticsearch.index
- indexServiceSafe(Index) - Method in class org.elasticsearch.indices.IndicesService
-
Returns an IndexService for the specified index if exists otherwise a
IndexNotFoundException
is thrown. - IndexSettingProvider - Interface in org.elasticsearch.index.shard
-
An
IndexSettingProvider
is a provider for index level settings that can be set explicitly as a default value (so they show up as "set" for newly created indices) - indexSettings - Variable in class org.elasticsearch.index.AbstractIndexComponent
- indexSettings - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
- indexSettings() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns settings that should be added/changed in all restored indices
- indexSettings() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- indexSettings() - Method in class org.elasticsearch.index.shard.AbstractIndexShardComponent
- indexSettings() - Method in interface org.elasticsearch.index.shard.IndexShardComponent
- indexSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets settings that should be added/changed in all restored indices
- indexSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets settings that should be added/changed in all restored indices
- indexSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets settings that should be added/changed in all restored indices
- indexSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets settings that should be added/changed in all restored indices
- IndexSettings - Class in org.elasticsearch.index
-
This class encapsulates all index level settings and handles settings updates.
- IndexSettings(IndexMetadata, Settings) - Constructor for class org.elasticsearch.index.IndexSettings
-
Creates a new
IndexSettings
instance. - IndexSettings(IndexMetadata, Settings, IndexScopedSettings) - Constructor for class org.elasticsearch.index.IndexSettings
-
Creates a new
IndexSettings
instance. - indexShape(Geometry) - Method in class org.elasticsearch.index.mapper.GeoShapeIndexer
- indexShard() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- indexShard() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- indexShard() - Method in class org.elasticsearch.search.internal.ReaderContext
- indexShard() - Method in class org.elasticsearch.search.internal.SearchContext
- IndexShard - Class in org.elasticsearch.index.shard
- IndexShard(ShardRouting, IndexSettings, ShardPath, Store, Supplier<Sort>, IndexCache, MapperService, SimilarityService, EngineFactory, IndexEventListener, CheckedFunction<DirectoryReader, DirectoryReader, IOException>, ThreadPool, BigArrays, Engine.Warmer, List<SearchOperationListener>, List<IndexingOperationListener>, Runnable, RetentionLeaseSyncer, CircuitBreakerService, IndexStorePlugin.SnapshotCommitSupplier) - Constructor for class org.elasticsearch.index.shard.IndexShard
- IndexShard.ShardFailure - Class in org.elasticsearch.index.shard
-
Simple struct encapsulating a shard failure
- IndexShardClosedException - Exception in org.elasticsearch.index.shard
- IndexShardClosedException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardClosedException
- IndexShardClosedException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardClosedException
- IndexShardClosedException(ShardId, String) - Constructor for exception org.elasticsearch.index.shard.IndexShardClosedException
- IndexShardComponent - Interface in org.elasticsearch.index.shard
- IndexShardNotRecoveringException - Exception in org.elasticsearch.index.shard
- IndexShardNotRecoveringException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardNotRecoveringException
- IndexShardNotRecoveringException(ShardId, IndexShardState) - Constructor for exception org.elasticsearch.index.shard.IndexShardNotRecoveringException
- IndexShardNotStartedException - Exception in org.elasticsearch.index.shard
- IndexShardNotStartedException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardNotStartedException
- IndexShardNotStartedException(ShardId, IndexShardState) - Constructor for exception org.elasticsearch.index.shard.IndexShardNotStartedException
- IndexShardRecoveringException - Exception in org.elasticsearch.index.shard
- IndexShardRecoveringException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardRecoveringException
- IndexShardRecoveringException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardRecoveringException
- IndexShardRecoveryException - Exception in org.elasticsearch.index.shard
- IndexShardRecoveryException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardRecoveryException
- IndexShardRecoveryException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.shard.IndexShardRecoveryException
- IndexShardRelocatedException - Exception in org.elasticsearch.index.shard
- IndexShardRelocatedException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardRelocatedException
- IndexShardRelocatedException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardRelocatedException
- IndexShardRelocatedException(ShardId, String) - Constructor for exception org.elasticsearch.index.shard.IndexShardRelocatedException
- IndexShardRestoreException - Exception in org.elasticsearch.index.snapshots
-
Generic shard restore exception
- IndexShardRestoreException(StreamInput) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreException
- IndexShardRestoreException(ShardId, String) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreException
- IndexShardRestoreException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreException
- IndexShardRestoreFailedException - Exception in org.elasticsearch.index.snapshots
-
Thrown when restore of a shard fails
- IndexShardRestoreFailedException(StreamInput) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreFailedException
- IndexShardRestoreFailedException(ShardId, String) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreFailedException
- IndexShardRestoreFailedException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardRestoreFailedException
- IndexShardRoutingTable - Class in org.elasticsearch.cluster.routing
-
IndexShardRoutingTable
encapsulates all instances of a single shard. - IndexShardRoutingTable.Builder - Class in org.elasticsearch.cluster.routing
- indexShards(ClusterState, String, IndexRouting, String, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- IndexShardSegments - Class in org.elasticsearch.action.admin.indices.segments
- IndexShardSnapshotException - Exception in org.elasticsearch.index.snapshots
-
Generic shard snapshot exception
- IndexShardSnapshotException(StreamInput) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotException
- IndexShardSnapshotException(ShardId, String) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotException
- IndexShardSnapshotException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotException
- IndexShardSnapshotFailedException - Exception in org.elasticsearch.index.snapshots
-
Thrown when snapshot process is failed on a shard level
- IndexShardSnapshotFailedException(StreamInput) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotFailedException
- IndexShardSnapshotFailedException(ShardId, String) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotFailedException
- IndexShardSnapshotFailedException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.snapshots.IndexShardSnapshotFailedException
- IndexShardSnapshotStatus - Class in org.elasticsearch.index.snapshots
-
Represent shard snapshot status
- IndexShardSnapshotStatus.Copy - Class in org.elasticsearch.index.snapshots
-
Returns an immutable state of
IndexShardSnapshotStatus
at a given point in time. - IndexShardSnapshotStatus.Stage - Enum Class in org.elasticsearch.index.snapshots
-
Snapshot stage
- IndexShardStartedException - Exception in org.elasticsearch.index.shard
- IndexShardStartedException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.IndexShardStartedException
- IndexShardStartedException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardStartedException
- IndexShardState - Enum Class in org.elasticsearch.index.shard
- indexShardStateChanged(IndexShard, IndexShardState, IndexShardState, String) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called after a shard's
IndexShardState
changes. - IndexShardStats - Class in org.elasticsearch.action.admin.indices.stats
- IndexShardStats(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- IndexShardStats(ShardId, ShardStats[]) - Constructor for class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- IndexShardUpgradeStatus - Class in org.elasticsearch.action.admin.indices.upgrade.get
- indexSize - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition.Stats
- indexSnapshotDetails() - Method in class org.elasticsearch.snapshots.SnapshotInfo
- IndexSnapshotDetails(int, ByteSizeValue, int) - Constructor for class org.elasticsearch.snapshots.SnapshotInfo.IndexSnapshotDetails
- IndexSnapshotDetails(StreamInput) - Constructor for class org.elasticsearch.snapshots.SnapshotInfo.IndexSnapshotDetails
- IndexSnapshotsService - Class in org.elasticsearch.repositories
- IndexSnapshotsService(RepositoriesService) - Constructor for class org.elasticsearch.repositories.IndexSnapshotsService
- IndexSortConfig - Class in org.elasticsearch.index
-
Holds all the information that is used to build the sort order of an index.
- IndexSortConfig(IndexSettings) - Constructor for class org.elasticsearch.index.IndexSortConfig
- indexSortedOnField(String) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- IndexStats - Class in org.elasticsearch.action.admin.indices.stats
- IndexStats(String, String, ShardStats[]) - Constructor for class org.elasticsearch.action.admin.indices.stats.IndexStats
- IndexStats.IndexStatsBuilder - Class in org.elasticsearch.action.admin.indices.stats
- IndexStatsBuilder(String, String) - Constructor for class org.elasticsearch.action.admin.indices.stats.IndexStats.IndexStatsBuilder
- IndexStorePlugin - Interface in org.elasticsearch.plugins
-
A plugin that provides alternative directory implementations.
- IndexStorePlugin.DirectoryFactory - Interface in org.elasticsearch.plugins
-
An interface that describes how to create a new directory instance per shard.
- IndexStorePlugin.IndexFoldersDeletionListener - Interface in org.elasticsearch.plugins
-
IndexStorePlugin.IndexFoldersDeletionListener
are invoked before the folders of a shard or an index are deleted from disk. - IndexStorePlugin.RecoveryStateFactory - Interface in org.elasticsearch.plugins
-
An interface that allows to create a new
RecoveryState
per shard. - IndexStorePlugin.SnapshotCommitSupplier - Interface in org.elasticsearch.plugins
-
An interface that allows plugins to override the
IndexCommit
of which a snapshot is taken. - indexTemplate() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
- indexTemplate(ComposableIndexTemplate) - Method in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
-
The index template that will be inserted into the cluster state
- IndexTemplateMetadata - Class in org.elasticsearch.cluster.metadata
- IndexTemplateMetadata(String, int, Integer, List<String>, Settings, ImmutableOpenMap<String, CompressedXContent>, ImmutableOpenMap<String, AliasMetadata>) - Constructor for class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- IndexTemplateMetadata.Builder - Class in org.elasticsearch.cluster.metadata
- indexTemplateMetadataUpgraders - Variable in class org.elasticsearch.plugins.MetadataUpgrader
- IndexTemplateMissingException - Exception in org.elasticsearch.indices
- IndexTemplateMissingException(String) - Constructor for exception org.elasticsearch.indices.IndexTemplateMissingException
- IndexTemplateMissingException(StreamInput) - Constructor for exception org.elasticsearch.indices.IndexTemplateMissingException
- indexTemplateRequest(PutComposableIndexTemplateAction.Request) - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateRequest
- indexTemplateRequest(PutComposableIndexTemplateAction.Request) - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction.Request
- indexTemplates() - Method in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Response
- indexTemplates() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- indexTemplates(Map<String, ComposableIndexTemplate>) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- IndexThrottle() - Constructor for class org.elasticsearch.index.engine.Engine.IndexThrottle
- indexTranslogOperations(List<Translog.Operation>, int, long, long, RetentionLeases, long, ActionListener<Long>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- indexTranslogOperations(List<Translog.Operation>, int, long, long, RetentionLeases, long, ActionListener<Long>) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
Index a set of translog operations on the target
- indexTranslogOperations(List<Translog.Operation>, int, long, long, RetentionLeases, long, ActionListener<Long>) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- IndexUpgradeStatus - Class in org.elasticsearch.action.admin.indices.upgrade.get
- indexUUID - Variable in class org.elasticsearch.index.shard.ShardStateMetadata
- indexUUID() - Method in class org.elasticsearch.index.IndexService
- indexValue(DocumentParserContext, byte[]) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper
- indexVersionCreated() - Method in class org.elasticsearch.index.mapper.MappingParserContext
- indexVersionCreated() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- indexVersionCreated() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
- indexVersionCreated() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- IndexWarmer - Class in org.elasticsearch.index
- IndexWarmer.Listener - Interface in org.elasticsearch.index
- IndexWarmer.TerminationHandle - Interface in org.elasticsearch.index
-
A handle on the execution of warm-up action.
- indexWriterConfigWithNoMerging(Analyzer) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Prepares a new
IndexWriterConfig
that does not do any merges, by setting both the merge policy and the merge scheduler. - indices - Variable in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- indices() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- indices() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Get indices.
- indices() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
The indices
- indices() - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
- indices() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns a list of indices that should be included into the snapshot
- indices() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns list of indices that should be restored from snapshot
- indices() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- indices() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
-
The indices to be closed
- indices() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
-
The index to delete.
- indices() - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- indices() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The indices the mappings will be put.
- indices() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
The indices to be opened
- indices() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockRequest
-
Returns the indices to be blocked
- indices() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Request
- indices() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- indices() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
- indices() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- indices() - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- indices() - Method in class org.elasticsearch.action.datastreams.ModifyDataStreamsAction.Request
- indices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
The list of indices where this field name is defined as
type
, or null if all indices have the sametype
for the field. - indices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- indices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- indices() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- indices() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- indices() - Method in interface org.elasticsearch.action.IndicesRequest
-
Returns the array of indices that the action relates to
- indices() - Method in class org.elasticsearch.action.OriginalIndices
- indices() - Method in class org.elasticsearch.action.search.CanMatchNodeRequest
- indices() - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- indices() - Method in class org.elasticsearch.action.search.SearchRequest
-
The indices
- indices() - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- indices() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- indices() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- indices() - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- indices() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- indices() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- indices() - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
- indices() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- indices() - Method in interface org.elasticsearch.client.AdminClient
-
A client allowing to perform actions/operations against the indices.
- indices() - Method in class org.elasticsearch.cluster.ack.IndicesClusterStateUpdateRequest
-
Returns the indices the operation needs to be executed on
- indices() - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- indices() - Method in class org.elasticsearch.cluster.metadata.Metadata
- indices() - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
-
Returns list of indices
- indices() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- indices() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- indices() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- indices() - Method in class org.elasticsearch.repositories.ShardGenerations
-
Returns all indices for which shard generations are tracked.
- indices() - Method in class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- indices() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- indices() - Method in class org.elasticsearch.search.query.QuerySearchRequest
- indices() - Method in class org.elasticsearch.snapshots.RestoreInfo
-
List of restored indices
- indices() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns indices that were included in this snapshot.
- indices(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Should indices stats be returned.
- indices(String...) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
Sets the indices the search will be executed on.
- indices(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets a list of indices that should be included into the snapshot
- indices(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets the list of indices that should be restored from snapshot
- indices(String...) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
-
Sets the indices to be closed
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
Sets the indices this put mapping operation will execute on.
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
Sets the indices to be opened
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockRequest
-
Sets the indices to be blocked
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Request
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Sets the indices to apply to settings update to
- indices(String...) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
Sets the indices for the shard stores request
- indices(String...) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
-
The list of indices to lookup
- indices(String...) - Method in interface org.elasticsearch.action.IndicesRequest.Replaceable
-
Sets the indices that the action relates to.
- indices(String...) - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- indices(String...) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets the indices the search will be executed on.
- indices(String...) - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- indices(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- indices(String...) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- indices(String...) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- indices(List<String>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets a list of indices that should be included into the snapshot
- indices(List<String>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets the list of indices that should be restored from snapshot
- indices(CommonStatsFlags) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Set indices.
- indices(ClusterBlockLevel) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- indices(ImmutableOpenMap<String, IndexMetadata>) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- indices(Index[]) - Method in class org.elasticsearch.cluster.ack.IndicesClusterStateUpdateRequest
-
Sets the indices the operation needs to be executed on
- INDICES - Enum constant in enum class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest.Level
- INDICES - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
- INDICES - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.SortBy
- INDICES - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- INDICES - Enum constant in enum class org.elasticsearch.index.analysis.AnalyzerScope
- INDICES_ALL_ACTIVE - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
-
Re-balancing is allowed only once all shards on all indices are active.
- INDICES_BOOST_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- INDICES_CACHE_CLEAN_INTERVAL_SETTING - Static variable in class org.elasticsearch.indices.IndicesService
- INDICES_CACHE_QUERY_COUNT_SETTING - Static variable in class org.elasticsearch.indices.IndicesQueryCache
- INDICES_CACHE_QUERY_EXPIRE - Static variable in class org.elasticsearch.indices.IndicesRequestCache
- INDICES_CACHE_QUERY_SIZE - Static variable in class org.elasticsearch.indices.IndicesRequestCache
- INDICES_CACHE_QUERY_SIZE_SETTING - Static variable in class org.elasticsearch.indices.IndicesQueryCache
- INDICES_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- INDICES_FIELDDATA_CACHE_SIZE_KEY - Static variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
- INDICES_FOLDER - Static variable in class org.elasticsearch.env.NodeEnvironment
- INDICES_ID_FIELD_DATA_ENABLED_SETTING - Static variable in class org.elasticsearch.indices.IndicesService
- INDICES_MAPPING_DYNAMIC_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
- INDICES_MAX_CLAUSE_COUNT_SETTING - Static variable in class org.elasticsearch.search.SearchModule
- INDICES_MAX_IN_FLIGHT_UPDATES_SETTING - Static variable in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
- INDICES_MAX_NESTED_DEPTH_SETTING - Static variable in class org.elasticsearch.search.SearchModule
- INDICES_OPTIONS - Static variable in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- INDICES_OPTIONS - Static variable in class org.elasticsearch.action.support.single.shard.SingleShardRequest
- INDICES_PRIMARIES_ACTIVE - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
-
Re-balancing is allowed only once all primary shards on all indices are active.
- INDICES_QUERIES_CACHE_ALL_SEGMENTS_SETTING - Static variable in class org.elasticsearch.indices.IndicesQueryCache
- INDICES_RECOVERY_ACTIVITY_TIMEOUT_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
recoveries that don't show any activity for more then this interval will be failed.
- INDICES_RECOVERY_INTERNAL_ACTION_RETRY_TIMEOUT_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
timeout value to use for the retrying of requests made as part of the recovery process
- INDICES_RECOVERY_INTERNAL_ACTION_TIMEOUT_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
timeout value to use for requests made as part of the recovery process
- INDICES_RECOVERY_INTERNAL_LONG_ACTION_TIMEOUT_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
timeout value to use for requests made as part of the recovery process that are expected to take long time.
- INDICES_RECOVERY_MAX_BYTES_PER_SEC_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
- INDICES_RECOVERY_MAX_CONCURRENT_FILE_CHUNKS_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
Controls the maximum number of file chunk requests that can be sent concurrently from the source node to the target node.
- INDICES_RECOVERY_MAX_CONCURRENT_OPERATIONS_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
Controls the maximum number of operation chunk requests that can be sent concurrently from the source node to the target node.
- INDICES_RECOVERY_MAX_CONCURRENT_SNAPSHOT_FILE_DOWNLOADS - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
- INDICES_RECOVERY_MAX_CONCURRENT_SNAPSHOT_FILE_DOWNLOADS_PER_NODE - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
- INDICES_RECOVERY_RETRY_DELAY_NETWORK_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
how long to wait before retrying after network related issues
- INDICES_RECOVERY_RETRY_DELAY_STATE_SYNC_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
how long to wait before retrying after issues cause by cluster state syncing between nodes i.e., local node is not yet known on remote node, remote shard not yet started etc.
- INDICES_RECOVERY_USE_SNAPSHOTS_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
recoveries would try to use files from available snapshots instead of sending them from the source node.
- INDICES_SHARDS_CLOSED_TIMEOUT - Static variable in class org.elasticsearch.indices.IndicesService
- INDICES_STORE_DELETE_SHARD_TIMEOUT - Static variable in class org.elasticsearch.indices.store.IndicesStore
- IndicesAdminClient - Interface in org.elasticsearch.client
-
Administrative actions/operations against indices.
- indicesAliases(IndicesAliasesClusterStateUpdateRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexAliasesService
- IndicesAliasesAction - Class in org.elasticsearch.action.admin.indices.alias
- IndicesAliasesClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.alias
-
Cluster state update request that allows to add or remove aliases
- IndicesAliasesClusterStateUpdateRequest(List<AliasAction>) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesClusterStateUpdateRequest
- IndicesAliasesRequest - Class in org.elasticsearch.action.admin.indices.alias
-
A request to add/remove aliases for one or more indices.
- IndicesAliasesRequest() - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- IndicesAliasesRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- IndicesAliasesRequest.AliasActions - Class in org.elasticsearch.action.admin.indices.alias
-
Request to take one or more actions on one or more indexes and alias combinations.
- IndicesAliasesRequest.AliasActions.Type - Enum Class in org.elasticsearch.action.admin.indices.alias
- IndicesAliasesRequestBuilder - Class in org.elasticsearch.action.admin.indices.alias
-
Builder for request to modify many aliases at once.
- IndicesAliasesRequestBuilder(ElasticsearchClient, IndicesAliasesAction) - Constructor for class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
- indicesAliasesRequestValidators() - Method in interface org.elasticsearch.plugins.ActionPlugin
- indicesAllowReleaseResources(String[]) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
-
Returns
true
iff non of the given have aClusterBlockLevel.METADATA_WRITE
in place where theClusterBlock.isAllowReleaseResources()
returnsfalse
. - indicesBlockedException(ClusterBlockLevel, String[]) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- IndicesClusterStateService - Class in org.elasticsearch.indices.cluster
- IndicesClusterStateService(Settings, IndicesService, ClusterService, ThreadPool, PeerRecoveryTargetService, ShardStateAction, RepositoriesService, SearchService, SyncedFlushService, PeerRecoverySourceService, SnapshotShardsService, PrimaryReplicaSyncer, GlobalCheckpointSyncAction, RetentionLeaseSyncer) - Constructor for class org.elasticsearch.indices.cluster.IndicesClusterStateService
- IndicesClusterStateService.AllocatedIndex<T extends IndicesClusterStateService.Shard> - Interface in org.elasticsearch.indices.cluster
- IndicesClusterStateService.AllocatedIndices<T extends IndicesClusterStateService.Shard,
U extends IndicesClusterStateService.AllocatedIndex<T>> - Interface in org.elasticsearch.indices.cluster - IndicesClusterStateService.AllocatedIndices.IndexRemovalReason - Enum Class in org.elasticsearch.indices.cluster
- IndicesClusterStateService.Shard - Interface in org.elasticsearch.indices.cluster
- IndicesClusterStateUpdateRequest<T extends IndicesClusterStateUpdateRequest<T>> - Class in org.elasticsearch.cluster.ack
-
Base cluster state update request that allows to execute update against multiple indices
- IndicesClusterStateUpdateRequest() - Constructor for class org.elasticsearch.cluster.ack.IndicesClusterStateUpdateRequest
- indicesCreated() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns the indices created in this event
- indicesDeleted() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns the indices deleted in this event
- IndicesExistsAction - Class in org.elasticsearch.action.admin.indices.exists.indices
- indicesExistsRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates an indices exists request.
- IndicesExistsRequest - Class in org.elasticsearch.action.admin.indices.exists.indices
- IndicesExistsRequest() - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- IndicesExistsRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- IndicesExistsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- IndicesExistsRequestBuilder - Class in org.elasticsearch.action.admin.indices.exists.indices
- IndicesExistsRequestBuilder(ElasticsearchClient, IndicesExistsAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequestBuilder
- IndicesExistsResponse - Class in org.elasticsearch.action.admin.indices.exists.indices
- IndicesExistsResponse(boolean) - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsResponse
- IndicesFieldDataCache - Class in org.elasticsearch.indices.fielddata.cache
- IndicesFieldDataCache(Settings, IndexFieldDataCache.Listener) - Constructor for class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
- IndicesFieldDataCache.FieldDataWeigher - Class in org.elasticsearch.indices.fielddata.cache
- IndicesFieldDataCache.Key - Class in org.elasticsearch.indices.fielddata.cache
- indicesLevelRequest - Variable in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- indicesMigrationComplete(Map<String, Object>, ClusterService, Client, ActionListener<Boolean>) - Method in interface org.elasticsearch.indices.SystemIndices.Feature.MigrationCompletionHandler
- indicesMigrationComplete(Map<String, Object>, ClusterService, Client, ActionListener<Boolean>) - Method in interface org.elasticsearch.plugins.SystemIndexPlugin
-
A method used to signal that the system indices owned by this plugin have been upgraded and all restrictions (i.e.
- IndicesModule - Class in org.elasticsearch.indices
-
Configures classes and services that are shared by indices on each node.
- IndicesModule(List<MapperPlugin>) - Constructor for class org.elasticsearch.indices.IndicesModule
- indicesOptions() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Specifies the indices options.
- indicesOptions() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Specifies what type of requested indices to ignore and how to deal with wildcard expressions.
- indicesOptions() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
-
Specifies what type of requested indices to ignore and how to deal with wildcard expressions.
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
Specifies what type of requested indices to ignore and how to deal with wildcard expressions.
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockRequest
-
Specifies what type of requested indices to ignore and how to deal with wildcard expressions.
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Request
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
- indicesOptions() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- indicesOptions() - Method in class org.elasticsearch.action.datastreams.ModifyDataStreamsAction.Request
- indicesOptions() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the options for this request
- indicesOptions() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- indicesOptions() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- indicesOptions() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- indicesOptions() - Method in class org.elasticsearch.action.index.IndexRequest
- indicesOptions() - Method in interface org.elasticsearch.action.IndicesRequest
-
Returns the indices options used to resolve indices.
- indicesOptions() - Method in class org.elasticsearch.action.OriginalIndices
- indicesOptions() - Method in class org.elasticsearch.action.search.CanMatchNodeRequest
- indicesOptions() - Method in class org.elasticsearch.action.search.MultiSearchRequest
- indicesOptions() - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- indicesOptions() - Method in class org.elasticsearch.action.search.SearchRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- indicesOptions() - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
- indicesOptions() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- indicesOptions() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- indicesOptions() - Method in class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- indicesOptions() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- indicesOptions() - Method in class org.elasticsearch.search.query.QuerySearchRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Specifies the indices options.
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Specifies what type of requested indices to ignore and how to deal with wildcard expressions.
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
-
Specifies what type of requested indices to ignore and how to deal wild wildcard expressions.
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
Specifies what type of requested indices to ignore and how to deal with wildcard expressions.
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockRequest
-
Specifies what type of requested indices to ignore and how to deal wild wildcard expressions.
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
Specifies what type of requested indices to ignore and wildcard indices expressions By default, expands wildcards to both open and closed indices
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.search.MultiSearchRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.search.SearchRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- indicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- IndicesOptions - Class in org.elasticsearch.action.support
-
Controls how to deal with unavailable concrete indices (closed or missing), how wildcard expressions are expanded to actual indices (all, closed or open indices) and how to deal with wildcard expressions that resolve to no indices.
- IndicesOptions(EnumSet<IndicesOptions.Option>, EnumSet<IndicesOptions.WildcardStates>) - Constructor for class org.elasticsearch.action.support.IndicesOptions
- IndicesOptions.Option - Enum Class in org.elasticsearch.action.support
- IndicesOptions.WildcardStates - Enum Class in org.elasticsearch.action.support
- indicesPath - Variable in class org.elasticsearch.env.NodeEnvironment.DataPath
- IndicesQueryCache - Class in org.elasticsearch.indices
- IndicesQueryCache(Settings) - Constructor for class org.elasticsearch.indices.IndicesQueryCache
- IndicesRequest - Interface in org.elasticsearch.action
-
Needs to be implemented by all
ActionRequest
subclasses that relate to one or more indices. - IndicesRequest.Replaceable - Interface in org.elasticsearch.action
- IndicesRequestCache - Class in org.elasticsearch.indices
-
The indices request cache allows to cache a shard level request stage responses, helping with improving similar requests that are potentially expensive (because of aggs for example).
- indicesRouting() - Method in class org.elasticsearch.cluster.routing.RoutingTable
- IndicesSegmentResponse - Class in org.elasticsearch.action.admin.indices.segments
- IndicesSegmentsAction - Class in org.elasticsearch.action.admin.indices.segments
- indicesSegmentsRequest(String...) - Static method in class org.elasticsearch.client.Requests
- IndicesSegmentsRequest - Class in org.elasticsearch.action.admin.indices.segments
- IndicesSegmentsRequest() - Constructor for class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
- IndicesSegmentsRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
- IndicesSegmentsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
- IndicesSegmentsRequestBuilder - Class in org.elasticsearch.action.admin.indices.segments
- IndicesSegmentsRequestBuilder(ElasticsearchClient, IndicesSegmentsAction) - Constructor for class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequestBuilder
- indicesService - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- IndicesService - Class in org.elasticsearch.indices
- IndicesService(Settings, PluginsService, NodeEnvironment, NamedXContentRegistry, AnalysisRegistry, IndexNameExpressionResolver, MapperRegistry, NamedWriteableRegistry, ThreadPool, IndexScopedSettings, CircuitBreakerService, BigArrays, ScriptService, ClusterService, Client, MetaStateService, Collection<Function<IndexSettings, Optional<EngineFactory>>>, Map<String, IndexStorePlugin.DirectoryFactory>, ValuesSourceRegistry, Map<String, IndexStorePlugin.RecoveryStateFactory>, List<IndexStorePlugin.IndexFoldersDeletionListener>, Map<String, IndexStorePlugin.SnapshotCommitSupplier>, CheckedBiConsumer<ShardSearchRequest, StreamOutput, IOException>) - Constructor for class org.elasticsearch.indices.IndicesService
- IndicesService.ShardDeletionCheckResult - Enum Class in org.elasticsearch.indices
-
result type returned by
signaling different reasons why a shard can / cannot be deleted
- IndicesShardStoreRequestBuilder - Class in org.elasticsearch.action.admin.indices.shards
-
Request builder for
IndicesShardStoresRequest
- IndicesShardStoreRequestBuilder(ElasticsearchClient, ActionType<IndicesShardStoresResponse>, String...) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoreRequestBuilder
- IndicesShardStoresAction - Class in org.elasticsearch.action.admin.indices.shards
-
ActionType for
TransportIndicesShardStoresAction
Exposes shard store information for requested indices. - indicesShardStoresRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates an indices shard stores info request.
- IndicesShardStoresRequest - Class in org.elasticsearch.action.admin.indices.shards
-
Request for
IndicesShardStoresAction
- IndicesShardStoresRequest() - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- IndicesShardStoresRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
Create a request for shard stores info for
indices
- IndicesShardStoresRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- IndicesShardStoresResponse - Class in org.elasticsearch.action.admin.indices.shards
-
Response for
IndicesShardStoresAction
Consists ofIndicesShardStoresResponse.StoreStatus
s for requested indices grouped by indices and shard ids and a list of encountered nodeIndicesShardStoresResponse.Failure
s - IndicesShardStoresResponse(ImmutableOpenMap<String, ImmutableOpenIntMap<List<IndicesShardStoresResponse.StoreStatus>>>, List<IndicesShardStoresResponse.Failure>) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
- IndicesShardStoresResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
- IndicesShardStoresResponse.Failure - Exception in org.elasticsearch.action.admin.indices.shards
-
Single node failure while retrieving shard store information
- IndicesShardStoresResponse.StoreStatus - Class in org.elasticsearch.action.admin.indices.shards
-
Shard store information from a node
- IndicesShardStoresResponse.StoreStatus.AllocationStatus - Enum Class in org.elasticsearch.action.admin.indices.shards
-
The status of the shard store with respect to the cluster
- IndicesStatsAction - Class in org.elasticsearch.action.admin.indices.stats
- IndicesStatsRequest - Class in org.elasticsearch.action.admin.indices.stats
-
A request to get indices level stats.
- IndicesStatsRequest() - Constructor for class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- IndicesStatsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- IndicesStatsRequestBuilder - Class in org.elasticsearch.action.admin.indices.stats
-
A request to get indices level stats.
- IndicesStatsRequestBuilder(ElasticsearchClient, IndicesStatsAction) - Constructor for class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- IndicesStatsResponse - Class in org.elasticsearch.action.admin.indices.stats
- IndicesStore - Class in org.elasticsearch.indices.store
- IndicesStore(Settings, IndicesService, ClusterService, TransportService, ThreadPool) - Constructor for class org.elasticsearch.indices.store.IndicesStore
- indicesToUpdateAfterRemovingSnapshot(Collection<SnapshotId>) - Method in class org.elasticsearch.repositories.RepositoryData
-
Returns the list of
IndexId
that have their snapshots updated but not removed (because they are still referenced by other snapshots) after removing the given snapshot from the repository. - InetAddresses - Class in org.elasticsearch.common.network
- InetAddresses() - Constructor for class org.elasticsearch.common.network.InetAddresses
- infer(boolean, boolean) - Static method in enum class org.elasticsearch.index.query.GeoValidationMethod
-
Returns validation method corresponding to given coerce and ignoreMalformed values.
- InFlightOpsRequest(StreamInput) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.InFlightOpsRequest
- InFlightOpsRequest(ShardId) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.InFlightOpsRequest
- InFlightShardSnapshotStates - Class in org.elasticsearch.snapshots
-
Holds information about currently in-flight shard level snapshot or clone operations on a per-shard level.
- info - Variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptLanguageResponse
- info() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- info() - Method in interface org.elasticsearch.http.HttpServerTransport
- info() - Method in class org.elasticsearch.ingest.IngestService
- info() - Method in class org.elasticsearch.monitor.jvm.JvmService
- info() - Method in class org.elasticsearch.monitor.os.OsService
- info() - Method in class org.elasticsearch.monitor.process.ProcessService
- info() - Method in interface org.elasticsearch.node.ReportingService
- info() - Method in class org.elasticsearch.plugins.PluginsService
-
Get information about plugins and modules
- info() - Method in class org.elasticsearch.search.aggregations.support.AggregationUsageService
- info() - Method in class org.elasticsearch.threadpool.ThreadPool
- info() - Method in class org.elasticsearch.transport.TransportService
- info(boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class org.elasticsearch.node.NodeService
- info(String) - Method in class org.elasticsearch.threadpool.ThreadPool
- Info(String, ThreadPool.ThreadPoolType) - Constructor for class org.elasticsearch.threadpool.ThreadPool.Info
- Info(String, ThreadPool.ThreadPoolType, int) - Constructor for class org.elasticsearch.threadpool.ThreadPool.Info
- Info(String, ThreadPool.ThreadPoolType, int, int, TimeValue, SizeValue) - Constructor for class org.elasticsearch.threadpool.ThreadPool.Info
- Info(StreamInput) - Constructor for class org.elasticsearch.threadpool.ThreadPool.Info
- INFO - Enum constant in enum class org.elasticsearch.index.SlowLogLevel
- inGap(long, LocalTimeOffset.Gap) - Method in interface org.elasticsearch.common.LocalTimeOffset.Strategy
-
Handle a local time that never actually happened because a "gap" jumped over it.
- INGEST - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
- INGEST - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- INGEST_CONTEXT - Static variable in class org.elasticsearch.script.TemplateScript
- INGEST_KEY - Static variable in class org.elasticsearch.ingest.IngestDocument
- INGEST_ORIGIN - Static variable in class org.elasticsearch.ingest.IngestService
- INGEST_ROLE - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
Represents the role for an ingest node.
- IngestActionForwarder - Class in org.elasticsearch.action.ingest
-
A utility for forwarding ingest requests to ingest nodes in a round-robin fashion.
- IngestActionForwarder(TransportService) - Constructor for class org.elasticsearch.action.ingest.IngestActionForwarder
- IngestConditionalScript - Class in org.elasticsearch.script
-
A script used by
ConditionalProcessor
. - IngestConditionalScript(Map<String, Object>) - Constructor for class org.elasticsearch.script.IngestConditionalScript
- IngestConditionalScript.Factory - Interface in org.elasticsearch.script
- IngestDocument - Class in org.elasticsearch.ingest
-
Represents a single document being captured before indexing and holds the source and metadata (like id, type and index).
- IngestDocument(String, String, String, String, Long, VersionType, Map<String, Object>) - Constructor for class org.elasticsearch.ingest.IngestDocument
- IngestDocument(Map<String, Object>, Map<String, Object>) - Constructor for class org.elasticsearch.ingest.IngestDocument
-
Constructor needed for testing that allows to create a new
IngestDocument
given the provided elasticsearch metadata, source and ingest metadata. - IngestDocument(IngestDocument) - Constructor for class org.elasticsearch.ingest.IngestDocument
-
Copy constructor that creates a new
IngestDocument
which has exactly the same properties as the one provided as argument - IngestDocument.Metadata - Enum Class in org.elasticsearch.ingest
- IngestInfo - Class in org.elasticsearch.ingest
- IngestInfo(List<ProcessorInfo>) - Constructor for class org.elasticsearch.ingest.IngestInfo
- IngestInfo(StreamInput) - Constructor for class org.elasticsearch.ingest.IngestInfo
-
Read from a stream.
- IngestMetadata - Class in org.elasticsearch.ingest
-
Holds the ingest pipelines that are available in the cluster
- IngestMetadata(Map<String, PipelineConfiguration>) - Constructor for class org.elasticsearch.ingest.IngestMetadata
- IngestMetadata(StreamInput) - Constructor for class org.elasticsearch.ingest.IngestMetadata
- IngestPlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
implementations to add custom ingest processors - IngestProcessorException - Exception in org.elasticsearch.ingest
-
A dedicated wrapper for exceptions encountered executing an ingest processor.
- IngestProcessorException(StreamInput) - Constructor for exception org.elasticsearch.ingest.IngestProcessorException
- IngestScript - Class in org.elasticsearch.script
-
A script used by the Ingest Script Processor.
- IngestScript(Map<String, Object>) - Constructor for class org.elasticsearch.script.IngestScript
- IngestScript.Factory - Interface in org.elasticsearch.script
- ingestService - Variable in class org.elasticsearch.ingest.Processor.Parameters
- IngestService - Class in org.elasticsearch.ingest
-
Holder class for several ingest related services.
- IngestService(ClusterService, ThreadPool, Environment, ScriptService, AnalysisRegistry, List<IngestPlugin>, Client) - Constructor for class org.elasticsearch.ingest.IngestService
- IngestStats - Class in org.elasticsearch.ingest
- IngestStats(StreamInput) - Constructor for class org.elasticsearch.ingest.IngestStats
-
Read from a stream.
- IngestStats(IngestStats.Stats, List<IngestStats.PipelineStat>, Map<String, List<IngestStats.ProcessorStat>>) - Constructor for class org.elasticsearch.ingest.IngestStats
- IngestStats.PipelineStat - Class in org.elasticsearch.ingest
-
Container for pipeline stats.
- IngestStats.ProcessorStat - Class in org.elasticsearch.ingest
-
Container for processor stats.
- IngestStats.Stats - Class in org.elasticsearch.ingest
- inHeapMode(long) - Method in class org.elasticsearch.search.sort.BucketedSort
-
Is this bucket a min heap
true
or in gathering modefalse
? - init() - Static method in class org.elasticsearch.bootstrap.BootstrapInfo
- init() - Static method in class org.elasticsearch.common.filesystem.FileSystemNatives
- init() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
- init() - Method in interface org.elasticsearch.watcher.ResourceWatcher
-
Called once when the resource watcher is added to
ResourceWatcherService
- init(FieldMapper) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
Initialises all parameters from an existing mapper
- init(PersistentTasksService, TaskManager, String, long) - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- INIT - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Snapshot hasn't started yet
- INIT - Enum constant in enum class org.elasticsearch.cluster.RestoreInProgress.State
-
Initializing state
- INIT - Enum constant in enum class org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- INIT - Enum constant in enum class org.elasticsearch.cluster.SnapshotsInProgress.State
- INIT - Enum constant in enum class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Snapshot hasn't started yet
- INIT - Enum constant in enum class org.elasticsearch.indices.recovery.RecoveryState.Stage
- initCounter() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- initGatherOffsets() - Method in class org.elasticsearch.search.sort.BucketedSort
-
Initialize the gather offsets after setting up values.
- INITIAL_ASSIGNMENT - Static variable in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- INITIAL_MASTER_NODES_SETTING - Static variable in class org.elasticsearch.cluster.coordination.ClusterBootstrapService
- INITIAL_STATE_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.DiscoverySettings
- initialize() - Method in class org.elasticsearch.common.inject.multibindings.MapBinder.RealMapBinder.MapBinderProviderWithDependencies
- initialize(String, String, long) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Initializes an unassigned shard on a node.
- initialize(String, String, long, RoutingChangesObserver) - Method in interface org.elasticsearch.cluster.routing.allocation.ExistingShardsAllocator.UnassignedAllocationHandler
-
Initializes the current unassigned shard and moves it from the unassigned list.
- initialize(String, String, long, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
-
Initializes the current unassigned shard and moves it from the unassigned list.
- initialize(Map<ActionType<? extends ActionResponse>, TransportAction<? extends ActionRequest, ? extends ActionResponse>>, Supplier<String>, RemoteClusterService, NamedWriteableRegistry) - Method in class org.elasticsearch.client.node.NodeClient
- initialize(Injector) - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
-
Invoked by Guice at Injector-creation time to prepare providers for each element in this set.
- initialize(Settings) - Static method in class org.elasticsearch.common.logging.DeprecationLogger
-
The DeprecationLogger uses the "deprecation.skip_deprecated_settings" setting to decide whether to log a deprecation for a setting.
- INITIALIZE - Enum constant in enum class org.elasticsearch.search.profile.aggregation.AggregationTimingType
- initializeAsFromCloseToOpen(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Initializes a new empty index, as as a result of opening a closed index.
- initializeAsFromDangling(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Initializes a new index caused by dangling index imported.
- initializeAsFromOpenToClose(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Initializes a new empty index, as as a result of closing an opened index.
- initializeAsNew(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Initializes a new empty index, as if it was created from an API.
- initializeAsNewRestore(IndexMetadata, RecoverySource.SnapshotRecoverySource, IntSet) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Initializes a new empty index, to be restored from a snapshot
- initializeAsRecovery(IndexMetadata) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Initializes an existing index.
- initializeAsRestore(IndexMetadata, RecoverySource.SnapshotRecoverySource) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
-
Initializes an existing index, to be restored from a snapshot
- initialized() - Method in class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazyBits
- initialized() - Method in class org.elasticsearch.common.component.Lifecycle
-
Returns
true
if the state is initialized. - INITIALIZED - Enum constant in enum class org.elasticsearch.common.component.Lifecycle.State
- initializeDelegate(MembersInjector<T>) - Method in class org.elasticsearch.common.inject.spi.MembersInjectorLookup
-
Sets the actual members injector.
- initializeDelegate(Provider<T>) - Method in class org.elasticsearch.common.inject.spi.ProviderLookup
-
Sets the actual provider.
- initializedReplicaReinitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- initializedReplicaReinitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- initializedReplicaReinitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- initializedReplicaReinitialized(ShardRouting, ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when an initializing replica is reinitialized.
- initializerNotSupported() - Static method in interface org.elasticsearch.index.mapper.RuntimeField
- initializeRuntimeMonitoring() - Static method in class org.elasticsearch.monitor.jvm.HotThreads
- initializeShard(ShardRouting, String, String, long, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Moves a shard from unassigned to initialize state
- initializeSnapshot(SnapshotId, List<IndexId>, Metadata) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- initializeSnapshot(SnapshotId, List<IndexId>, Metadata) - Method in class org.elasticsearch.repositories.FilterRepository
- initializeSnapshot(SnapshotId, List<IndexId>, Metadata) - Method in interface org.elasticsearch.repositories.Repository
-
Deprecated.this method is only used when taking snapshots in a mixed version cluster where a master node older than
SnapshotsService.NO_REPO_INITIALIZE_VERSION
is present. - initializeUnassignedShard(RoutingAllocation, RoutingNodes, RoutingNode, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Initializes an unassigned shard on a node and removes it from the unassigned
- initializeUnassignedShard(RoutingAllocation, RoutingNodes, RoutingNode, ShardRouting, UnassignedInfo, RecoverySource) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Initializes an unassigned shard on a node and removes it from the unassigned
- initializing() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard is initializing (usually recovering either from peer shard or from gateway).
- INITIALIZING - Enum constant in enum class org.elasticsearch.cluster.routing.ShardRoutingState
-
The shard is initializing (probably recovering from either a peer shard or gateway).
- initiateChannel(DiscoveryNode) - Method in class org.elasticsearch.transport.TcpTransport
-
Initiate a single tcp socket channel.
- initiateTracking(String) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Called when the recovery process for a shard has opened the engine on the target shard.
- initiateTracking(String) - Method in class org.elasticsearch.index.shard.IndexShard
-
Called when the recovery process for a shard has opened the engine on the target shard.
- initInjector(Injector) - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- initReader(String, Reader) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- initReader(String, Reader) - Method in class org.elasticsearch.index.analysis.ReloadableCustomAnalyzer
- initReaderForNormalization(String, Reader) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- initReaderForNormalization(String, Reader) - Method in class org.elasticsearch.index.analysis.ReloadableCustomAnalyzer
- initRestHandlers(Supplier<DiscoveryNodes>) - Method in class org.elasticsearch.action.ActionModule
- initScheduler(Settings, String) - Static method in interface org.elasticsearch.threadpool.Scheduler
-
Create a scheduler that can be used client side.
- initScript() - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
-
Get the
init
script. - initScript(Script) - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
-
Set the
init
script. - InitScript(Map<String, Object>, Map<String, Object>) - Constructor for class org.elasticsearch.script.ScriptedMetricAggContexts.InitScript
- Inject - Annotation Interface in org.elasticsearch.common.inject
-
Annotates members of your implementation class (constructors, methods and fields) into which the
Injector
should inject values. - InjectionListener<I> - Interface in org.elasticsearch.common.inject.spi
-
Listens for injections into instances of type
I
. - InjectionPoint - Class in org.elasticsearch.common.inject.spi
-
A constructor, field or method that can receive injections.
- InjectionRequest<T> - Class in org.elasticsearch.common.inject.spi
-
A request to inject the instance fields and methods of an instance.
- InjectionRequest(Object, TypeLiteral<T>, T) - Constructor for class org.elasticsearch.common.inject.spi.InjectionRequest
- injectMembers(Object) - Method in interface org.elasticsearch.common.inject.Injector
-
Injects dependencies into the fields and methods of
instance
. - injectMembers(T) - Method in interface org.elasticsearch.common.inject.MembersInjector
-
Injects dependencies into the fields and methods of
instance
. - injector() - Method in class org.elasticsearch.node.Node
- Injector - Interface in org.elasticsearch.common.inject
-
Builds the graphs of objects that make up your application.
- INLINE - Enum constant in enum class org.elasticsearch.script.ScriptType
-
INLINE scripts are specified in numerous queries and compiled on-the-fly.
- InMemoryPersistedState - Class in org.elasticsearch.cluster.coordination
- InMemoryPersistedState(long, ClusterState) - Constructor for class org.elasticsearch.cluster.coordination.InMemoryPersistedState
- INNER_HITS_FIELD - Static variable in class org.elasticsearch.search.collapse.CollapseBuilder
- innerAllocatedUnassigned(RoutingAllocation, PrimaryShardAllocator, ReplicaShardAllocator, ShardRouting, ExistingShardsAllocator.UnassignedAllocationHandler) - Static method in class org.elasticsearch.gateway.GatewayAllocator
- innerBuild(AggregationContext, Map<String, ValuesSourceConfig>, Map<String, QueryBuilder>, DocValueFormat, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- innerBuild(AggregationContext, Map<String, ValuesSourceConfig>, Map<String, QueryBuilder>, DocValueFormat, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.PercentileRanksAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- innerBuild(AggregationContext, ValuesSourceConfig, AggregatorFactory, AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- innerBuild(ValuesSourceRegistry, ValuesSourceConfig) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Actually build the values source and its associated configuration.
- innerBuild(ValuesSourceRegistry, ValuesSourceConfig) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- innerBuild(ValuesSourceRegistry, ValuesSourceConfig) - Method in class org.elasticsearch.search.aggregations.bucket.composite.GeoTileGridValuesSourceBuilder
- innerBuild(ValuesSourceRegistry, ValuesSourceConfig) - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- innerBuild(ValuesSourceRegistry, ValuesSourceConfig) - Method in class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- innerBuildContext(int, SearchExecutionContext) - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- innerBuildContext(int, SearchExecutionContext) - Method in class org.elasticsearch.search.rescore.RescorerBuilder
-
Extensions override this to build the context that they need for rescoring.
- innerDocs(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
-
Get a
DocIdSet
that matches the inner documents. - innerExecute(String, CompletionSuggestionContext, IndexSearcher, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggester
- innerExecute(String, PhraseSuggestionContext, IndexSearcher, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggester
- innerExecute(String, TermSuggestionContext, IndexSearcher, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.term.TermSuggester
- innerExecute(String, T, IndexSearcher, CharsRefBuilder) - Method in class org.elasticsearch.search.suggest.Suggester
- innerFromXContent(XContentParser) - Static method in class org.elasticsearch.action.search.SearchResponse
- innerFromXContent(XContentParser) - Static method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- innerFromXContent(XContentParser, boolean) - Static method in exception org.elasticsearch.ElasticsearchException
- innerFromXContent(XContentParser, String) - Static method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- innerGetRaw(Settings) - Method in class org.elasticsearch.common.settings.Setting.AffixSetting
- innerHit() - Method in class org.elasticsearch.index.query.NestedQueryBuilder
-
Returns inner hit definition in the scope of this query and reusing the defined type and query.
- innerHit(InnerHitBuilder) - Method in class org.elasticsearch.index.query.NestedQueryBuilder
- innerHitBuilder - Variable in class org.elasticsearch.index.query.InnerHitContextBuilder
- innerHitBuilder() - Method in class org.elasticsearch.index.query.InnerHitContextBuilder
- InnerHitBuilder - Class in org.elasticsearch.index.query
- InnerHitBuilder() - Constructor for class org.elasticsearch.index.query.InnerHitBuilder
- InnerHitBuilder(String) - Constructor for class org.elasticsearch.index.query.InnerHitBuilder
- InnerHitBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.InnerHitBuilder
-
Read from a stream.
- InnerHitContextBuilder - Class in org.elasticsearch.index.query
-
A builder for
InnerHitsContext.InnerHitSubContext
- InnerHitContextBuilder(QueryBuilder, InnerHitBuilder, Map<String, InnerHitContextBuilder>) - Constructor for class org.elasticsearch.index.query.InnerHitContextBuilder
- innerHits() - Method in class org.elasticsearch.search.fetch.FetchContext
-
Configuration for returning inner hits
- innerHits() - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- innerHits() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- innerHits() - Method in class org.elasticsearch.search.internal.SearchContext
- InnerHitsContext - Class in org.elasticsearch.search.fetch.subphase
-
Context used for inner hits retrieval
- InnerHitsContext() - Constructor for class org.elasticsearch.search.fetch.subphase.InnerHitsContext
- InnerHitsContext.InnerHitSubContext - Class in org.elasticsearch.search.fetch.subphase
- InnerHitsPhase - Class in org.elasticsearch.search.fetch.subphase
- InnerHitsPhase(FetchPhase) - Constructor for class org.elasticsearch.search.fetch.subphase.InnerHitsPhase
- InnerHitSubContext(String, SearchContext) - Constructor for class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- innerOnFailure(Exception) - Method in class org.elasticsearch.action.NotifyOnceListener
- innerOnFailure(Exception) - Method in class org.elasticsearch.action.StepListener
- innerOnResponse(Response) - Method in class org.elasticsearch.action.NotifyOnceListener
- innerOnResponse(Response) - Method in class org.elasticsearch.action.StepListener
- innerPut(PutPipelineRequest, ClusterState) - Static method in class org.elasticsearch.ingest.IngestService
- innerQueries() - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- innerQuery() - Method in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- innerQuery() - Method in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- innerQuery() - Method in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- innerQuery() - Method in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- innerToString(StringBuilder) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult.Failure
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult.Failure
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.Failure
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.DocWriteResponse
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.SearchResponse
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.support.DefaultShardOperationFailedException
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.update.UpdateResponse
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.Laplace
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.SmoothingModel
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
- innerToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.tasks.TaskResult
- innerToXContent(XContentBuilder, ToXContent.Params, Throwable, String, String, Map<String, List<String>>, Map<String, List<String>>, Throwable) - Static method in exception org.elasticsearch.ElasticsearchException
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.common.Rounding
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.GeoTileGridValuesSourceBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregator
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregator
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.MaxBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.MinBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregator
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.StatsBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.SumBucketPipelineAggregationBuilder
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
-
Write subclass' state to the stream
- innerWriteTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Write subclass's state to the stream.
- innerWriteTo(StreamOutput, boolean) - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- innerXContent(XContentBuilder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- innerXContent(XContentBuilder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
- innerXContent(XContentBuilder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- innerXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
We need to write a manual parser for this because of
BulkByScrollTask.StatusOrException
. - inOrder() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- inOrder(boolean) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
-
When
inOrder
is true, the spans from each clause must be in the same order as inclauses
and must be non-overlapping. - inOverlap(long, LocalTimeOffset.Overlap) - Method in interface org.elasticsearch.common.LocalTimeOffset.Strategy
-
Handle a local time that happened twice because an "overlap" jumped behind it.
- inPackage(Package) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches classes in the given package.
- inProgress(SnapshotsInProgress.Entry) - Static method in class org.elasticsearch.snapshots.SnapshotInfo
- inputStream(InputStream, boolean) - Static method in class org.elasticsearch.common.compress.DeflateCompressor
-
Creates a new input stream that decompresses the contents read from the provided input stream.
- InputStreamIndexInput - Class in org.elasticsearch.common.lucene.store
- InputStreamIndexInput(IndexInput, long) - Constructor for class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- InputStreamStreamInput - Class in org.elasticsearch.common.io.stream
- InputStreamStreamInput(InputStream) - Constructor for class org.elasticsearch.common.io.stream.InputStreamStreamInput
-
Creates a new InputStreamStreamInput with unlimited size
- InputStreamStreamInput(InputStream, long) - Constructor for class org.elasticsearch.common.io.stream.InputStreamStreamInput
-
Creates a new InputStreamStreamInput with a size limit
- inQuotes(Object) - Static method in class org.elasticsearch.common.logging.ESLogMessage
- inQuotes(String) - Static method in class org.elasticsearch.common.logging.ESLogMessage
- insecureString(String) - Static method in class org.elasticsearch.common.settings.SecureSetting
-
A setting which contains a sensitive string, but which for legacy reasons must be found outside secure settings.
- insert(String, T) - Method in class org.elasticsearch.common.path.PathTrie
- INSERT_ZEROS - Enum constant in enum class org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
- insertElement(T[], T, int) - Static method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
- insertionOrder - Variable in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.Pending
- insertOrUpdate(String, T, BiFunction<T, T, T>) - Method in class org.elasticsearch.common.path.PathTrie
-
Insert a value for the given path.
- install(Module) - Method in class org.elasticsearch.common.inject.AbstractModule
- install(Module) - Method in interface org.elasticsearch.common.inject.Binder
-
Uses the given module to configure more bindings.
- install(Module) - Method in class org.elasticsearch.common.inject.PrivateModule
- instance() - Static method in class org.elasticsearch.tasks.LoggingTaskListener
-
Get the instance of NoopActionListener cast appropriately.
- Instance(T) - Constructor for class org.elasticsearch.common.inject.internal.InternalFactory.Instance
- INSTANCE - Static variable in class org.elasticsearch.action.ActionResponse.Empty
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.health.ClusterHealthAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.features.SnapshottableFeaturesAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.state.ClusterStateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptContextAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptLanguageAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.close.CloseIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.create.AutoCreateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.create.CreateIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.dangling.delete.DeleteDanglingIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.dangling.find.FindDanglingIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.dangling.import_index.ImportDanglingIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.delete.DeleteIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.diskusage.AnalyzeIndexDiskUsageAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.flush.FlushAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.flush.SyncedFlushAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.get.GetIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.mapping.put.AutoPutMappingAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.open.OpenIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.recovery.RecoveryAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.refresh.RefreshAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.rollover.RolloverAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.shrink.ResizeAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.shrink.ShrinkAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.stats.IndicesStatsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.delete.DeleteComponentTemplateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.delete.DeleteComposableIndexTemplateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsAction
- INSTANCE - Static variable in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryAction
- INSTANCE - Static variable in class org.elasticsearch.action.bulk.BulkAction
- INSTANCE - Static variable in class org.elasticsearch.action.datastreams.ModifyDataStreamsAction
- INSTANCE - Static variable in class org.elasticsearch.action.delete.DeleteAction
- INSTANCE - Static variable in class org.elasticsearch.action.explain.ExplainAction
- INSTANCE - Static variable in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesAction
- INSTANCE - Static variable in class org.elasticsearch.action.get.GetAction
- INSTANCE - Static variable in class org.elasticsearch.action.get.MultiGetAction
- INSTANCE - Static variable in class org.elasticsearch.action.index.IndexAction
- INSTANCE - Static variable in class org.elasticsearch.action.ingest.DeletePipelineAction
- INSTANCE - Static variable in class org.elasticsearch.action.ingest.GetPipelineAction
- INSTANCE - Static variable in class org.elasticsearch.action.ingest.PutPipelineAction
- INSTANCE - Static variable in class org.elasticsearch.action.ingest.SimulatePipelineAction
- INSTANCE - Static variable in class org.elasticsearch.action.main.MainAction
- INSTANCE - Static variable in class org.elasticsearch.action.search.ClearScrollAction
- INSTANCE - Static variable in class org.elasticsearch.action.search.ClosePointInTimeAction
- INSTANCE - Static variable in class org.elasticsearch.action.search.MultiSearchAction
- INSTANCE - Static variable in class org.elasticsearch.action.search.OpenPointInTimeAction
- INSTANCE - Static variable in class org.elasticsearch.action.search.SearchAction
- INSTANCE - Static variable in class org.elasticsearch.action.search.SearchScrollAction
- INSTANCE - Static variable in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.EmptyResult
- INSTANCE - Static variable in class org.elasticsearch.action.termvectors.MultiTermVectorsAction
- INSTANCE - Static variable in class org.elasticsearch.action.termvectors.TermVectorsAction
- INSTANCE - Static variable in class org.elasticsearch.action.update.UpdateAction
- INSTANCE - Static variable in class org.elasticsearch.cluster.EmptyClusterInfoService
- INSTANCE - Static variable in class org.elasticsearch.cluster.routing.RecoverySource.EmptyStoreRecoverySource
- INSTANCE - Static variable in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- INSTANCE - Static variable in class org.elasticsearch.cluster.routing.RecoverySource.LocalShardsRecoverySource
- INSTANCE - Static variable in class org.elasticsearch.cluster.routing.RecoverySource.PeerRecoverySource
- INSTANCE - Static variable in class org.elasticsearch.common.xcontent.LoggingDeprecationHandler
- INSTANCE - Static variable in class org.elasticsearch.index.mapper.DocCountFieldMapper.DocCountFieldType
- INSTANCE - Static variable in class org.elasticsearch.index.mapper.IgnoredFieldMapper.IgnoredFieldType
- INSTANCE - Static variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- INSTANCE - Static variable in class org.elasticsearch.index.mapper.VersionFieldMapper
- INSTANCE - Static variable in class org.elasticsearch.index.reindex.DeleteByQueryAction
- INSTANCE - Static variable in class org.elasticsearch.index.reindex.ReindexAction
- INSTANCE - Static variable in class org.elasticsearch.index.reindex.UpdateByQueryAction
- INSTANCE - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Add
- INSTANCE - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove
- INSTANCE - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions.Renew
- INSTANCE - Static variable in class org.elasticsearch.indices.recovery.plan.PeerOnlyRecoveryPlannerService
- INSTANCE - Static variable in class org.elasticsearch.monitor.jvm.SunThreadInfo
- INSTANCE - Static variable in class org.elasticsearch.persistent.CompletionPersistentTaskAction
- INSTANCE - Static variable in class org.elasticsearch.persistent.RemovePersistentTaskAction
- INSTANCE - Static variable in class org.elasticsearch.persistent.StartPersistentTaskAction
- INSTANCE - Static variable in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction
- INSTANCE - Static variable in class org.elasticsearch.search.DocValueFormat.BinaryDocValueFormat
- INSTANCE - Static variable in class org.elasticsearch.search.DocValueFormat.BooleanDocValueFormat
- INSTANCE - Static variable in class org.elasticsearch.search.DocValueFormat.GeoHashDocValueFormat
- INSTANCE - Static variable in class org.elasticsearch.search.DocValueFormat.GeoTileDocValueFormat
- INSTANCE - Static variable in class org.elasticsearch.search.DocValueFormat.IpDocValueFormat
- INSTANCE - Static variable in class org.elasticsearch.search.DocValueFormat.RawDocValueFormat
- INSTANCE - Static variable in class org.elasticsearch.search.DocValueFormat.UnsignedLongShiftedDocValueFormat
- INSTANCE - Static variable in class org.elasticsearch.search.rescore.QueryRescorer
- INSTANCE - Static variable in class org.elasticsearch.search.suggest.completion.CompletionSuggester
- INSTANCE - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggester
- INSTANCE - Static variable in class org.elasticsearch.search.suggest.term.TermSuggester
- INSTANCE - Static variable in class org.elasticsearch.snapshots.EmptySnapshotsInfoService
- INSTANCE - Static variable in class org.elasticsearch.SpecialPermission
- INSTANCE - Static variable in class org.elasticsearch.transport.TransportRequest.Empty
- INSTANCE - Static variable in class org.elasticsearch.transport.TransportResponse.Empty
- INSTANCE_SAME - Static variable in class org.elasticsearch.transport.EmptyTransportResponseHandler
- InstanceBinding<T> - Interface in org.elasticsearch.common.inject.spi
-
A binding to a single instance.
- InstanceBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- InstanceBindingImpl(Object, Key<T>, Scoping, Set<InjectionPoint>, T) - Constructor for class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- InstanceBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Set<InjectionPoint>, T) - Constructor for class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- instanceClazz - Variable in class org.elasticsearch.script.ScriptContext
-
A class that is an instance of a script.
- InstanceShardOperationRequest<Request extends InstanceShardOperationRequest<Request>> - Class in org.elasticsearch.action.support.single.instance
- InstanceShardOperationRequest() - Constructor for class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- InstanceShardOperationRequest(String) - Constructor for class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- InstanceShardOperationRequest(ShardId, StreamInput) - Constructor for class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- InstanceShardOperationRequestBuilder<Request extends InstanceShardOperationRequest<Request>,
Response extends ActionResponse, RequestBuilder extends InstanceShardOperationRequestBuilder<Request, Response, RequestBuilder>> - Class in org.elasticsearch.action.support.single.instance - InstanceShardOperationRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequestBuilder
- inSubpackage(String) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches classes in the given package and its subpackages.
- INSUFFICIENT_STORAGE - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The 507 (Insufficient Storage) status code means the method could not be performed on the resource because the server is unable to store the representation needed to successfully complete the request.
- inSyncAllocationIds(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- INT - Enum constant in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- INT_PAGE_SIZE - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- IntArray - Interface in org.elasticsearch.common.util
-
Abstraction of an array of integer values.
- Integer() - Constructor for class org.elasticsearch.common.collect.HppcMaps.Object.Integer
- INTEGER - Enum constant in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- INTEGER - Enum constant in enum class org.elasticsearch.index.mapper.RangeType
- interceptHandler(String, String, boolean, TransportRequestHandler<T>) - Method in interface org.elasticsearch.transport.TransportInterceptor
-
This is called for each handler that is registered via
TransportService.registerRequestHandler(String, String, boolean, boolean, Reader, TransportRequestHandler)
orTransportService.registerRequestHandler(String, String, Reader, TransportRequestHandler)
. - interceptSender(TransportInterceptor.AsyncSender) - Method in interface org.elasticsearch.transport.TransportInterceptor
-
This is called up-front providing the actual low level
TransportInterceptor.AsyncSender
that performs the low level send request. - INTERNAL - Enum constant in enum class org.elasticsearch.index.engine.Engine.SearcherScope
- INTERNAL - Enum constant in enum class org.elasticsearch.index.VersionType
- INTERNAL - Enum constant in enum class org.elasticsearch.indices.SystemDataStreamDescriptor.Type
- INTERNAL - Enum constant in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
This is the default and is based on
damerau_levenshtein
, but highly optimized for comparing string distance for terms inside the index. - INTERNAL_CLUSTER_INFO_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.InternalClusterInfoService
- INTERNAL_CLUSTER_INFO_UPDATE_INTERVAL_SETTING - Static variable in class org.elasticsearch.cluster.InternalClusterInfoService
- INTERNAL_MANAGED - Enum constant in enum class org.elasticsearch.indices.SystemIndexDescriptor.Type
- INTERNAL_SERVER_ERROR - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server encountered an unexpected condition which prevented it from fulfilling the request.
- INTERNAL_SNAPSHOT_INFO_MAX_CONCURRENT_FETCHES_SETTING - Static variable in class org.elasticsearch.snapshots.InternalSnapshotsInfoService
- INTERNAL_UNMANAGED - Enum constant in enum class org.elasticsearch.indices.SystemIndexDescriptor.Type
- internalActionLongTimeout() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- internalActionRetryTimeout() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- internalActionTimeout() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- InternalAdjacencyMatrix - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- InternalAdjacencyMatrix(String, List<InternalAdjacencyMatrix.InternalBucket>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- InternalAdjacencyMatrix(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
-
Read from a stream.
- InternalAdjacencyMatrix.InternalBucket - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- InternalAggregation - Class in org.elasticsearch.search.aggregations
-
An internal implementation of
Aggregation
. - InternalAggregation(String, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation
-
Constructs an aggregation result with a given name.
- InternalAggregation(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregation
-
Read from a stream.
- InternalAggregation.ReduceContext - Class in org.elasticsearch.search.aggregations
- InternalAggregation.ReduceContextBuilder - Interface in org.elasticsearch.search.aggregations
- InternalAggregationProfileTree - Class in org.elasticsearch.search.profile.aggregation
- InternalAggregationProfileTree() - Constructor for class org.elasticsearch.search.profile.aggregation.InternalAggregationProfileTree
- InternalAggregations - Class in org.elasticsearch.search.aggregations
-
An internal implementation of
Aggregations
. - InternalAggregations(List<InternalAggregation>, Supplier<PipelineAggregator.PipelineTree>) - Constructor for class org.elasticsearch.search.aggregations.InternalAggregations
-
Constructs a node in the aggregation tree.
- InternalAutoDateHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
Implementation of
Histogram
. - InternalAutoDateHistogram(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
-
Stream from a stream.
- InternalAutoDateHistogram.Bucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
- InternalAvg - Class in org.elasticsearch.search.aggregations.metrics
- InternalAvg(String, double, long, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalAvg
- InternalAvg(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalAvg
-
Read from a stream.
- InternalBinaryRange - Class in org.elasticsearch.search.aggregations.bucket.range
-
A range aggregation for data that is encoded in doc values using a binary representation.
- InternalBinaryRange(String, DocValueFormat, boolean, List<InternalBinaryRange.Bucket>, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- InternalBinaryRange(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
-
Read from a stream.
- InternalBinaryRange.Bucket - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalBucket() - Constructor for class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation.InternalBucket
- InternalBucket(String, long, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- InternalBucket(String, long, InternalAggregations, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- InternalBucket(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
-
Read from a stream.
- InternalBucket(StreamInput, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
-
Read from a stream.
- InternalBucketMetricValue - Class in org.elasticsearch.search.aggregations.pipeline
- InternalBucketMetricValue(String, String[], double, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalBucketMetricValue
- InternalBucketMetricValue(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalBucketMetricValue
-
Read from a stream.
- InternalCardinality - Class in org.elasticsearch.search.aggregations.metrics
- InternalCardinality(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalCardinality
-
Read from a stream.
- InternalClusterInfoService - Class in org.elasticsearch.cluster
-
InternalClusterInfoService provides the ClusterInfoService interface, routinely updated on a timer.
- InternalClusterInfoService(Settings, ClusterService, ThreadPool, Client) - Constructor for class org.elasticsearch.cluster.InternalClusterInfoService
- InternalComposite - Class in org.elasticsearch.search.aggregations.bucket.composite
- InternalComposite(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- InternalComposite.InternalBucket - Class in org.elasticsearch.search.aggregations.bucket.composite
- InternalContext - Class in org.elasticsearch.common.inject.internal
-
Internal context.
- InternalContext() - Constructor for class org.elasticsearch.common.inject.internal.InternalContext
- InternalDateHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
Implementation of
Histogram
. - InternalDateHistogram(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
-
Stream from a stream.
- InternalDateHistogram.Bucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
- InternalDateRange - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalDateRange(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalDateRange
-
Read from a stream.
- InternalDateRange.Bucket - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalDateRange.Factory - Class in org.elasticsearch.search.aggregations.bucket.range
- internalDecode(ReleasableBytesReference, Consumer<Object>) - Method in class org.elasticsearch.transport.InboundDecoder
- InternalDerivative - Class in org.elasticsearch.search.aggregations.pipeline
- InternalDerivative(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalDerivative
-
Read from a stream.
- InternalEngine - Class in org.elasticsearch.index.engine
- InternalEngine(EngineConfig) - Constructor for class org.elasticsearch.index.engine.InternalEngine
- InternalEngine.DeletionStrategy - Class in org.elasticsearch.index.engine
- InternalEngine.IndexingStrategy - Class in org.elasticsearch.index.engine
- InternalEngineFactory - Class in org.elasticsearch.index.engine
- InternalEngineFactory() - Constructor for class org.elasticsearch.index.engine.InternalEngineFactory
- InternalExtendedStats - Class in org.elasticsearch.search.aggregations.metrics
- InternalExtendedStats(String, long, double, double, double, double, double, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- InternalExtendedStats(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
-
Read from a stream.
- InternalExtendedStatsBucket - Class in org.elasticsearch.search.aggregations.pipeline
- InternalExtendedStatsBucket(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalExtendedStatsBucket
-
Read from a stream.
- InternalFactory<T> - Interface in org.elasticsearch.common.inject.internal
-
Creates objects which will be injected.
- InternalFactory.Instance<T> - Class in org.elasticsearch.common.inject.internal
-
ES: An factory that returns a pre created instance.
- InternalFilter - Class in org.elasticsearch.search.aggregations.bucket.filter
- InternalFilter(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.InternalFilter
-
Stream from a stream.
- InternalFilters - Class in org.elasticsearch.search.aggregations.bucket.filter
- InternalFilters(String, List<InternalFilters.InternalBucket>, boolean, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- InternalFilters(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
-
Read from a stream.
- InternalFilters.InternalBucket - Class in org.elasticsearch.search.aggregations.bucket.filter
- InternalGeoBounds - Class in org.elasticsearch.search.aggregations.metrics
- InternalGeoBounds(String, double, double, double, double, double, double, boolean, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- InternalGeoBounds(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
-
Read from a stream.
- InternalGeoCentroid - Class in org.elasticsearch.search.aggregations.metrics
-
Serialization and merge logic for
GeoCentroidAggregator
. - InternalGeoCentroid(String, GeoPoint, long, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- InternalGeoCentroid(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
-
Read from a stream.
- InternalGeoDistance - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalGeoDistance(String, List<InternalGeoDistance.Bucket>, boolean, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance
- InternalGeoDistance(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalGeoDistance
-
Read from a stream.
- InternalGeoDistance.Factory - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalGeoGrid<B extends InternalGeoGridBucket> - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Represents a grid of cells where each cell's location is determined by a specific geo hashing algorithm.
- InternalGeoGrid(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
-
Read from a stream.
- InternalGeoGridBucket - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- InternalGeoGridBucket(long, long, InternalAggregations) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- InternalGeoGridBucket(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
-
Read from a stream.
- InternalGeoHashGrid - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Represents a grid of cells where each cell's location is determined by a geohash.
- InternalGeoHashGrid(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGrid
- InternalGeoHashGridBucket - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- InternalGeoHashGridBucket(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoHashGridBucket
-
Read from a stream.
- InternalGeoTileGrid - Class in org.elasticsearch.search.aggregations.bucket.geogrid
-
Represents a grid of cells where each cell's location is determined by a geohash.
- InternalGeoTileGrid(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoTileGrid
- InternalGeoTileGridBucket - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- InternalGeoTileGridBucket(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoTileGridBucket
-
Read from a stream.
- InternalGlobal - Class in org.elasticsearch.search.aggregations.bucket.global
-
A global scope get (the document set on which we aggregate is all documents in the search context (ie.
- InternalGlobal(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.global.InternalGlobal
-
Read from a stream.
- InternalHDRPercentileRanks - Class in org.elasticsearch.search.aggregations.metrics
- InternalHDRPercentileRanks(String, double[], DoubleHistogram, boolean, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks
- InternalHDRPercentileRanks(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks
-
Read from a stream.
- InternalHDRPercentileRanks.Iter - Class in org.elasticsearch.search.aggregations.metrics
- InternalHDRPercentiles - Class in org.elasticsearch.search.aggregations.metrics
- InternalHDRPercentiles(String, double[], DoubleHistogram, boolean, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- InternalHDRPercentiles(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
-
Read from a stream.
- InternalHDRPercentiles.Iter - Class in org.elasticsearch.search.aggregations.metrics
- InternalHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
Implementation of
Histogram
. - InternalHistogram(String, List<InternalHistogram.Bucket>, BucketOrder, long, InternalHistogram.EmptyBucketInfo, DocValueFormat, boolean, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- InternalHistogram(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
-
Stream from a stream.
- InternalHistogram.Bucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
- InternalHistogram.EmptyBucketInfo - Class in org.elasticsearch.search.aggregations.bucket.histogram
- InternalIndex - Enum constant in enum class org.elasticsearch.common.settings.Setting.Property
-
Indicates an index-level setting that is managed internally.
- InternalMappedRareTerms<A extends InternalRareTerms<A,
B>, B extends InternalRareTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms - InternalMappedSignificantTerms<A extends InternalMappedSignificantTerms<A,
B>, B extends InternalSignificantTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms - InternalMappedSignificantTerms(String, int, long, Map<String, Object>, DocValueFormat, long, long, SignificanceHeuristic, List<B>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- InternalMappedSignificantTerms(StreamInput, InternalSignificantTerms.Bucket.Reader<B>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- InternalMappedTerms<A extends InternalTerms<A,
B>, B extends InternalTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms -
Common superclass for results of the terms aggregation on mapped fields.
- InternalMappedTerms(String, BucketOrder, BucketOrder, int, long, Map<String, Object>, DocValueFormat, int, boolean, long, List<B>, Long) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- InternalMappedTerms(StreamInput, InternalTerms.Bucket.Reader<B>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
-
Read from a stream.
- InternalMax - Class in org.elasticsearch.search.aggregations.metrics
- InternalMax(String, double, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalMax
- InternalMax(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalMax
-
Read from a stream.
- InternalMedianAbsoluteDeviation - Class in org.elasticsearch.search.aggregations.metrics
- InternalMedianAbsoluteDeviation(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalMedianAbsoluteDeviation
- InternalMin - Class in org.elasticsearch.search.aggregations.metrics
- InternalMin(String, double, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalMin
- InternalMin(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalMin
-
Read from a stream.
- InternalMissing - Class in org.elasticsearch.search.aggregations.bucket.missing
- InternalMissing(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.InternalMissing
-
Read from a stream.
- InternalMultiBucketAggregation<A extends InternalMultiBucketAggregation,
B extends InternalMultiBucketAggregation.InternalBucket> - Class in org.elasticsearch.search.aggregations - InternalMultiBucketAggregation(String, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
- InternalMultiBucketAggregation(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
-
Read from a stream.
- InternalMultiBucketAggregation.InternalBucket - Class in org.elasticsearch.search.aggregations
- InternalMultiValueAggregation - Class in org.elasticsearch.search.aggregations.metrics
- InternalMultiValueAggregation(String, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalMultiValueAggregation
- InternalMultiValueAggregation(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalMultiValueAggregation
-
Read from a stream.
- InternalNested - Class in org.elasticsearch.search.aggregations.bucket.nested
-
Result of the
NestedAggregator
. - InternalNested(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
-
Read from a stream.
- InternalNumericMetricsAggregation - Class in org.elasticsearch.search.aggregations.metrics
- InternalNumericMetricsAggregation(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation
-
Read from a stream.
- InternalNumericMetricsAggregation.MultiValue - Class in org.elasticsearch.search.aggregations.metrics
- InternalNumericMetricsAggregation.SingleValue - Class in org.elasticsearch.search.aggregations.metrics
- InternalOrder - Class in org.elasticsearch.search.aggregations
-
Implementations for
MultiBucketsAggregation.Bucket
ordering strategies. - InternalOrder() - Constructor for class org.elasticsearch.search.aggregations.InternalOrder
- InternalOrder.Aggregation - Class in org.elasticsearch.search.aggregations
-
MultiBucketsAggregation.Bucket
ordering strategy to sort by a sub-aggregation. - InternalOrder.CompoundOrder - Class in org.elasticsearch.search.aggregations
-
MultiBucketsAggregation.Bucket
ordering strategy to sort by multiple criteria. - InternalOrder.Parser - Class in org.elasticsearch.search.aggregations
-
Contains logic for parsing a
BucketOrder
from aXContentParser
. - InternalOrder.Streams - Class in org.elasticsearch.search.aggregations
-
Contains logic for reading/writing
BucketOrder
from/to streams. - InternalPercentilesBucket - Class in org.elasticsearch.search.aggregations.pipeline
- InternalPercentilesBucket(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket
-
Read from a stream.
- InternalPercentilesBucket.Iter - Class in org.elasticsearch.search.aggregations.pipeline
- InternalProfileCollector - Class in org.elasticsearch.search.profile.query
-
This class wraps a Lucene Collector and times the execution of: - setScorer() - collect() - doSetNextReader() - needsScores() InternalProfiler facilitates the linking of the Collector graph
- InternalProfileCollector(Collector, String, List<InternalProfileCollector>) - Constructor for class org.elasticsearch.search.profile.query.InternalProfileCollector
- InternalQueryContext(String, int, boolean) - Constructor for class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- InternalRange<B extends InternalRange.Bucket,
R extends InternalRange<B, R>> - Class in org.elasticsearch.search.aggregations.bucket.range - InternalRange(String, List<B>, DocValueFormat, boolean, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- InternalRange(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.InternalRange
-
Read from a stream.
- InternalRange.Bucket - Class in org.elasticsearch.search.aggregations.bucket.range
- InternalRange.Factory<B extends InternalRange.Bucket,
R extends InternalRange<B, R>> - Class in org.elasticsearch.search.aggregations.bucket.range - InternalRareTerms<A extends InternalRareTerms<A,
B>, B extends InternalRareTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms - InternalRareTerms(String, BucketOrder, long, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
- InternalRareTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
-
Read from a stream.
- InternalRareTerms.Bucket<B extends InternalRareTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms
- InternalRareTerms.Bucket.Reader<B extends InternalRareTerms.Bucket<B>> - Interface in org.elasticsearch.search.aggregations.bucket.terms
-
Reads a bucket.
- InternalReverseNested - Class in org.elasticsearch.search.aggregations.bucket.nested
-
Result of the
ReverseNestedAggregator
. - InternalReverseNested(String, long, InternalAggregations, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
- InternalReverseNested(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
-
Read from a stream.
- InternalSampler - Class in org.elasticsearch.search.aggregations.bucket.sampler
- InternalSampler(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
-
Read from a stream.
- InternalScriptedMetric - Class in org.elasticsearch.search.aggregations.metrics
- InternalScriptedMetric(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalScriptedMetric
-
Read from a stream.
- InternalScrollSearchRequest - Class in org.elasticsearch.search.internal
- InternalScrollSearchRequest() - Constructor for class org.elasticsearch.search.internal.InternalScrollSearchRequest
- InternalScrollSearchRequest(SearchScrollRequest, ShardSearchContextId) - Constructor for class org.elasticsearch.search.internal.InternalScrollSearchRequest
- InternalScrollSearchRequest(StreamInput) - Constructor for class org.elasticsearch.search.internal.InternalScrollSearchRequest
- InternalSearchResponse - Class in org.elasticsearch.search.internal
-
SearchResponseSections
subclass that can be serialized over the wire. - InternalSearchResponse(StreamInput) - Constructor for class org.elasticsearch.search.internal.InternalSearchResponse
- InternalSearchResponse(SearchHits, InternalAggregations, Suggest, SearchProfileResults, boolean, Boolean, int) - Constructor for class org.elasticsearch.search.internal.InternalSearchResponse
- InternalSettingsPreparer - Class in org.elasticsearch.node
- InternalSettingsPreparer() - Constructor for class org.elasticsearch.node.InternalSettingsPreparer
- InternalSignificantTerms<A extends InternalSignificantTerms<A,
B>, B extends InternalSignificantTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms -
Result of the significant terms aggregation.
- InternalSignificantTerms(String, int, long, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- InternalSignificantTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
-
Read from a stream.
- InternalSignificantTerms.Bucket<B extends InternalSignificantTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms
- InternalSignificantTerms.Bucket.Reader<B extends InternalSignificantTerms.Bucket<B>> - Interface in org.elasticsearch.search.aggregations.bucket.terms
-
Reads a bucket.
- InternalSimpleValue - Class in org.elasticsearch.search.aggregations.pipeline
- InternalSimpleValue(String, double, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- InternalSimpleValue(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
-
Read from a stream.
- InternalSingleBucketAggregation - Class in org.elasticsearch.search.aggregations.bucket
-
A base class for all the single bucket aggregations.
- InternalSingleBucketAggregation(String, long, InternalAggregations, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
-
Creates a single bucket aggregation.
- InternalSingleBucketAggregation(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
-
Read from a stream.
- InternalSnapshotsInfoService - Class in org.elasticsearch.snapshots
- InternalSnapshotsInfoService(Settings, ClusterService, Supplier<RepositoriesService>, Supplier<RerouteService>) - Constructor for class org.elasticsearch.snapshots.InternalSnapshotsInfoService
- InternalSnapshotsInfoService.SnapshotShard - Class in org.elasticsearch.snapshots
- internalSourceRef() - Method in class org.elasticsearch.index.get.GetResult
-
Internal source representation, might be compressed....
- internalSourceRef() - Method in class org.elasticsearch.search.lookup.SourceLookup
-
Internal source representation, might be compressed....
- InternalStats - Class in org.elasticsearch.search.aggregations.metrics
- InternalStats(String, long, double, double, double, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalStats
- InternalStats(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalStats
-
Read from a stream.
- InternalStatsBucket - Class in org.elasticsearch.search.aggregations.pipeline
- InternalStatsBucket(String, long, double, double, double, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalStatsBucket
- InternalStatsBucket(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalStatsBucket
-
Read from a stream.
- InternalSum - Class in org.elasticsearch.search.aggregations.metrics
- InternalSum(String, double, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalSum
- InternalSum(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalSum
-
Read from a stream.
- InternalTDigestPercentileRanks - Class in org.elasticsearch.search.aggregations.metrics
- InternalTDigestPercentileRanks(String, double[], TDigestState, boolean, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks
- InternalTDigestPercentileRanks(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks
-
Read from a stream.
- InternalTDigestPercentileRanks.Iter - Class in org.elasticsearch.search.aggregations.metrics
- InternalTDigestPercentiles - Class in org.elasticsearch.search.aggregations.metrics
- InternalTDigestPercentiles(String, double[], TDigestState, boolean, DocValueFormat, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- InternalTDigestPercentiles(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
-
Read from a stream.
- InternalTDigestPercentiles.Iter - Class in org.elasticsearch.search.aggregations.metrics
- InternalTerms<A extends InternalTerms<A,
B>, B extends InternalTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms - InternalTerms(String, BucketOrder, BucketOrder, int, long, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
-
Creates a new
InternalTerms
- InternalTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
-
Read from a stream.
- InternalTerms.Bucket<B extends InternalTerms.Bucket<B>> - Class in org.elasticsearch.search.aggregations.bucket.terms
- InternalTerms.Bucket.Reader<B extends InternalTerms.Bucket<B>> - Interface in org.elasticsearch.search.aggregations.bucket.terms
-
Reads a bucket.
- internalTermStats(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- InternalTopHits - Class in org.elasticsearch.search.aggregations.metrics
-
Results of the
TopHitsAggregator
. - InternalTopHits(String, int, int, TopDocsAndMaxScore, SearchHits, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalTopHits
- InternalTopHits(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalTopHits
-
Read from a stream.
- InternalValueCount - Class in org.elasticsearch.search.aggregations.metrics
-
An internal implementation of
ValueCount
. - InternalValueCount(String, long, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalValueCount
- InternalValueCount(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalValueCount
-
Read from a stream.
- InternalVariableWidthHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
- InternalVariableWidthHistogram(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
-
Stream from a stream.
- InternalVariableWidthHistogram.Bucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
- InternalVariableWidthHistogram.Bucket.BucketBounds - Class in org.elasticsearch.search.aggregations.bucket.histogram
- InternalWeightedAvg - Class in org.elasticsearch.search.aggregations.metrics
- InternalWeightedAvg(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalWeightedAvg
-
Read from a stream.
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- internalXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- interruptTask() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
-
Subclasses can override this method to implement interruption of the future's computation.
- intersect(Predicate<String>) - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
-
Returns a new
DataStreamAlias
instance that contains a new intersection of data streams from this instance and the provided filter. - intersect(Weight, Weight, Collector, LeafReaderContext) - Static method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext
- intersection(ObjectLookupContainer<T>, ObjectLookupContainer<T>) - Static method in class org.elasticsearch.common.collect.HppcMaps
- intersection(Set<T>, Set<T>) - Static method in class org.elasticsearch.common.util.set.Sets
- INTERSECTION - Enum constant in enum class org.elasticsearch.index.query.RegexpFlag
-
Enables intersection of the form:
<expression> & <expression>
- INTERSECTS - Enum constant in enum class org.apache.lucene.queries.BinaryDocValuesRangeQuery.QueryType
- INTERSECTS - Enum constant in enum class org.elasticsearch.common.geo.ShapeRelation
- INTERSECTS - Enum constant in enum class org.elasticsearch.index.mapper.MappedFieldType.Relation
- intersectsQuery(String, Object, Object, boolean, boolean) - Method in enum class org.elasticsearch.index.mapper.RangeType
- interval - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- interval() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- interval() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Deprecated.
- interval() - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
-
Returns the interval that is set on this source
- interval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Deprecated.
- interval() - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalConsumer
-
Deprecated.
- interval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
-
Deprecated.
- interval() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Get the current interval that is set on this builder.
- interval(double) - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
-
Sets the interval on this source.
- interval(double) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Set the interval on this builder, and return the builder so that calls can be chained.
- interval(long) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- interval(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- interval(long) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalConsumer
-
Deprecated.
- interval(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- interval(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- interval(TimeValue) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- Interval() - Constructor for class org.elasticsearch.index.query.IntervalFilterScript.Interval
- INTERVAL - Enum constant in enum class org.elasticsearch.index.query.RegexpFlag
-
Enables numerical interval expression:
<n-m>
- INTERVAL_FIELD - Static variable in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
- IntervalBuilder - Class in org.elasticsearch.index.query
-
Constructs an IntervalsSource based on analyzed text
- IntervalBuilder(String, Analyzer) - Constructor for class org.elasticsearch.index.query.IntervalBuilder
- IntervalFilter(StreamInput) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.IntervalFilter
- IntervalFilter(IntervalsSourceProvider, String) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.IntervalFilter
- IntervalFilterScript - Class in org.elasticsearch.index.query
-
Base class for scripts used as interval filters, see
IntervalsSourceProvider.IntervalFilter
- IntervalFilterScript() - Constructor for class org.elasticsearch.index.query.IntervalFilterScript
- IntervalFilterScript.Factory - Interface in org.elasticsearch.index.query
- IntervalFilterScript.Interval - Class in org.elasticsearch.index.query
- IntervalQueryBuilder - Class in org.elasticsearch.index.query
-
Builder for
IntervalQuery
- IntervalQueryBuilder(String, IntervalsSourceProvider) - Constructor for class org.elasticsearch.index.query.IntervalQueryBuilder
- IntervalQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.IntervalQueryBuilder
- IntervalsSourceProvider - Class in org.elasticsearch.index.query
-
Factory class for
IntervalsSource
Built-in sources includeIntervalsSourceProvider.Match
, which analyzes a text string and converts it to a proximity source (phrase, ordered or unordered depending on how strict the matching should be);IntervalsSourceProvider.Combine
, which allows proximity queries between different sub-sources; andIntervalsSourceProvider.Disjunction
. - IntervalsSourceProvider() - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider
- IntervalsSourceProvider.Combine - Class in org.elasticsearch.index.query
- IntervalsSourceProvider.Disjunction - Class in org.elasticsearch.index.query
- IntervalsSourceProvider.Fuzzy - Class in org.elasticsearch.index.query
- IntervalsSourceProvider.IntervalFilter - Class in org.elasticsearch.index.query
- IntervalsSourceProvider.Match - Class in org.elasticsearch.index.query
- IntervalsSourceProvider.Prefix - Class in org.elasticsearch.index.query
- IntervalsSourceProvider.Wildcard - Class in org.elasticsearch.index.query
- intField(FieldInfo, int) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- intField(FieldInfo, int) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- intField(FieldInfo, int) - Method in class org.elasticsearch.search.internal.FilterFieldNamesProvidingStoredFieldsVisitor
- intField(FieldInfo, int) - Method in class org.elasticsearch.search.internal.FilterStoredFieldVisitor
- intPage(boolean) - Method in class org.elasticsearch.common.util.PageCacheRecycler
- intParam(String, boolean, Function<FieldMapper, Integer>, int) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Defines a parameter that takes an integer value
- intSetting(String, int, int, int, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- intSetting(String, int, int, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- intSetting(String, int, int, Setting.Validator<Integer>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- intSetting(String, int, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- intSetting(String, Setting<Integer>, int, int, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- intSetting(String, Setting<Integer>, int, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- intSetting(String, Setting<Integer>, int, Setting.Validator<Integer>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- intToBytes(int) - Static method in class org.elasticsearch.common.Numbers
- intValue() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic.LongAccessor
- INVALID_FILENAME_CHARS - Static variable in class org.elasticsearch.common.Strings
- InvalidAggregationPathException - Exception in org.elasticsearch.search.aggregations
- InvalidAggregationPathException(String) - Constructor for exception org.elasticsearch.search.aggregations.InvalidAggregationPathException
- InvalidAggregationPathException(String, Throwable) - Constructor for exception org.elasticsearch.search.aggregations.InvalidAggregationPathException
- InvalidAggregationPathException(StreamInput) - Constructor for exception org.elasticsearch.search.aggregations.InvalidAggregationPathException
- InvalidAliasNameException - Exception in org.elasticsearch.indices
- InvalidAliasNameException(String, String) - Constructor for exception org.elasticsearch.indices.InvalidAliasNameException
- InvalidAliasNameException(StreamInput) - Constructor for exception org.elasticsearch.indices.InvalidAliasNameException
- InvalidAliasNameException(Index, String, String) - Constructor for exception org.elasticsearch.indices.InvalidAliasNameException
- invalidate(K) - Method in class org.elasticsearch.common.cache.Cache
-
Invalidate the association for the specified key.
- invalidate(K, V) - Method in class org.elasticsearch.common.cache.Cache
-
Invalidate the entry for the specified key and value.
- invalidateAll() - Method in class org.elasticsearch.common.cache.Cache
-
Invalidate all cache entries.
- INVALIDATED - Enum constant in enum class org.elasticsearch.common.cache.RemovalNotification.RemovalReason
- InvalidIndexNameException - Exception in org.elasticsearch.indices
- InvalidIndexNameException(String, String) - Constructor for exception org.elasticsearch.indices.InvalidIndexNameException
- InvalidIndexNameException(StreamInput) - Constructor for exception org.elasticsearch.indices.InvalidIndexNameException
- InvalidIndexNameException(Index, String, String) - Constructor for exception org.elasticsearch.indices.InvalidIndexNameException
- InvalidIndexTemplateException - Exception in org.elasticsearch.indices
- InvalidIndexTemplateException(String, String) - Constructor for exception org.elasticsearch.indices.InvalidIndexTemplateException
- InvalidIndexTemplateException(StreamInput) - Constructor for exception org.elasticsearch.indices.InvalidIndexTemplateException
- InvalidSnapshotNameException - Exception in org.elasticsearch.snapshots
-
Thrown on the attempt to create a snapshot with invalid name
- InvalidSnapshotNameException(String, String, String) - Constructor for exception org.elasticsearch.snapshots.InvalidSnapshotNameException
- InvalidSnapshotNameException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.InvalidSnapshotNameException
- InvalidTypeNameException - Exception in org.elasticsearch.indices
- InvalidTypeNameException(String) - Constructor for exception org.elasticsearch.indices.InvalidTypeNameException
- InvalidTypeNameException(StreamInput) - Constructor for exception org.elasticsearch.indices.InvalidTypeNameException
- invariant() - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- invariant() - Method in class org.elasticsearch.cluster.coordination.Coordinator
- INVERTED_INDEX - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- INVERTED_INDEX - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- IoStats(StreamInput) - Constructor for class org.elasticsearch.monitor.fs.FsInfo.IoStats
- IoStats(FsInfo.DeviceStats[]) - Constructor for class org.elasticsearch.monitor.fs.FsInfo.IoStats
- ioTimeInMillis() - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- IP - Enum constant in enum class org.elasticsearch.index.mapper.RangeType
- IP - Enum constant in enum class org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- IP - Enum constant in enum class org.elasticsearch.search.aggregations.support.ValueType
- IP - Static variable in interface org.elasticsearch.search.DocValueFormat
- IP_VALIDATOR - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
-
Validates the IP addresses in a group of
Settings
by looking for the keys "_ip", "_host_ip", and "_publish_ip" and ensuring each of their comma separated values that has no wildcards is a valid IP address. - IpFieldMapper - Class in org.elasticsearch.index.mapper
-
A
FieldMapper
for ip addresses. - IpFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- IpFieldMapper.IpFieldType - Class in org.elasticsearch.index.mapper
- IpFieldMapper.IpFieldType.IpScriptDocValues - Class in org.elasticsearch.index.mapper
- IpFieldScript - Class in org.elasticsearch.script
-
Script producing IP addresses.
- IpFieldScript(String, Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.IpFieldScript
- IpFieldScript.Emit - Class in org.elasticsearch.script
- IpFieldScript.Factory - Interface in org.elasticsearch.script
- IpFieldScript.LeafFactory - Interface in org.elasticsearch.script
- IpFieldType(String) - Constructor for class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- IpFieldType(String, boolean, boolean, boolean, InetAddress, FieldValues<InetAddress>, Map<String, String>, boolean) - Constructor for class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- ipRange(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
IpRangeAggregationBuilder
aggregation with the given name. - IpRangeAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.range
- IpRangeAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- IpRangeAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- IpRangeAggregationBuilder(IpRangeAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- IpRangeAggregationBuilder.Range - Class in org.elasticsearch.search.aggregations.bucket.range
- IpRangeAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.bucket.range
- IpScriptDocValues - Class in org.elasticsearch.index.fielddata
- IpScriptDocValues(SortedSetDocValues) - Constructor for class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType.IpScriptDocValues
- IpScriptDocValues(SortedBinaryDocValues) - Constructor for class org.elasticsearch.index.fielddata.IpScriptFieldData.IpScriptDocValues
- IpScriptFieldData - Class in org.elasticsearch.index.fielddata
- IpScriptFieldData.Builder - Class in org.elasticsearch.index.fielddata
- IpScriptFieldData.IpScriptDocValues - Class in org.elasticsearch.index.fielddata
-
Doc values implementation for ips.
- IpScriptFieldExistsQuery - Class in org.elasticsearch.search.runtime
- IpScriptFieldExistsQuery(Script, IpFieldScript.LeafFactory, String) - Constructor for class org.elasticsearch.search.runtime.IpScriptFieldExistsQuery
- IpScriptFieldRangeQuery - Class in org.elasticsearch.search.runtime
- IpScriptFieldRangeQuery(Script, IpFieldScript.LeafFactory, String, BytesRef, BytesRef) - Constructor for class org.elasticsearch.search.runtime.IpScriptFieldRangeQuery
- IpScriptFieldTermQuery - Class in org.elasticsearch.search.runtime
- IpScriptFieldTermQuery(Script, IpFieldScript.LeafFactory, String, BytesRef) - Constructor for class org.elasticsearch.search.runtime.IpScriptFieldTermQuery
- IpScriptFieldTermsQuery - Class in org.elasticsearch.search.runtime
- IpScriptFieldTermsQuery(Script, IpFieldScript.LeafFactory, String, BytesRefHash) - Constructor for class org.elasticsearch.search.runtime.IpScriptFieldTermsQuery
- IpScriptFieldType - Class in org.elasticsearch.index.mapper
- isA(ValueType) - Method in enum class org.elasticsearch.search.aggregations.support.ValueType
-
This is a bit of a hack to mirror the old
ValueType
behavior, which would allow a rough compatibility between types. - isAborted() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
-
Whether this failure is the result of an abort.
- isAborted() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- isAbortOnVersionConflict() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Whether or not version conflicts cause the action to abort.
- isAbsolute() - Method in class org.elasticsearch.common.unit.RelativeByteSizeValue
- isAcceptDataLoss() - Method in class org.elasticsearch.action.admin.indices.dangling.delete.DeleteDanglingIndexRequest
- isAcceptDataLoss() - Method in class org.elasticsearch.action.admin.indices.dangling.import_index.ImportDanglingIndexRequest
- isAccepted() - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse
- isAccessibleDirectory(Path, Logger) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Check that a directory exists, is a directory and is readable by the current user
- isAcknowledged() - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
-
Returns whether the response is acknowledged or not
- isActive() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
-
Checks if this shard snapshot is actively executing.
- isActive() - Method in class org.elasticsearch.index.shard.IndexShard
- isAfter(ChronoZonedDateTime<?>) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- isAggregatable() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
Whether this field can be aggregated on all indices.
- isAggregatable() - Method in class org.elasticsearch.action.fieldcaps.IndexFieldCapabilities
- isAggregatable() - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- isAggregatable() - Method in class org.elasticsearch.index.mapper.ConstantFieldType
- isAggregatable() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns true if the field is aggregatable.
- isAggregating() - Method in class org.elasticsearch.transport.InboundAggregator
- isAllIndices(Collection<String>) - Static method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Identifies whether the array containing index names given as argument refers to all indices The empty or null array identifies all indices
- isAllOrWildcard(String) - Static method in class org.elasticsearch.common.Strings
-
Returns `true` if the string is `_all` or `*`.
- isAllOrWildcard(String[]) - Static method in class org.elasticsearch.common.Strings
-
If an array only consists of zero or one element, which is "*" or "_all" return an empty array which is usually used as everything
- isAllowReleaseResources() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- isAllTypes(String[]) - Static method in class org.elasticsearch.cluster.metadata.Metadata
-
Identifies whether the array containing type names given as argument refers to all types The empty or null array identifies all types
- isAlpha() - Method in class org.elasticsearch.Version
-
Returns true iff this version is an alpha version Note: This has been introduced in elasticsearch version 5.
- isAnyContextEnabled() - Method in class org.elasticsearch.script.ScriptService
- isAnyOriginSupported() - Method in class org.elasticsearch.http.CorsHandler.Config
- isArchived() - Method in class org.elasticsearch.repositories.RepositoryStatsSnapshot
- isArray(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- isArtificial() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- isAssigned() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Assignment
- isAssigned() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- isAutogenerated(String) - Static method in class org.elasticsearch.index.store.Store
-
Returns true if the file is auto-generated by the store and shouldn't be deleted during cleanup.
- isAutoGeneratedIDsOptimizationEnabled() - Method in class org.elasticsearch.index.engine.EngineConfig
-
returns true if the engine is allowed to optimize indexing operations with an auto-generated ID
- isAutomaticallyManaged() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- isAutoReleaseIndexEnabled() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- isAutoThrottle() - Method in class org.elasticsearch.index.MergeSchedulerConfig
-
Returns
true
iff auto throttle is enabled. - isBecomeMasterTask() - Method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor.Task
- isBefore(ChronoZonedDateTime<?>) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- isBeta() - Method in class org.elasticsearch.Version
- isBoost() - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Returns whether to boost terms in query based on "score" or not.
- isBoostTerms() - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- isBootstrapPlaceholder(String) - Static method in class org.elasticsearch.cluster.coordination.ClusterBootstrapService
- isBottomSortShardDisjoint(SearchExecutionContext, SearchSortValuesAndFormats) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Returns whether some values of the given
SearchExecutionContext.getIndexReader()
are within the primary sort value provided in thebottomSortValues
. - isBuiltinType(String) - Static method in class org.elasticsearch.index.IndexModule
- isCacheable() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Returns
true
iff the result of the processed search request is cacheable. - isCacheable() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Is this request cacheable? Requests that have non-deterministic queries or scripts aren't cachable.
- isCacheable() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- isCacheable(LeafReaderContext) - Method in class org.elasticsearch.search.profile.query.ProfileWeight
- isCamelCase(String) - Method in enum class org.elasticsearch.common.time.FormatNames
- isCanceled() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
- isCancellable() - Method in class org.elasticsearch.tasks.TaskInfo
-
Returns true if the task supports cancellation
- isCancelled() - Method in class org.elasticsearch.common.util.CancellableThreads
- isCancelled() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
- isCancelled() - Method in class org.elasticsearch.repositories.GetSnapshotInfoContext
- isCancelled() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Has the search been cancelled?
- isCancelled() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- isCancelled() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- isCancelled() - Method in class org.elasticsearch.search.internal.SearchContext
- isCancelled() - Method in class org.elasticsearch.tasks.CancellableTask
-
Return whether the task is cancelled.
- isCancelled() - Method in class org.elasticsearch.tasks.TaskInfo
-
Returns true if the task supports cancellation and has been cancelled
- isCancelled() - Method in interface org.elasticsearch.threadpool.Scheduler.Cancellable
-
Check if the execution has been cancelled
- isCancelled() - Method in class org.elasticsearch.threadpool.Scheduler.ReschedulingRunnable
- isCcsMinimizeRoundtrips() - Method in class org.elasticsearch.action.search.SearchRequest
-
Returns whether network round-trips should be minimized when executing cross-cluster search requests.
- isChanged() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
-
Returns whether changes were made
- isChanged() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Builder
-
Returns true if any the task list was changed since the builder was created
- isClone() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- isCloseConnectionException(Throwable) - Static method in class org.elasticsearch.common.transport.NetworkExceptionHelper
- isClosed - Variable in class org.elasticsearch.index.engine.Engine
- isClosed() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- isClosed() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.PingingRound
- isClosed() - Method in class org.elasticsearch.index.translog.TranslogReader
- isClosed() - Method in class org.elasticsearch.index.translog.TranslogWriter
- isClosed() - Method in class org.elasticsearch.node.Node
-
Returns
true
if the node is closed. - isClosed() - Method in class org.elasticsearch.transport.CloseableConnection
- isClosed() - Method in class org.elasticsearch.transport.Lz4TransportDecompressor
-
Returns
true
if and only if the end of the compressed stream has been reached. - isClosed() - Method in class org.elasticsearch.transport.RemoteConnectionStrategy
- isClosed() - Method in interface org.elasticsearch.transport.Transport.Connection
- isClosing() - Method in class org.elasticsearch.index.store.Store
- isCoerce(GeoValidationMethod) - Static method in enum class org.elasticsearch.index.query.GeoValidationMethod
-
Returns whether or not to try and fix broken/wrapping bounding boxes.
- isColdNode(DiscoveryNode) - Static method in class org.elasticsearch.cluster.routing.allocation.DataTier
- isCommitted() - Method in class org.elasticsearch.cluster.coordination.Publication
- isCommitted() - Method in class org.elasticsearch.index.engine.Segment
- isCompatible(Version) - Method in class org.elasticsearch.Version
-
Returns
true
iff both version are compatible. - isComplete() - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- isComplete() - Method in class org.elasticsearch.index.shard.IndexLongFieldRange
- isComplete() - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- isCompleted() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
-
For external purposes, locally aborted and completed are the same.
- isCompleted() - Method in class org.elasticsearch.tasks.TaskResult
- isCompound() - Method in class org.elasticsearch.index.engine.Segment
- isCompress() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Returns true if metadata and snapshot files should be compressed
- isCompress(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- isCompressed(BytesReference) - Method in interface org.elasticsearch.common.compress.Compressor
- isCompressed(BytesReference) - Static method in class org.elasticsearch.common.compress.CompressorFactory
- isCompressed(BytesReference) - Method in class org.elasticsearch.common.compress.DeflateCompressor
- isCompression() - Method in class org.elasticsearch.http.HttpHandlingSettings
- isConcrete(Class<?>) - Static method in class org.elasticsearch.common.Classes
- isConfigured() - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- isConnected() - Method in class org.elasticsearch.transport.ProxyConnectionStrategy.ProxyModeInfo
- isConnected() - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- isConnected() - Method in interface org.elasticsearch.transport.RemoteConnectionInfo.ModeInfo
- isConnected() - Method in class org.elasticsearch.transport.SniffConnectionStrategy.SniffModeInfo
- isConnectException(Throwable) - Static method in class org.elasticsearch.common.transport.NetworkExceptionHelper
- isConnectionEnabled(String, Map<Setting<?>, Object>) - Static method in class org.elasticsearch.transport.RemoteConnectionStrategy
- isConnectionEnabled(String, Settings) - Static method in class org.elasticsearch.transport.RemoteConnectionStrategy
- isConsistent() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting's value can be checked for equality across all nodes. - isConstant() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
-
Is this a constant binding? This returns true for constant bindings as well as toInstance() bindings.
- isConstructing() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- isContentConsumed() - Method in class org.elasticsearch.rest.RestRequest
- isContentNode(DiscoveryNode) - Static method in class org.elasticsearch.cluster.routing.allocation.DataTier
- isContextEnabled(ScriptContext<?>) - Method in class org.elasticsearch.script.ScriptService
- isCorruptionException(Throwable) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Returns
true
iff the given exception or one of it's causes is an instance ofCorruptIndexException
,IndexFormatTooOldException
, orIndexFormatTooNewException
otherwisefalse
. - isCorruptMarkerFileIsPresent(Directory) - Static method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- isCorsEnabled() - Method in class org.elasticsearch.http.HttpHandlingSettings
- isCorsSupportEnabled() - Method in class org.elasticsearch.http.CorsHandler.Config
- isCountDesc(BucketOrder) - Static method in class org.elasticsearch.search.aggregations.InternalOrder
-
Determine if the ordering strategy is sorting on bucket count descending.
- isCountedDown() - Method in class org.elasticsearch.common.util.concurrent.CountDown
-
Returns
true
iff the count-down has reached zero. - isCreated() - Method in class org.elasticsearch.index.engine.Engine.IndexResult
- isCredentialsAllowed() - Method in class org.elasticsearch.http.CorsHandler.Config
- isCrossClusterSearchEnabled() - Method in class org.elasticsearch.transport.RemoteClusterService
-
Returns
true
if at least one remote cluster is configured - isCustomDataPath() - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- isCustomDataPath() - Method in class org.elasticsearch.index.shard.ShardPath
-
Returns
true
iff the data location is a custom data location and therefore outside of the nodes configured data paths. - isDataStreamIndex() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns if this shard is a part of datastream
- isDataStreamRelated() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- isDataStreamRelated() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- isDataStreamRelated() - Method in interface org.elasticsearch.cluster.metadata.IndexAbstraction
- isDataStreamTimestampFieldEnabled() - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Returns if this mapping contains a data-stream's timestamp meta-field and this field is enabled.
- isDecisionTaken() - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Returns
true
if a decision was taken by the allocator,false
otherwise. - isDecisionTaken() - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- isDecisionTaken() - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
- isDecisionTaken() - Method in class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
-
Returns
true
if either an allocation decision or a move decision was taken for the shard. - isDedicatedFrozenNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Returns whether or not the node is a frozen only node, i.e., has data frozen role and no other data roles.
- isDedicatedFrozenNode(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Check if the settings are for a dedicated frozen node, i.e.
- isDedicatedVotingOnlyNode(Set<DiscoveryNodeRole>) - Static method in class org.elasticsearch.repositories.RepositoriesService
- isDefaultAllowUnmappedFields() - Method in class org.elasticsearch.index.IndexSettings
-
Returns
true
if queries should be lenient about unmapped fields. - isDefaultProfile - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- isDeflate(BytesReference) - Static method in enum class org.elasticsearch.transport.Compression.Scheme
- isDelayed() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
-
Returns true if allocation of this shard is delayed due to
UnassignedInfo.INDEX_DELAYED_NODE_LEFT_TIMEOUT_SETTING
- isDeleted() - Method in class org.elasticsearch.common.lucene.FilterIndexCommit
- isDeleteOnExit() - Method in class org.elasticsearch.common.PidFile
-
Returns
true
iff the process id file is deleted on system exit. - isDeprecated() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting is deprecated, otherwisefalse
- isDeprecated() - Method in class org.elasticsearch.rest.RestHandler.Route
- isDeprecatedPattern(String) - Static method in class org.elasticsearch.common.joda.JodaDeprecationPatterns
-
Checks if date parsing pattern is deprecated.
- isDesktopServicesStore(Path) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Check whether the file denoted by the given path is a desktop services store created by Finder on macOS.
- isDimension() - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- isDimension() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- isDimension() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- isDimension() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- isDirty() - Method in exception org.elasticsearch.gateway.WriteStateException
-
If this method returns false, state is guaranteed to be not written to disk.
- isDone() - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
- isDryRun() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- isDryRun() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
-
Returns if the rollover execution was skipped even when conditions were met
- isDynamic() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting is dynamically updateable, otherwisefalse
- isDynamicSetting(String) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Returns
true
if the setting for the given key is dynamically updateable. - isEagerSingleton(Stage) - Method in class org.elasticsearch.common.inject.internal.Scoping
-
Returns true if this scope is a singleton that should be loaded eagerly in
stage
. - isEdgefromPolygon(int) - Method in class org.apache.lucene.geo.XTessellator.Triangle
-
get if edge is shared with the polygon for the given edge
- isElectionQuorum(CoordinationState.VoteCollection) - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- isElectionQuorum(DiscoveryNode, long, long, long, CoordinationMetadata.VotingConfiguration, CoordinationMetadata.VotingConfiguration, CoordinationState.VoteCollection) - Method in class org.elasticsearch.cluster.coordination.ElectionStrategy
-
Whether there is an election quorum from the point of view of the given local node under the provided voting configurations
- isEmpty() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- isEmpty() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfiguration
- isEmpty() - Method in class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- isEmpty() - Method in class org.elasticsearch.cluster.metadata.Manifest
- isEmpty() - Method in class org.elasticsearch.cluster.RestoreInProgress
- isEmpty() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- isEmpty() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Returns
true
iff this collection contains one or more non-ignored unassigned shards. - isEmpty() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- isEmpty() - Method in class org.elasticsearch.common.collect.EvictingQueue
- isEmpty() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- isEmpty() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- isEmpty() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- isEmpty() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- isEmpty() - Method in class org.elasticsearch.common.collect.MapBuilder
- isEmpty() - Method in class org.elasticsearch.common.settings.Settings
-
Returns
true
if this settings object contains no settings - isEmpty() - Method in class org.elasticsearch.common.util.LazyMap
- isEmpty() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan.SnapshotFilesToRecover
- isEmpty() - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- isEmpty() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
- isEmpty() - Method in class org.elasticsearch.repositories.IndexMetaDataGenerations
- isEmpty() - Method in class org.elasticsearch.script.DynamicMap
- isEmpty() - Method in class org.elasticsearch.script.field.EmptyField
- isEmpty() - Method in interface org.elasticsearch.script.field.Field
-
Returns
true
if this field has no values, otherwisefalse
. - isEmpty() - Method in class org.elasticsearch.script.ScriptContextStats.TimeSeries
- isEmpty() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- isEmpty() - Method in class org.elasticsearch.search.lookup.FieldLookup
- isEmpty() - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- isEmpty() - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- isEmpty() - Method in class org.elasticsearch.search.lookup.SourceLookup
- isEmpty(CharSequence) - Static method in class org.elasticsearch.common.Strings
-
Check that the given CharSequence is either
null
or of length 0. - isEmpty(Object[]) - Static method in class org.elasticsearch.common.util.CollectionUtils
-
Checks if the given array contains any elements.
- isEnabled() - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdSettings
- isEnabled() - Method in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper
- isEnabled() - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- isEnabled() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- isEnabled() - Static method in class org.elasticsearch.rollup.RollupV2
- isEnabled() - Method in class org.elasticsearch.transport.RemoteClusterService
- isEnabled(String) - Method in class org.elasticsearch.common.lucene.LoggerInfoStream
- isEnabledByDefault(Settings) - Method in class org.elasticsearch.cluster.node.DiscoveryNodeRole
- isEnableGcDeletes() - Method in class org.elasticsearch.index.engine.EngineConfig
-
Returns
true
iff delete garbage collection in the engine should be enabled. - isEOS() - Method in class org.elasticsearch.transport.DeflateTransportDecompressor
- isEqual(ChronoZonedDateTime<?>) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- isError(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- isExecuting() - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- isExecutorShutdown() - Method in exception org.elasticsearch.common.util.concurrent.EsRejectedExecutionException
-
Checks if the thread pool that rejected the execution was terminated shortly after the rejection.
- isExists() - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistResponse
- isExists() - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsResponse
- isExists() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsResponse
- isExists() - Method in class org.elasticsearch.action.explain.ExplainResponse
- isExists() - Method in class org.elasticsearch.action.get.GetResponse
-
Does the document exists.
- isExists() - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- isExists() - Method in class org.elasticsearch.index.get.GetResult
-
Does the document exist.
- isExpired() - Method in class org.elasticsearch.search.internal.ReaderContext
- isExplain() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- isExplicitAllType(String[]) - Static method in class org.elasticsearch.cluster.metadata.Metadata
-
Identifies whether the array containing type names given as argument explicitly refers to all types The empty or null array doesn't explicitly map to all types
- isExplicitDataTier(Settings) - Static method in class org.elasticsearch.cluster.routing.allocation.DataTier
-
Returns true iff the given settings have a data tier setting configured
- isExplicitlyScoped() - Method in class org.elasticsearch.common.inject.internal.Scoping
-
Returns true if this scope was explicitly applied.
- isExplicitRefresh() - Method in class org.elasticsearch.index.IndexSettings
-
Returns true iff the refresh setting exists or in other words is explicitly set.
- isExternal() - Method in class org.elasticsearch.indices.SystemDataStreamDescriptor
- isExternal() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- isExternal() - Method in enum class org.elasticsearch.indices.SystemIndexDescriptor.Type
- isFailed() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
-
Returns true if there is at least one failed response.
- isFailed() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
-
Is this a failed execution of an operation.
- isFailed() - Method in class org.elasticsearch.action.get.MultiGetItemResponse
-
Is this a failed execution?
- isFailed() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
-
Is this a failed execution?
- isFailure() - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
-
Is it a failed search?
- isFailure() - Method in class org.elasticsearch.bootstrap.BootstrapCheck.BootstrapCheckResult
- isFieldMapped(String) - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Returns true if the field identified by the provided name is mapped, false otherwise
- isFieldMapped(String) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Returns true if the field identified by the provided name is mapped, false otherwise
- isFieldMapped(String) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- isFieldWithinQuery(long, long, Object, Object, boolean, boolean, ZoneId, DateMathParser, QueryRewriteContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- isFieldWithinQuery(IndexReader, Object, Object, boolean, boolean, ZoneId, DateMathParser, QueryRewriteContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- isFieldWithinQuery(IndexReader, Object, Object, boolean, boolean, ZoneId, DateMathParser, QueryRewriteContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Return whether all values of the given
IndexReader
are within the range, outside the range or cross the range. - isFiltered() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting must be filtered, otherwisefalse
- isFinal() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting is final, otherwisefalse
- isFinalReduce() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
-
Returns
true
iff the current reduce phase is the final reduce phase. - isFinalSetting(String) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Returns
true
if the setting for the given key is final. - isFinishElectionTask() - Method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor.Task
- isFloatingPoint() - Method in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- isFloatingPoint() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashCellIdSource
- isFloatingPoint() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileCellIdSource
- isFloatingPoint() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
- isFloatingPoint() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
-
Are values of this field better represented as a double precision floating point numbers (
true
) or 64 bit signed numbers (false
)? - isFloatingPoint() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
- isFloatingPoint() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
- isForceExecution() - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
-
Should the runnable force its execution in case it gets rejected?
- isForceExecution() - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- isFound() - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- isFound() - Method in class org.elasticsearch.index.engine.Engine.DeleteResult
- isFragment() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- isFragment() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- isFragment() - Method in class org.elasticsearch.index.seqno.RetentionLease
- isFragment() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- isFragment() - Method in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- isFragment() - Method in class org.elasticsearch.upgrades.SingleFeatureMigrationResult
- isFreed() - Method in class org.elasticsearch.action.search.SearchTransportService.SearchFreeContextResponse
- isFresh(Key, Key) - Method in class org.elasticsearch.common.util.CancellableSingleObjectCache
-
Compute whether the
currentKey
is fresh enough for a retrieval associated withnewKey
. - isFromDynamicTemplate() - Method in class org.elasticsearch.index.mapper.MappingParserContext
-
true if this pars context is coming from parsing dynamic template mappings
- isFrozenNode(Set<DiscoveryNodeRole>) - Static method in class org.elasticsearch.cluster.routing.allocation.DataTier
- isFrozenNode(DiscoveryNode) - Static method in class org.elasticsearch.cluster.routing.allocation.DataTier
- isFullySpecified() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
- isFullySpecified() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- isFullySpecified() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
- isGeneralCompilationRateSet - Variable in class org.elasticsearch.script.ScriptService.ContextSettings
- isGlobalGenerationMissing() - Method in class org.elasticsearch.cluster.metadata.Manifest
- isGlobalStateEquals(Metadata, Metadata) - Static method in class org.elasticsearch.cluster.metadata.Metadata
- isHardLimit() - Method in class org.elasticsearch.common.lucene.search.SpanBooleanQueryRewriteWithMaxClause
- isHeadless() - Method in class org.elasticsearch.bootstrap.plugins.LoggerTerminal
- isHeldByCurrentThread() - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
- isHeldByCurrentThread(T) - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
-
Returns
true
iff the caller thread holds the lock for the given key - isHidden() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
- isHidden() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- isHidden() - Method in class org.elasticsearch.cluster.metadata.AliasAction.Add
- isHidden() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- isHidden() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- isHidden() - Method in class org.elasticsearch.cluster.metadata.DataStream
- isHidden() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- isHidden() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.ConcreteIndex
- isHidden() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- isHidden() - Method in interface org.elasticsearch.cluster.metadata.IndexAbstraction
- isHidden() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- isHidden(Boolean) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Sets whether this alias is hidden
- isHidden(Boolean) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- isHidden(Boolean) - Method in class org.elasticsearch.cluster.metadata.AliasMetadata.Builder
- isHidden(Path) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Check whether the file denoted by the given path is hidden.
- isHighlighted() - Method in class org.apache.lucene.search.uhighlight.Snippet
- isHotNode(DiscoveryNode) - Static method in class org.elasticsearch.cluster.routing.allocation.DataTier
- isHybridFs(Directory) - Static method in class org.elasticsearch.index.store.FsDirectoryFactory
-
Returns true iff the directory is a hybrid fs directory
- isIdFieldDataEnabled() - Method in class org.elasticsearch.index.mapper.MappingParserContext
- isIdFieldDataEnabled() - Method in class org.elasticsearch.indices.IndicesService
- isIgnoredEmpty() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Returns
true
iff any unassigned shards are marked as temporarily ignored. - isIgnoreFailure() - Method in class org.elasticsearch.ingest.CompoundProcessor
- isIgnoreMalformed(GeoValidationMethod) - Static method in enum class org.elasticsearch.index.query.GeoValidationMethod
-
Returns whether or not to skip bounding box validation.
- isIgnoreUnmapped() - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Whether to include inner hits in the search response hits if required mappings is missing
- isImplicitContextCacheSet(Settings) - Static method in class org.elasticsearch.script.ScriptService
- isIncludeInParent() - Method in class org.elasticsearch.index.mapper.NestedObjectMapper
- isIncludeInRoot() - Method in class org.elasticsearch.index.mapper.NestedObjectMapper
- isIndexVerifiedBeforeClosed(IndexMetadata) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexStateService
- isIndexVisible(String, String, IndicesOptions, Metadata, IndexNameExpressionResolver, boolean) - Static method in class org.elasticsearch.cluster.metadata.IndexAbstractionResolver
- isIndexVisible(String, String, IndicesOptions, Metadata, IndexNameExpressionResolver, boolean, boolean) - Static method in class org.elasticsearch.cluster.metadata.IndexAbstractionResolver
- isIndicesOptions(String) - Static method in class org.elasticsearch.action.support.IndicesOptions
-
Returns true if the name represents a valid name for one of the indices option false otherwise
- isInefficientUnion() - Method in class org.elasticsearch.search.aggregations.bucket.filter.QueryToFilterAdapter
-
Is this an inefficient union of the top level query with the filter? If the top level query if complex we can't efficiently merge it with the filter.
- isInetAddress(String) - Static method in class org.elasticsearch.common.network.InetAddresses
- isIngestNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Returns a boolean that tells whether this an ingest node or not
- isIngestNode(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
- isInitialConfigurationSet() - Method in class org.elasticsearch.cluster.coordination.Coordinator
- isInnerClass(Class<?>) - Static method in class org.elasticsearch.common.Classes
- isInRange(String, String...) - Static method in class org.elasticsearch.common.network.CIDRUtils
- isInSortOrderExecutionRequired() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Return true if any of the child aggregations is a time-series aggregation that requires an in-order execution
- isInSync() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
-
Returns
true
if the shard copy is in-sync and contains the latest data. - isInterleavedSegment(LeafReader) - Static method in class org.apache.lucene.index.ShuffleForcedMergePolicy
-
Return
true
if the provided reader was merged with interleaved segments. - isInternal() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- isInternal() - Method in enum class org.elasticsearch.indices.SystemIndexDescriptor.Type
- isInternalIndex() - Method in class org.elasticsearch.common.settings.Setting
- isJodaPattern(Version, String) - Static method in class org.elasticsearch.common.joda.Joda
-
Deprecated.Checks if a pattern is Joda-style.
- isKeyAsc(BucketOrder) - Static method in class org.elasticsearch.search.aggregations.InternalOrder
-
Determine if the ordering strategy is sorting on bucket key ascending.
- isKeyDesc(BucketOrder) - Static method in class org.elasticsearch.search.aggregations.InternalOrder
-
Determine if the ordering strategy is sorting on bucket key descending.
- isKeyed() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- isKeyed() - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- isKeyOrder(BucketOrder) - Static method in class org.elasticsearch.search.aggregations.InternalOrder
-
Determine if the ordering strategy is sorting on bucket key (ascending or descending).
- isKnownRole() - Method in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
Whether this role is known by this node, or is an
DiscoveryNodeRole.UnknownRole
. - isKnownWord(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
- isKnownWord(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- isKnownWord(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.MultiCandidateGeneratorWrapper
- isLangSupported(String) - Method in class org.elasticsearch.script.ScriptService
- isLeader() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Returns true if this task is a leader for other slice subtasks
- isLicensed() - Method in class org.elasticsearch.plugins.PluginDescriptor
-
Whether this plugin is subject to the Elastic License.
- isLoaded() - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
- isLoaded() - Method in interface org.elasticsearch.common.settings.SecureSettings
-
Returns true iff the settings are loaded and retrievable.
- isLocalAbortSupported() - Method in class org.elasticsearch.persistent.PersistentTasksService
-
Is the cluster able to support locally aborting persistent tasks? This requires that every node in the cluster is on version
CompletionPersistentTaskAction.LOCAL_ABORT_AVAILABLE_VERSION
or above. - isLocalAbortSupported(ClusterState) - Static method in class org.elasticsearch.persistent.PersistentTasksService
- isLocalNodeElectedMaster() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- isLocalNodeElectedMaster() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns
true
if the local node is the elected master node. - isLogicallyEquivalent(String) - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshot
- isLZ4(BytesReference) - Static method in enum class org.elasticsearch.transport.Compression.Scheme
- isManaged() - Method in enum class org.elasticsearch.indices.SystemIndexDescriptor.Type
- isMapped() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
- isMapped() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- isMapped() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- isMapped() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- isMapped() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Return true if this aggregation is mapped, and can lead a reduction.
- isMappingSourceTyped(String, Map<String, Object>) - Static method in class org.elasticsearch.index.mapper.MapperService
-
Returns
true
if the givenmappingSource
includes a type as a top-level object. - isMappingSourceTyped(String, CompressedXContent) - Static method in class org.elasticsearch.index.mapper.MapperService
- isMarkedCorrupted() - Method in class org.elasticsearch.index.store.Store
- isMasterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Can this node become master or not.
- isMasterNode(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
- isMasterUpdateThread() - Static method in class org.elasticsearch.cluster.service.MasterService
- isMatch() - Method in class org.elasticsearch.action.explain.ExplainResponse
- isMatchAll(String[]) - Static method in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
- isMatchAllPattern(String) - Static method in class org.elasticsearch.common.regex.Regex
- isMemoryLocked() - Static method in class org.elasticsearch.bootstrap.BootstrapInfo
-
Returns true if we were able to lock the process's address space.
- isMetadata() - Method in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- isMetadatafield() - Method in class org.elasticsearch.action.fieldcaps.IndexFieldCapabilities
- isMetadataField() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
Whether this field is a metadata field.
- isMetadataField(String) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
-
Returns
true
if the provided field is a metadata field. - isMetadataField(String) - Method in class org.elasticsearch.index.mapper.MapperService
- isMetadataField(String) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- isMlockall() - Method in class org.elasticsearch.monitor.process.ProcessInfo
- isMultiField(String) - Method in class org.elasticsearch.index.mapper.MappingLookup
- isMultiValueAllowed() - Method in class org.elasticsearch.rest.RestHeaderDefinition
- isMultiValued(SortedSetDocValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns whether the provided values *might* be multi-valued.
- isNativesAvailable() - Static method in class org.elasticsearch.bootstrap.BootstrapInfo
-
Returns true if we successfully loaded native libraries.
- isNested() - Method in class org.elasticsearch.index.mapper.NestedObjectMapper
- isNested() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- isNetNew() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- isNetNewSystemIndex(String) - Method in class org.elasticsearch.indices.SystemIndices
-
Checks whether an index is a net-new system index, meaning we can apply non-BWC behavior to it.
- isNewCluster() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Determines whether or not the current cluster state represents an entirely new cluster, either when a node joins a cluster for the first time or when the node receives a cluster state update from a brand new cluster (different UUID from the previous cluster), which will happen when a master node is elected that has never been part of the cluster before.
- isNonZeroSize() - Method in class org.elasticsearch.common.unit.RelativeByteSizeValue
- isNoop() - Method in class org.elasticsearch.search.aggregations.LeafBucketCollector
-
Does this collector collect anything? If this returns true we can safely just never call
LeafBucketCollector.collect(int, long)
. - isNoop() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingLeafBucketCollector
- isNoScope() - Method in class org.elasticsearch.common.inject.internal.Scoping
-
Returns true if this is the default scope.
- isNotA(ValueType) - Method in enum class org.elasticsearch.search.aggregations.support.ValueType
- isNull() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetadata
- isNull() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns true if the result doesn't contain any useful information.
- isNullable() - Method in class org.elasticsearch.common.inject.spi.Dependency
-
Returns true if null is a legal value for this dependency.
- isNullOrEmpty(String) - Static method in class org.elasticsearch.common.Strings
- isNumeric() - Method in enum class org.elasticsearch.index.mapper.RangeType
- ISO8601 - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- isObject(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- isObjectField(String) - Method in class org.elasticsearch.index.mapper.MappingLookup
- IsoCalendarDataProvider - Class in org.elasticsearch.common.time
-
This class is loaded by JVM SPI mechanism in order to provide ISO compatible behaviour for week calculations using java.time.
- IsoCalendarDataProvider() - Constructor for class org.elasticsearch.common.time.IsoCalendarDataProvider
- ISOLATED - Enum constant in enum class org.elasticsearch.plugins.PluginType
- isOnlyAttributeValueFilter() - Method in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
- isOpen() - Method in interface org.elasticsearch.common.network.CloseableChannel
-
Indicates whether a channel is currently open
- isOpen() - Method in class org.elasticsearch.gateway.PersistedClusterStateService.Writer
- isOpen() - Method in class org.elasticsearch.index.translog.Translog
-
Returns
true
if thisTranslog
is still open. - isOperatorOnly() - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
if this setting is dynamically updateable by operators, otherwisefalse
- isOptional() - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
-
Returns true if this injection point shall be skipped if the injector cannot resolve bindings for all required dependencies.
- isOriginAllowed(String) - Method in class org.elasticsearch.http.CorsHandler.Config
- isPartialSearchableSnapshotIndex(Map<Setting<?>, Object>) - Static method in class org.elasticsearch.snapshots.SearchableSnapshotsSettings
-
Based on a map from setting to value, do the settings represent a partial searchable snapshot index? Both index.store.type and index.store.snapshot.partial must be supplied.
- isPartialSearchableSnapshotIndex(Settings) - Static method in class org.elasticsearch.snapshots.SearchableSnapshotsSettings
- isPartitionBased() - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- isPhase1() - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction.ShardRequest
- isPing() - Method in class org.elasticsearch.transport.InboundMessage
- isPipelineResolved() - Method in class org.elasticsearch.action.index.IndexRequest
-
Returns whether or not the pipeline for this request has been resolved by the coordinating node.
- isPipelineResolved(boolean) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets if the pipeline for this request has been resolved by the coordinating node.
- isPositiveNumeric(String) - Static method in class org.elasticsearch.common.Numbers
-
Checks if the given string can be parsed as a positive integer value.
- isPrefix - Variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- isPrefix() - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext
-
Returns if the context should be treated as a prefix
- isPreserveDataStreams() - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.Context
- isPreserveExisting() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
-
Returns
true
iff the settings update should only add but not update settings. - isPreserveExisting() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Returns
true
iff the settings update should only add but not update settings. - isPrimary() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Returns
true
if explaining the primary shard for the shard id (seeClusterAllocationExplainRequest.getShard()
),false
if explaining a replica shard copy for the shard id, ornull
to use any unassigned shard (seeClusterAllocationExplainRequest.useAnyUnassignedShard()
). - isPrimary() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
-
Returns
true
if the explained shard is primary,false
otherwise. - isPrimaryActive() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- isPrimaryMode() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Returns whether the replication tracker is in primary mode, i.e., whether the current shard is acting as primary from the point of view of replication.
- isPrimaryRelocation() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- isPrivate() - Method in interface org.elasticsearch.cluster.ClusterState.Custom
-
Returns
true
iff thisClusterState.Custom
is private to the cluster and should never be send to a client. - isPrivateIndex() - Method in class org.elasticsearch.common.settings.Setting
- isPrivateSetting(String) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Returns
true
iff the setting is a private setting ie. - isPrivateSetting(String) - Method in class org.elasticsearch.common.settings.IndexScopedSettings
- isProductionRelease() - Method in class org.elasticsearch.Build
-
Provides information about the intent of the build
- isProxyAction(String) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Returns
true
iff the given action is a proxy action - isProxyRequest(TransportRequest) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Returns
true
iff the given request is a proxy request - isPublishQuorum(CoordinationState.VoteCollection) - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- isPublishQuorum(CoordinationState.VoteCollection) - Method in class org.elasticsearch.cluster.coordination.Publication
- isQueryStringAllowLeadingWildcard() - Method in class org.elasticsearch.index.IndexSettings
-
Returns
true
if the query string parser should allow leading wildcards. - isQueryStringAnalyzeWildcard() - Method in class org.elasticsearch.index.IndexSettings
-
Returns
true
if the query string should analyze wildcards. - isQueryStringLenient() - Method in class org.elasticsearch.index.IndexSettings
-
Returns
true
if query string parsing should be lenient. - isQuorum(CoordinationMetadata.VotingConfiguration) - Method in class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- isRawIndexingData() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- isRawIndexingData() - Method in interface org.elasticsearch.transport.RawIndexingDataTransportRequest
- isRC() - Method in class org.elasticsearch.Version
- isReadAllowed() - Method in class org.elasticsearch.index.shard.IndexShard
-
returns true if the
IndexShardState
allows reading - isReadFromTranslog() - Method in class org.elasticsearch.index.engine.Engine.Get
- isReadOnly() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- isReadOnly() - Method in class org.elasticsearch.repositories.FilterRepository
- isReadOnly() - Method in interface org.elasticsearch.repositories.Repository
-
Returns true if the repository supports only read operations
- isReadOverrideException(Exception) - Static method in class org.elasticsearch.action.support.TransportActions
-
If a failure is already present, should this failure override it or not for read operations.
- isRecovery() - Method in enum class org.elasticsearch.index.engine.Engine.Operation.Origin
- isRecycled() - Method in class org.elasticsearch.common.recycler.NoneRecycler.NV
- isRecycled() - Method in interface org.elasticsearch.common.recycler.Recycler.V
-
Whether this instance has been recycled (true) or newly allocated (false).
- isRefresh() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Call refresh on the indexes we've written to after the request ends?
- isRegexBased() - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- isRegistered(Class<? extends Throwable>, Version) - Static method in exception org.elasticsearch.ElasticsearchException
-
Returns
true
iff the given class is a registered for an exception to be read. - isRegistered(ValuesSourceRegistry.RegistryKey<?>) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry
- isRelease() - Method in class org.elasticsearch.Version
- isRelocated() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Returns whether the replication tracker has relocated away to another shard copy.
- isRelocatedPrimary() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns whether the shard is a relocated primary, i.e.
- isRelocationSourceOf(ShardRouting) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
returns true if the routing is the relocation source for the given routing
- isRelocationTarget() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns
true
if this shard is a relocation target for another shard (i.e., was created withShardRouting.initializeTargetRelocatingShard()
- isRelocationTargetOf(ShardRouting) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
returns true if the routing is the relocation target of the given routing
- isRemoteClusterClient() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
-
Returns whether or not the node can be a remote cluster client.
- isRemoteClusterClient(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
- isReplacement() - Method in class org.elasticsearch.rest.RestHandler.Route
- isReplicated() - Method in class org.elasticsearch.cluster.metadata.DataStream
-
Determines whether this data stream is replicated from elsewhere, for example a remote cluster.
- isRequest(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- isRequireAlias() - Method in class org.elasticsearch.action.delete.DeleteRequest
- isRequireAlias() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Should this request override specifically require the destination to be an alias?
- isRequireAlias() - Method in class org.elasticsearch.action.index.IndexRequest
- isRequireAlias() - Method in class org.elasticsearch.action.update.UpdateRequest
- isRescored(int) - Method in class org.elasticsearch.search.rescore.RescoreContext
- isResetCookies() - Method in class org.elasticsearch.http.HttpHandlingSettings
- isResultDeterministic() - Method in interface org.elasticsearch.script.ScriptFactory
-
Returns
true
if the result of the script will be deterministic,false
otherwise. - isRetainedAtRuntime(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.internal.Annotations
-
Returns true if the given annotation is retained at runtime.
- isRetry() - Method in class org.elasticsearch.action.index.IndexRequest
-
Returns
true
if this request has been sent to a shard copy more than once. - isRetry() - Method in class org.elasticsearch.index.engine.Engine.Index
-
Returns
true
if this index requests has been retried on the coordinating node and can therefor be delivered multiple times. - isRetryFailed() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Returns the current retry failed flag
- isRolledOver() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
-
Returns true if the rollover was not simulated and the conditions were met
- isRoutingPartitionedIndex() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- isRunning() - Method in class org.elasticsearch.cluster.coordination.ClusterFormationFailureHelper
- isRunning() - Method in class org.elasticsearch.common.StopWatch
-
Return whether the stop watch is currently running.
- isRuntimeMapping() - Method in class org.elasticsearch.index.mapper.DynamicTemplate
- isSame(BlobStoreIndexShardSnapshot.FileInfo) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Checks if a file in a store is the same file
- isSame(SnapshotFiles) - Method in class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
-
Checks if the given other instance contains the same files as well as the same
SnapshotFiles.shardStateIdentifier
. - isSame(StoreFileMetadata) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Checks if a file in a store is the same file
- isSame(StoreFileMetadata) - Method in class org.elasticsearch.index.store.StoreFileMetadata
-
Returns
true
iff the length and the checksums are the same. - isSameAllocation(ShardRouting) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
returns true if this routing has the same allocation ID as another.
- isSameUUID(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Test whether the current index UUID is the same as the given one.
- isScheduled() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- isScopeAnnotation(Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.internal.Annotations
- isSearch() - Method in class org.elasticsearch.index.engine.Segment
- isSearchable() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
Whether this field is indexed for search on all indices.
- isSearchable() - Method in class org.elasticsearch.action.fieldcaps.IndexFieldCapabilities
- isSearchable() - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- isSearchable() - Method in class org.elasticsearch.index.mapper.ConstantFieldType
- isSearchable() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns true if the field is searchable.
- isSearchableSnapshotStore(Settings) - Static method in class org.elasticsearch.snapshots.SearchableSnapshotsSettings
- isSearchIdle() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns true if this shards is search idle
- isSearchThrottled() - Method in class org.elasticsearch.index.IndexSettings
-
Returns true if the this index should be searched throttled ie.
- isSecure() - Method in interface org.elasticsearch.transport.Transport
- isSecure(Settings) - Method in class org.elasticsearch.common.settings.Setting
-
Checks whether this is a secure setting.
- isSeqNoAndPrimaryTerm() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- isSerialized() - Method in class org.elasticsearch.common.io.stream.DelayableWriteable
- isSerialized() - Method in class org.elasticsearch.common.io.stream.DelayableWriteable.Serialized
- isServerChannel() - Method in interface org.elasticsearch.transport.TcpChannel
-
Indicates if the channel is an inbound server channel.
- isSet() - Method in class org.elasticsearch.tasks.TaskId
- isSet(CommonStatsFlags.Flag) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- isShadowed(String) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- isShadowed(String) - Method in class org.elasticsearch.index.mapper.MappingLookup
- isShardNotAvailableException(Throwable) - Static method in class org.elasticsearch.action.support.TransportActions
- isShardsAcknowledged() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
- isShardsAcknowledged() - Method in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
-
Returns true if the requisite number of shards were started before returning from the index creation operation.
- isShortCircuit() - Method in class org.elasticsearch.transport.InboundMessage
- isSimpleMatchPattern(String) - Static method in class org.elasticsearch.common.regex.Regex
-
Is the str a simple match pattern.
- isSingleNodeDiscovery(Settings) - Static method in class org.elasticsearch.discovery.DiscoveryModule
- isSingleRepositoryRequest() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- isSingleRepositoryRequest() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotRequest
- isSkipDuplicates() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionContext
- isSkippable - Variable in enum class org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
- isSkipUnavailable() - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- isSkipUnavailable(String) - Method in class org.elasticsearch.transport.RemoteClusterService
-
Returns whether the cluster identified by the provided alias is configured to be skipped when unavailable
- isSnapshot() - Method in class org.elasticsearch.Build
- isSoftDeleteEnabled() - Method in class org.elasticsearch.index.IndexSettings
-
Returns
true
if soft-delete is enabled. - isSourceEmpty() - Method in class org.elasticsearch.action.get.GetResponse
-
Is the source empty (not available) or not.
- isSourceEmpty() - Method in class org.elasticsearch.index.get.GetResult
-
Is the source empty (not available) or not.
- isSourceEnabled() - Method in class org.elasticsearch.index.mapper.MappingLookup
- isSourceEnabled() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- isSpecificShard() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
- isStopped() - Method in class org.elasticsearch.repositories.RepositoryInfo
- isStored() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns true if the field is stored separately.
- isSubAction() - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- isSubAction() - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
-
Tells whether the action is a main one or a subaction.
- isSubAction() - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- isSucceeded() - Method in class org.elasticsearch.action.search.ClearScrollResponse
- isSuccess() - Method in class org.elasticsearch.bootstrap.BootstrapCheck.BootstrapCheckResult
- isSuccess() - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.TaskResult
- isSuggestOnly() - Method in class org.elasticsearch.action.search.SearchRequest
- isSuggestOnly() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- isSummary() - Method in class org.elasticsearch.action.ingest.GetPipelineRequest
- isSummary() - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- isSupported(TemporalField) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- isSupported(TemporalUnit) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- isSyncNeeded() - Method in class org.elasticsearch.index.shard.IndexShard
-
Checks if the underlying storage sync is required.
- isSynthetic() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
- isSystem() - Method in class org.elasticsearch.cluster.metadata.DataStream
- isSystem() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.Alias
- isSystem() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.ConcreteIndex
- isSystem() - Method in class org.elasticsearch.cluster.metadata.IndexAbstraction.DataStream
- isSystem() - Method in interface org.elasticsearch.cluster.metadata.IndexAbstraction
- isSystem() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- isSystem() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- isSystem() - Method in class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService.CreateDataStreamClusterStateUpdateRequest
- isSystem() - Method in class org.elasticsearch.index.shard.IndexShard
- isSystemCallFilterInstalled() - Static method in class org.elasticsearch.bootstrap.BootstrapInfo
-
Returns true if system call filter is installed (supported systems only)
- isSystemContext() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Returns
true
iff this context is a system context - isSystemDataStream(String) - Method in class org.elasticsearch.indices.SystemIndices
-
Determines whether the provided name matches that of a system data stream that has been defined by a
SystemDataStreamDescriptor
- isSystemIndex(String) - Method in class org.elasticsearch.indices.SystemIndices
-
Determines whether a given index is a system index by comparing its name to the collection of loaded
SystemIndexDescriptor
s. - isSystemIndex(Index) - Method in class org.elasticsearch.indices.SystemIndices
-
Determines whether a given index is a system index by comparing its name to the collection of loaded
SystemIndexDescriptor
s - isSystemIndexBackingDataStream(String) - Method in class org.elasticsearch.indices.SystemIndices
-
Determines whether the provided name matches that of an index that backs a system data stream.
- isSystemName(String) - Method in class org.elasticsearch.indices.SystemIndices
-
Checks whether the given name matches a reserved name or pattern that is intended for use by a system component.
- isSystemShard(ShardId) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- isTempBlobName(String) - Static method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
-
Returns true if the blob is a leftover temporary blob.
- isTerminatedEarly() - Method in class org.elasticsearch.action.search.SearchResponse
-
Has the search operation terminated early due to reaching
terminateAfter
- isThreadAllocatedMemoryEnabled() - Method in class org.elasticsearch.monitor.jvm.SunThreadInfo
- isThreadAllocatedMemorySupported() - Method in class org.elasticsearch.monitor.jvm.SunThreadInfo
- isThrottled() - Method in class org.elasticsearch.index.engine.Engine
-
Returns the
true
iff this engine is currently under index throttling. - isThrottled() - Method in class org.elasticsearch.index.engine.InternalEngine
- isThrottled() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- isThrottled() - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
-
Returns if the index is under merge throttling control
- isTimedOut() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
-
true
if the waitForXXX has timeout out and did not match. - isTimedOut() - Method in class org.elasticsearch.action.search.SearchResponse
-
Has the search operation timed out.
- isTimedOut() - Method in class org.elasticsearch.cluster.ClusterStateObserver
-
indicates whether this observer has timed out
- isTimedOut() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
-
Did any of the sub-requests that were part of this request timeout?
- isTimedOut() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.Response
-
Did this batch time out?
- isTokenized() - Method in class org.elasticsearch.index.mapper.TextSearchInfo
- isTrackScores() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- isTranslogSyncNeeded() - Method in class org.elasticsearch.index.engine.Engine
-
Checks if the underlying storage sync is required.
- isTranslogSyncNeeded() - Method in class org.elasticsearch.index.engine.InternalEngine
- isTranslogSyncNeeded() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- isTransportClient() - Method in class org.elasticsearch.common.network.NetworkModule
- isTransportSecure() - Method in class org.elasticsearch.transport.TransportService
- isTransportThread(Thread) - Static method in enum class org.elasticsearch.transport.Transports
-
Utility method to detect whether a thread is a network thread.
- isTranspositions() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
-
Returns if transpositions option is set if transpositions is set, then swapping one character for another counts as one edit instead of two.
- isTypeEnabled(ScriptType) - Method in class org.elasticsearch.script.ScriptService
- isTypeless() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- isTypeless() - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- isUnbounded() - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- isUnicodeAware() - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
-
Returns if all measurements (like edit distance, transpositions and lengths) are in unicode code points (actual letters) instead of bytes.
- isUseContextCacheSet(Settings) - Static method in class org.elasticsearch.script.ScriptService
- isValid() - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- isValid() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
-
A boolean denoting whether the query is valid.
- isValidActionName(String) - Static method in class org.elasticsearch.transport.TransportService
-
Returns
true
iff the action name starts with a valid prefix. - isValidDouble(double) - Static method in class org.elasticsearch.common.Numbers
-
Returns true if value is neither NaN nor infinite.
- isValidKey(String) - Static method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Returns
true
iff the given key is a valid settings key otherwisefalse
- isValidLatitude(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Returns true if latitude is actually a valid latitude value.
- isValidLongitude(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Returns true if longitude is actually a valid longitude value.
- isValidPattern(String) - Static method in class org.elasticsearch.common.settings.SettingsFilter
-
Returns
true
iff the given string is either a valid settings key pattern or a simple regular expression - isVerbose() - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- isVerbose() - Method in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- isVersion() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- isVersionConflictForReads(long, long) - Method in enum class org.elasticsearch.index.VersionType
-
Checks whether the current version conflicts with the expected version, based on the current version type.
- isVersionConflictForWrites(long, long, boolean) - Method in enum class org.elasticsearch.index.VersionType
-
Checks whether the current version conflicts with the expected version, based on the current version type.
- isWaitForTimedOut() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
-
Returns whether the request timed out waiting for a cluster state with a metadata version equal or higher than the specified metadata.
- isWarmerEnabled() - Method in class org.elasticsearch.index.IndexSettings
-
Returns true if index warmers are enabled, otherwise
false
- isWarmNode(DiscoveryNode) - Static method in class org.elasticsearch.cluster.routing.allocation.DataTier
- isWeightRanked() - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
-
Is the weight assigned for the node?
- isWithinCopyTo() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- isWithinMultiField() - Method in class org.elasticsearch.index.mapper.MappingParserContext
- isWithinMultiFields() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- isWorker() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Returns true if this task is a worker task that performs search requests.
- isZen1Node(DiscoveryNode) - Static method in class org.elasticsearch.cluster.coordination.Coordinator
- Item() - Constructor for class org.elasticsearch.action.get.MultiGetRequest.Item
- Item() - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- Item(String, String) - Constructor for class org.elasticsearch.action.get.MultiGetRequest.Item
- Item(String, String) - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
Constructor for a given item / document request
- Item(String, String, String) - Constructor for class org.elasticsearch.action.get.MultiGetRequest.Item
-
Deprecated.Types are in the process of being removed, use
instead
. - Item(String, String, String) - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
Deprecated.Types are in the process of being removed, use
Item(java.lang.String,java.lang.String)
instead. - Item(String, String, XContentBuilder) - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
Deprecated.Types are in the process of being removed, use
Item(java.lang.String,org.elasticsearch.xcontent.XContentBuilder)
instead. - Item(String, XContentBuilder) - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
Constructor for an artificial document request, that is not present in the index.
- Item(SearchResponse, Exception) - Constructor for class org.elasticsearch.action.search.MultiSearchResponse.Item
- Item(StreamInput) - Constructor for class org.elasticsearch.action.get.MultiGetRequest.Item
- items() - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- ItemUsage - Class in org.elasticsearch.cluster.metadata
-
A class encapsulating the usage of a particular "thing" by something else
- ItemUsage(Collection<String>, Collection<String>, Collection<String>) - Constructor for class org.elasticsearch.cluster.metadata.ItemUsage
-
Create a new usage, a
null
value indicates that the item *cannot* be used by the thing, otherwise use an empty collection to indicate no usage. - ItemUsage(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.ItemUsage
- Iter(double[], double[]) - Constructor for class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket.Iter
- Iter(double[], TDigestState) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks.Iter
- Iter(double[], TDigestState) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles.Iter
- Iter(double[], DoubleHistogram) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks.Iter
- Iter(double[], DoubleHistogram) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles.Iter
- iterableAsArrayList(Iterable<? extends E>) - Static method in class org.elasticsearch.common.util.CollectionUtils
- Iterables - Class in org.elasticsearch.common.util.iterable
- Iterables() - Constructor for class org.elasticsearch.common.util.iterable.Iterables
- iterate(PortsRange.PortCallback) - Method in class org.elasticsearch.common.transport.PortsRange
- iterator() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
- iterator() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
- iterator() - Method in class org.elasticsearch.action.admin.indices.segments.IndexSegments
- iterator() - Method in class org.elasticsearch.action.admin.indices.segments.IndexShardSegments
- iterator() - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- iterator() - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- iterator() - Method in class org.elasticsearch.action.admin.indices.stats.IndexStats
- iterator() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexShardUpgradeStatus
- iterator() - Method in class org.elasticsearch.action.admin.indices.upgrade.get.IndexUpgradeStatus
- iterator() - Method in class org.elasticsearch.action.bulk.BulkResponse
- iterator() - Method in class org.elasticsearch.action.get.GetResponse
-
Deprecated.Use
GetResponse.getSource()
instead - iterator() - Method in class org.elasticsearch.action.get.MultiGetRequest
- iterator() - Method in class org.elasticsearch.action.get.MultiGetResponse
- iterator() - Method in class org.elasticsearch.action.search.MultiSearchResponse
- iterator() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- iterator() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse
- iterator() - Method in class org.elasticsearch.action.termvectors.TermVectorsFields
- iterator() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- iterator() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- iterator() - Method in class org.elasticsearch.cluster.metadata.Metadata
- iterator() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
- iterator() - Method in class org.elasticsearch.cluster.RestoreInProgress
- iterator() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
- iterator() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- iterator() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- iterator() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- iterator() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- iterator() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- iterator() - Method in class org.elasticsearch.cluster.routing.RoutingTable
- iterator() - Method in class org.elasticsearch.common.bytes.AbstractBytesReference
- iterator() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Returns a BytesRefIterator for this BytesReference.
- iterator() - Method in class org.elasticsearch.common.bytes.CompositeBytesReference
- iterator() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
- iterator() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- iterator() - Method in class org.elasticsearch.common.collect.EvictingQueue
- iterator() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- iterator() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
-
Returns a cursor over the entries (key-value pairs) in this map.
- iterator() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- iterator() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
Returns a cursor over the entries (key-value pairs) in this map.
- iterator() - Method in class org.elasticsearch.common.document.DocumentField
- iterator() - Method in class org.elasticsearch.common.FieldMemoryStats
- iterator() - Method in class org.elasticsearch.common.inject.ModulesBuilder
- iterator() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- iterator() - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
- iterator() - Method in class org.elasticsearch.common.util.PlainIterator
- iterator() - Method in class org.elasticsearch.index.get.GetResult
- iterator() - Method in class org.elasticsearch.index.IndexService
- iterator() - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
- iterator() - Method in class org.elasticsearch.index.mapper.FieldMapper
- iterator() - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields
- iterator() - Method in class org.elasticsearch.index.mapper.LuceneDocument
- iterator() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- iterator() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
- iterator() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
- iterator() - Method in class org.elasticsearch.indices.IndicesService
- iterator() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan.SnapshotFilesToRecover
- iterator() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
- iterator() - Method in class org.elasticsearch.monitor.fs.FsInfo
- iterator() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
- iterator() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
- iterator() - Method in class org.elasticsearch.search.aggregations.Aggregations
-
Iterates over the
Aggregation
s. - iterator() - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- iterator() - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms
- iterator() - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedHDRPercentileRanks
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedPercentiles
- iterator() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentileRanks
- iterator() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket
- iterator() - Method in class org.elasticsearch.search.SearchHit
- iterator() - Method in class org.elasticsearch.search.SearchHits
- iterator() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
- iterator() - Method in class org.elasticsearch.search.suggest.Suggest
- iterator() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- iterator() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- iterator() - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
- iterator() - Method in class org.elasticsearch.threadpool.ThreadPoolStats
- IteratorAndCurrent<B extends InternalMultiBucketAggregation.InternalBucket> - Class in org.elasticsearch.search.aggregations.bucket
- IteratorAndCurrent(Iterator<B>) - Constructor for class org.elasticsearch.search.aggregations.bucket.IteratorAndCurrent
- Iterators - Class in org.elasticsearch.common.collect
- Iterators() - Constructor for class org.elasticsearch.common.collect.Iterators
J
- JARO_WINKLER - Enum constant in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
String distance algorithm based on Jaro-Winkler algorithm.
- jars - Variable in class org.elasticsearch.bootstrap.PluginPolicyInfo
- JavaDateMathParser - Class in org.elasticsearch.common.time
-
A parser for date/time formatted text with optional date math.
- JLHScore - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- JLHScore() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.JLHScore
- JLHScore(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.JLHScore
-
Read from a stream.
- JLHScore.JLHScoreBuilder - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- JLHScoreBuilder() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.JLHScore.JLHScoreBuilder
- Joda - Class in org.elasticsearch.common.joda
-
Deprecated.
- Joda() - Constructor for class org.elasticsearch.common.joda.Joda
-
Deprecated.
- Joda.EpochTimeParser - Class in org.elasticsearch.common.joda
-
Deprecated.
- Joda.EpochTimePrinter - Class in org.elasticsearch.common.joda
-
Deprecated.
- JodaCompatibleZonedDateTime - Class in org.elasticsearch.script
-
A wrapper around ZonedDateTime that exposes joda methods for backcompat.
- JodaCompatibleZonedDateTime(Instant, ZoneId) - Constructor for class org.elasticsearch.script.JodaCompatibleZonedDateTime
- JodaDateFormatter - Class in org.elasticsearch.common.joda
- JodaDateMathParser - Class in org.elasticsearch.common.joda
-
A parser for date/time formatted text with optional date math.
- JodaDateMathParser(JodaDateFormatter) - Constructor for class org.elasticsearch.common.joda.JodaDateMathParser
- JodaDeprecationPatterns - Class in org.elasticsearch.common.joda
- JodaDeprecationPatterns() - Constructor for class org.elasticsearch.common.joda.JodaDeprecationPatterns
- join(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.Correction
- join(BytesRef, BytesRefBuilder, BytesRef...) - Static method in class org.elasticsearch.search.suggest.phrase.WordScorer
- join(BytesRef, BytesRefBuilder, BytesRef, BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.Correction
- join(BytesRef, BytesRef, BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.Correction
- Join - Class in org.elasticsearch.cluster.coordination
-
Triggered by a
StartJoinRequest
, instances of this class represent join votes, and have a source and target node. - Join(DiscoveryNode, DiscoveryNode, long, long, long) - Constructor for class org.elasticsearch.cluster.coordination.Join
- Join(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.Join
- JOIN_ACTION_NAME - Static variable in class org.elasticsearch.cluster.coordination.JoinHelper
- JOIN_PING_ACTION_NAME - Static variable in class org.elasticsearch.cluster.coordination.JoinHelper
- JOIN_RETRY_ATTEMPTS_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- JOIN_RETRY_DELAY_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- JOIN_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.JoinHelper
- JOIN_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- JOIN_VALIDATE_ACTION_NAME - Static variable in class org.elasticsearch.cluster.coordination.JoinHelper
- JoinHelper - Class in org.elasticsearch.cluster.coordination
- joiningCluster() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
-
returns true if zen discovery is started and there is a currently a background thread active for (re)joining the cluster used for testing.
- JoinRequest - Class in org.elasticsearch.cluster.coordination
- JoinRequest(DiscoveryNode) - Constructor for class org.elasticsearch.discovery.zen.MembershipAction.JoinRequest
- JoinRequest(DiscoveryNode, long, Optional<Join>) - Constructor for class org.elasticsearch.cluster.coordination.JoinRequest
- JoinRequest(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.JoinRequest
- JoinRequest(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.MembershipAction.JoinRequest
- JoinTaskExecutor - Class in org.elasticsearch.cluster.coordination
- JoinTaskExecutor(Settings, AllocationService, Logger, RerouteService) - Constructor for class org.elasticsearch.cluster.coordination.JoinTaskExecutor
- JoinTaskExecutor.Task - Class in org.elasticsearch.cluster.coordination
- joinVotesHaveQuorumFor(CoordinationMetadata.VotingConfiguration) - Method in class org.elasticsearch.cluster.coordination.CoordinationState
- JsonThrowablePatternConverter - Class in org.elasticsearch.common.logging
-
Outputs the Throwable portion of the LoggingEvent as a Json formatted field with array "exception": [ "stacktrace", "lines", "as", "array", "elements" ] Reusing @link org.apache.logging.log4j.core.pattern.ExtendedThrowablePatternConverter which already converts a Throwable from LoggingEvent into a multiline string
- JVM - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
- JVM - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- JvmGcMonitorService - Class in org.elasticsearch.monitor.jvm
- JvmGcMonitorService(Settings, ThreadPool) - Constructor for class org.elasticsearch.monitor.jvm.JvmGcMonitorService
- jvmInfo() - Static method in class org.elasticsearch.monitor.jvm.JvmInfo
- JvmInfo - Class in org.elasticsearch.monitor.jvm
- JvmInfo(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmInfo
- JvmInfo.Mem - Class in org.elasticsearch.monitor.jvm
- jvmService() - Method in class org.elasticsearch.monitor.MonitorService
- JvmService - Class in org.elasticsearch.monitor.jvm
- JvmService(Settings) - Constructor for class org.elasticsearch.monitor.jvm.JvmService
- jvmStats() - Static method in class org.elasticsearch.monitor.jvm.JvmStats
- JvmStats - Class in org.elasticsearch.monitor.jvm
- JvmStats(long, long, JvmStats.Mem, JvmStats.Threads, JvmStats.GarbageCollectors, List<JvmStats.BufferPool>, JvmStats.Classes) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats
- JvmStats(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats
- JvmStats.BufferPool - Class in org.elasticsearch.monitor.jvm
- JvmStats.Classes - Class in org.elasticsearch.monitor.jvm
- JvmStats.GarbageCollector - Class in org.elasticsearch.monitor.jvm
- JvmStats.GarbageCollectors - Class in org.elasticsearch.monitor.jvm
- JvmStats.Mem - Class in org.elasticsearch.monitor.jvm
- JvmStats.MemoryPool - Class in org.elasticsearch.monitor.jvm
- JvmStats.Threads - Class in org.elasticsearch.monitor.jvm
K
- KB - Enum constant in enum class org.elasticsearch.common.unit.ByteSizeUnit
- KDD - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- KDI - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- KDM - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- KEEP_VALUES - Enum constant in enum class org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
- keepAlive() - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- keepAlive() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
-
Returns a non-null to specify the time to live of the point-in-time reader that is used to execute this request.
- keepAlive() - Method in class org.elasticsearch.search.Scroll
-
How long the resources will be kept open to support the scroll request.
- keepAlive(TimeValue) - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
-
Set keep alive for the point in time
- KEEPALIVE_INTERVAL_SETTING - Static variable in class org.elasticsearch.search.SearchService
- key - Variable in class org.elasticsearch.common.settings.Setting.SimpleKey
- key - Variable in class org.elasticsearch.common.util.LongObjectPagedHashMap.Cursor
- key - Variable in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- key - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- key - Variable in class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
- key() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldType
- key() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- key() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
- key() - Method in class org.elasticsearch.search.aggregations.bucket.filter.QueryToFilterAdapter
-
Key for this filter.
- key(boolean) - Static method in class org.elasticsearch.search.aggregations.BucketOrder
-
Creates a bucket ordering strategy that sorts buckets by their keys (ascending or descending).
- Key<T> - Class in org.elasticsearch.common.inject
-
Binding key consisting of an injection type and an optional annotation.
- Key() - Constructor for class org.elasticsearch.common.inject.Key
-
Constructs a new key.
- Key(Annotation) - Constructor for class org.elasticsearch.common.inject.Key
-
Constructs a new key.
- Key(Class<? extends Annotation>) - Constructor for class org.elasticsearch.common.inject.Key
-
Constructs a new key.
- KEY - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- KEY - Static variable in enum class org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
- KEY_AS_STRING - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- KEY_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- KEY_FIELD_NAME - Static variable in class org.elasticsearch.common.logging.DeprecatedMessage
- KEY_IN_SYNC_ALLOCATIONS - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- KEY_PRIMARY_TERMS - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- KeyComparable<T extends MultiBucketsAggregation.Bucket & KeyComparable<T>> - Interface in org.elasticsearch.search.aggregations
-
Defines behavior for comparing
bucket keys
to imposes a total ordering of buckets of the same type. - keyed - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- keyed - Variable in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- keyed - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- keyed - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- keyed - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- keyed - Variable in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- keyed - Variable in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
- keyed - Variable in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation
- keyed() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Return whether buckets should be returned as a hash.
- keyed() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Return whether buckets should be returned as a hash.
- keyed() - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- keyed() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- keyed() - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- keyed() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
-
Should the output be keyed.
- keyed() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
-
Should the output be keyed.
- keyed() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
-
Get whether the XContent response should be keyed
- keyed(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set whether to return buckets as a hash or as an array, and return the builder so that calls can be chained.
- keyed(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Set whether to return buckets as a hash or as an array, and return the builder so that calls can be chained.
- keyed(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- keyed(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- keyed(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- keyed(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
-
Set whether the XContent response should be keyed
- KEYED_FIELD - Static variable in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
- KEYED_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- KEYED_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
- KeyedFilter(String, QueryBuilder) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- KeyedFilter(String, QueryBuilder) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
- KeyedFilter(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
-
Read from a stream.
- KeyedFilter(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
-
Read from a stream.
- KeyedFlattenedLeafFieldData - Class in org.elasticsearch.index.mapper.flattened
-
The atomic field data implementation for
FlattenedFieldMapper.KeyedFlattenedFieldType
. - KeyedLock<T> - Class in org.elasticsearch.common.util.concurrent
-
This class manages locks.
- KeyedLock() - Constructor for class org.elasticsearch.common.util.concurrent.KeyedLock
-
Creates a non-fair lock
- KeyedLock(boolean) - Constructor for class org.elasticsearch.common.util.concurrent.KeyedLock
-
Creates a new lock
- keys - Variable in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- keys - Variable in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- keys() - Method in class org.elasticsearch.common.cache.Cache
-
An LRU sequencing of the keys in the cache that supports removal.
- keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
-
Returns a specialized view of the keys of this associated container.
- keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- keys() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
Returns a specialized view of the keys of this associated container.
- keys() - Method in class org.elasticsearch.common.settings.Settings.Builder
- keys() - Method in interface org.elasticsearch.search.aggregations.pipeline.BucketMetricValue
- keys() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalBucketMetricValue
- keys() - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedBucketMetricValue
- keySerializer - Variable in class org.elasticsearch.cluster.DiffableUtils.MapDiff
- keySet() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
Returns a
Set
view of the keys contained in this map. - keySet() - Method in class org.elasticsearch.common.settings.Settings
-
Returns the fully qualified setting names contained in this settings object.
- keySet() - Method in class org.elasticsearch.common.util.LazyMap
- keySet() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- keySet() - Method in class org.elasticsearch.script.DynamicMap
- keySet() - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- keySet() - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- keySet() - Method in class org.elasticsearch.search.lookup.SourceLookup
- keysIt() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
-
Returns a direct iterator over the keys.
- keysIt() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
Returns a direct iterator over the keys.
- KeyStoreAwareCommand - Class in org.elasticsearch.cli
-
An
EnvironmentAwareCommand
that needs to access the elasticsearch keystore, possibly decrypting it if it is password protected. - KeyStoreAwareCommand(String) - Constructor for class org.elasticsearch.cli.KeyStoreAwareCommand
- keystorePath(Path) - Static method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Returns a path representing the ES keystore in the given config dir.
- KeyStoreWrapper - Class in org.elasticsearch.common.settings
-
A disk based container for sensitive settings in Elasticsearch.
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoGridBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongRareTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantLongTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantStringTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringRareTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms.ParsedBucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- keyToXContent(XContentBuilder) - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- keyTypeIsSet() - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- KEYWORD - Enum constant in enum class org.elasticsearch.index.mapper.MappedFieldType.CollapseType
- KEYWORD - Enum constant in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- KEYWORD - Enum constant in enum class org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- KEYWORD_ANALYZER - Static variable in class org.elasticsearch.common.lucene.Lucene
- KeywordAnalyzerProvider - Class in org.elasticsearch.index.analysis
- KeywordAnalyzerProvider(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.KeywordAnalyzerProvider
- KeywordField(String, BytesRef, FieldType) - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordField
- KeywordFieldMapper - Class in org.elasticsearch.index.mapper
-
A field mapper for keywords.
- KeywordFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- KeywordFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- KeywordFieldMapper.KeywordField - Class in org.elasticsearch.index.mapper
- KeywordFieldMapper.KeywordFieldType - Class in org.elasticsearch.index.mapper
- KeywordFieldType(String) - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- KeywordFieldType(String, boolean, boolean, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- KeywordFieldType(String, FieldType) - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- KeywordFieldType(String, FieldType, NamedAnalyzer, NamedAnalyzer, NamedAnalyzer, KeywordFieldMapper.Builder) - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- KeywordFieldType(String, NamedAnalyzer) - Constructor for class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- KeywordScriptFieldType - Class in org.elasticsearch.index.mapper
- KeywordScriptFieldType(String, StringFieldScript.Factory, Script, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.KeywordScriptFieldType
- kilo() - Method in class org.elasticsearch.common.unit.SizeValue
- KILO - Enum constant in enum class org.elasticsearch.common.unit.SizeUnit
- kiloFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- KILOMETERS - Enum constant in enum class org.elasticsearch.common.unit.DistanceUnit
- kind() - Method in class org.elasticsearch.common.lucene.RegExp
-
The type of expression.
L
- label() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
-
Get the description label for this decision.
- label() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- label() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- lag() - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
-
Gets the lag to use when calculating the serial difference.
- lag(int) - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
-
Sets the lag to use when calculating the serial difference.
- LagDetector - Class in org.elasticsearch.cluster.coordination
-
A publication can succeed and complete before all nodes have applied the published state and acknowledged it; however we need every node eventually either to apply the published state (or a later state) or be removed from the cluster.
- LagDetector(Settings, ThreadPool, LagDetector.LagListener, Supplier<DiscoveryNode>) - Constructor for class org.elasticsearch.cluster.coordination.LagDetector
- LagDetector.LagListener - Interface in org.elasticsearch.cluster.coordination
- LANG_PARSE_FIELD - Static variable in class org.elasticsearch.script.Script
-
Standard
ParseField
for lang on the inner level. - LANG_PARSE_FIELD - Static variable in class org.elasticsearch.script.StoredScriptSource
-
Standard
ParseField
for lang on the inner level. - languageContexts - Variable in class org.elasticsearch.script.ScriptLanguagesInfo
- LANGUID - Enum constant in enum class org.elasticsearch.common.Priority
- Laplace - Class in org.elasticsearch.search.suggest.phrase
-
An additive smoothing model.
- Laplace(double) - Constructor for class org.elasticsearch.search.suggest.phrase.Laplace
-
Creates a Laplace smoothing model.
- Laplace(StreamInput) - Constructor for class org.elasticsearch.search.suggest.phrase.Laplace
-
Read from a stream.
- last() - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- LAST - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.composite.MissingOrder
-
Place buckets for missing values last.
- lastAcceptedConfiguration(CoordinationMetadata.VotingConfiguration) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.Builder
- lastAcceptedVersion - Variable in class org.elasticsearch.gateway.PersistedClusterStateService.OnDiskState
- lastAccessTime() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
return the last time this RecoveryStatus was used (based on System.nanoTime()
- lastChunk() - Method in interface org.elasticsearch.indices.recovery.MultiChunkTransfer.ChunkRequest
- lastChunk() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
-
Returns
true
if this chunk is the last chunk in the stream. - lastCommittedConfiguration(CoordinationMetadata.VotingConfiguration) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.Builder
- lastEmittedDoc - Variable in class org.elasticsearch.search.internal.ScrollContext
- lastEmittedDoc() - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- lastPathElement() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
- lastRefreshTimestamp - Variable in class org.elasticsearch.common.util.SingleObjectCache
- lastTaskTime() - Method in class org.elasticsearch.common.StopWatch
-
Return the time taken by the last task.
- lastWriteNanos - Variable in class org.elasticsearch.index.engine.Engine
- lat - Variable in class org.elasticsearch.common.geo.GeoPoint
- lat() - Method in class org.elasticsearch.common.geo.GeoPoint
- LAT_FIELD - Static variable in class org.elasticsearch.common.geo.GeoBoundingBox
- LatchedActionListener<T> - Class in org.elasticsearch.action
-
An action listener that allows passing in a
CountDownLatch
that will be counted down after onResponse or onFailure is called - LatchedActionListener(ActionListener<T>, CountDownLatch) - Constructor for class org.elasticsearch.action.LatchedActionListener
- LATE_TIME_INTERVAL_WARN_THRESHOLD_SETTING - Static variable in class org.elasticsearch.threadpool.ThreadPool
- LATEST_CODEC - Static variable in class org.elasticsearch.common.lucene.Lucene
- latestSnapshotInAllRepositories(ShardId) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotRequest
- latestSnapshotInRepositories(ShardId, List<String>) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotRequest
- LATITUDE - Static variable in class org.elasticsearch.common.geo.GeoUtils
- LATITUDE_MASK - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
-
The geo-tile map is clipped at 85.05112878 to 90 and -85.05112878 to -90
- LatLonPointIndexFieldData(String, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointIndexFieldData.LatLonPointIndexFieldData
- latToSphericalMercator(double) - Static method in class org.elasticsearch.common.geo.SphericalMercatorUtils
-
Transforms WGS84 latitude to a Spherical mercator latitude
- LazyBits(int, String, LeafReader, int, int) - Constructor for class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazyBits
- LazyInitializable<T,
E extends Exception> - Class in org.elasticsearch.common.util -
Encapsulates a
CheckedSupplier
which is lazily invoked once on the first call to#getOrCompute()
. - LazyInitializable(CheckedSupplier<T, E>) - Constructor for class org.elasticsearch.common.util.LazyInitializable
-
Creates the simple LazyInitializable instance.
- LazyInitializable(CheckedSupplier<T, E>, Consumer<T>, Consumer<T>) - Constructor for class org.elasticsearch.common.util.LazyInitializable
-
Creates the complete LazyInitializable instance.
- LazyMap<K,
V> - Class in org.elasticsearch.common.util - LazyMap(Supplier<Map<K, V>>) - Constructor for class org.elasticsearch.common.util.LazyMap
- LazySoftDeletesDirectoryReaderWrapper - Class in org.apache.lucene.index
-
This is a modified version of
SoftDeletesDirectoryReaderWrapper
that materializes the liveDocs bitset lazily. - LazySoftDeletesDirectoryReaderWrapper(DirectoryReader, String) - Constructor for class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper
-
Creates a new soft deletes wrapper.
- LazySoftDeletesDirectoryReaderWrapper.LazyBits - Class in org.apache.lucene.index
- LazySoftDeletesDirectoryReaderWrapper.LazySoftDeletesFilterCodecReader - Class in org.apache.lucene.index
- LazySoftDeletesDirectoryReaderWrapper.LazySoftDeletesFilterLeafReader - Class in org.apache.lucene.index
- LazySoftDeletesFilterCodecReader(CodecReader, LazySoftDeletesDirectoryReaderWrapper.LazyBits, int) - Constructor for class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazySoftDeletesFilterCodecReader
- LazySoftDeletesFilterLeafReader(LeafReader, LazySoftDeletesDirectoryReaderWrapper.LazyBits, int) - Constructor for class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazySoftDeletesFilterLeafReader
- leader() - Method in class org.elasticsearch.cluster.coordination.LeaderChecker
- LEADER - Enum constant in enum class org.elasticsearch.cluster.coordination.Coordinator.Mode
- LEADER_CHECK_INTERVAL_SETTING - Static variable in class org.elasticsearch.cluster.coordination.LeaderChecker
- LEADER_CHECK_RETRY_COUNT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.LeaderChecker
- LEADER_CHECK_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.LeaderChecker
- LeaderBulkByScrollTaskState - Class in org.elasticsearch.index.reindex
-
Tracks the state of sliced subtasks and provides unified status information for a sliced BulkByScrollRequest.
- LeaderBulkByScrollTaskState(BulkByScrollTask, int) - Constructor for class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
- LeaderChecker - Class in org.elasticsearch.cluster.coordination
-
The LeaderChecker is responsible for allowing followers to check that the currently elected leader is still connected and healthy.
- Leaf(LeafReaderContext) - Constructor for class org.elasticsearch.search.sort.BucketedSort.ForDoubles.Leaf
- Leaf(LeafReaderContext) - Constructor for class org.elasticsearch.search.sort.BucketedSort.ForFloats.Leaf
- Leaf(LeafReaderContext) - Constructor for class org.elasticsearch.search.sort.BucketedSort.ForLongs.Leaf
- Leaf(LeafReaderContext) - Constructor for class org.elasticsearch.search.sort.BucketedSort.Leaf
- leafAdapter(Function<SearchLookup, CompositeFieldScript.LeafFactory>) - Static method in class org.elasticsearch.script.BooleanFieldScript
- leafAdapter(Function<SearchLookup, CompositeFieldScript.LeafFactory>) - Static method in class org.elasticsearch.script.DateFieldScript
- leafAdapter(Function<SearchLookup, CompositeFieldScript.LeafFactory>) - Static method in class org.elasticsearch.script.DoubleFieldScript
- leafAdapter(Function<SearchLookup, CompositeFieldScript.LeafFactory>) - Static method in class org.elasticsearch.script.GeoPointFieldScript
- leafAdapter(Function<SearchLookup, CompositeFieldScript.LeafFactory>) - Static method in class org.elasticsearch.script.IpFieldScript
- leafAdapter(Function<SearchLookup, CompositeFieldScript.LeafFactory>) - Static method in class org.elasticsearch.script.LongFieldScript
- leafAdapter(Function<SearchLookup, CompositeFieldScript.LeafFactory>) - Static method in class org.elasticsearch.script.StringFieldScript
- LeafBucketCollector - Class in org.elasticsearch.search.aggregations
-
Collects results for a particular segment.
- LeafBucketCollector() - Constructor for class org.elasticsearch.search.aggregations.LeafBucketCollector
- LeafBucketCollectorBase - Class in org.elasticsearch.search.aggregations
-
A
LeafBucketCollector
that delegates all calls to the sub leaf aggregator and sets the scorer on its source of values if it implementsScorerAware
. - LeafBucketCollectorBase(LeafBucketCollector, Object) - Constructor for class org.elasticsearch.search.aggregations.LeafBucketCollectorBase
- LeafDocLookup - Class in org.elasticsearch.search.lookup
- LeafDoubleFieldData - Class in org.elasticsearch.index.fielddata.plain
-
Specialization of
LeafNumericFieldData
for floating-point numerics. - LeafDoubleFieldData(long) - Constructor for class org.elasticsearch.index.fielddata.plain.LeafDoubleFieldData
- leafFactory(SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
-
Create a script leaf factory for queries.
- leafFactory(SearchLookup) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
-
Create a script leaf factory.
- LeafFieldData - Interface in org.elasticsearch.index.fielddata
-
The thread safe
LeafReader
level cache of the data. - LeafGeoPointFieldData - Interface in org.elasticsearch.index.fielddata
-
LeafFieldData
specialization for geo points. - LeafHistogramFieldData - Interface in org.elasticsearch.index.fielddata
-
LeafFieldData
specialization for histogram data. - LeafLongFieldData - Class in org.elasticsearch.index.fielddata.plain
-
Specialization of
LeafNumericFieldData
for integers. - LeafLongFieldData(long, IndexNumericFieldData.NumericType) - Constructor for class org.elasticsearch.index.fielddata.plain.LeafLongFieldData
- LeafNestedDocuments - Interface in org.elasticsearch.search
-
Manages loading information about nested documents for a single index segment
- LeafNumericFieldData - Interface in org.elasticsearch.index.fielddata
-
Specialization of
LeafFieldData
for numeric data. - LeafOnly(String) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder.LeafOnly
- LeafOnly(String) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.LeafOnly
- LeafOnly(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder.LeafOnly
-
Read from a stream that does not serialize its targetValueType.
- LeafOnly(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.LeafOnly
-
Read an aggregation from a stream
- LeafOnly(MultiValuesSourceAggregationBuilder.LeafOnly<AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder.LeafOnly
- LeafOnly(ValuesSourceAggregationBuilder.LeafOnly<VS, AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.LeafOnly
- LeafOrdinalsFieldData - Interface in org.elasticsearch.index.fielddata
-
Specialization of
LeafFieldData
for data that is indexed with ordinals. - leafReaderContext - Variable in class org.elasticsearch.script.DocValuesDocReader
- LeafReaderContextSupplier - Interface in org.elasticsearch.script
-
Provides direct access to a LeafReaderContext
- LeafRuntimeField - Class in org.elasticsearch.index.mapper
-
RuntimeField base class for leaf fields that will only ever return a single
MappedFieldType
fromRuntimeField.asMappedFieldTypes()
. - LeafRuntimeField(String, MappedFieldType, List<FieldMapper.Parameter<?>>) - Constructor for class org.elasticsearch.index.mapper.LeafRuntimeField
- LeafScoreFunction - Class in org.elasticsearch.common.lucene.search.function
-
Per-leaf
ScoreFunction
. - LeafScoreFunction() - Constructor for class org.elasticsearch.common.lucene.search.function.LeafScoreFunction
- leafSearchLookup - Variable in class org.elasticsearch.script.DocValuesDocReader
-
A leaf lookup for the bound segment this proxy will operate on.
- LeafSearchLookup - Class in org.elasticsearch.search.lookup
-
Per-segment version of
SearchLookup
. - LeafSearchLookup(LeafReaderContext, LeafDocLookup, SourceLookup, LeafStoredFieldsLookup) - Constructor for class org.elasticsearch.search.lookup.LeafSearchLookup
- LeafStoredFieldsLookup - Class in org.elasticsearch.search.lookup
- leases() - Method in class org.elasticsearch.index.seqno.RetentionLeases
-
The underlying collection of retention leases
- LeaveRequest(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.MembershipAction.LeaveRequest
- left() - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- LEFT - Enum constant in enum class org.elasticsearch.common.geo.Orientation
- LEGACY_DATE_HISTO - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
- LEGACY_DISCOVERY_HOSTS_PROVIDER_SETTING - Static variable in class org.elasticsearch.discovery.DiscoveryModule
- LEGACY_DISCOVERY_ZEN_PING_UNICAST_CONCURRENT_CONNECTS_SETTING - Static variable in class org.elasticsearch.discovery.SeedHostsResolver
- LEGACY_DISCOVERY_ZEN_PING_UNICAST_HOSTS_RESOLVE_TIMEOUT - Static variable in class org.elasticsearch.discovery.SeedHostsResolver
- LEGACY_DISCOVERY_ZEN_PING_UNICAST_HOSTS_SETTING - Static variable in class org.elasticsearch.discovery.SettingsBasedSeedHostsProvider
- LEGACY_INTERVAL - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
- LEGACY_NO_MASTER_BLOCK_SETTING - Static variable in class org.elasticsearch.cluster.coordination.NoMasterBlockService
- legacyBase64UUID() - Static method in class org.elasticsearch.common.UUIDs
-
Legacy implementation of
UUIDs.base64UUID()
, for pre 6.0 indices. - LegacyReaderContext - Class in org.elasticsearch.search.internal
- LegacyReaderContext(ShardSearchContextId, IndexService, IndexShard, Engine.SearcherSupplier, ShardSearchRequest, long) - Constructor for class org.elasticsearch.search.internal.LegacyReaderContext
- legacySetting() - Method in class org.elasticsearch.cluster.node.DiscoveryNodeRole
- length - Variable in class org.elasticsearch.index.translog.TranslogReader
- length - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- length() - Method in class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazyBits
- length() - Method in class org.apache.lucene.util.CombinedBitSet
- length() - Method in interface org.elasticsearch.common.blobstore.BlobMetadata
-
Gets the size of the blob in bytes.
- length() - Method in class org.elasticsearch.common.blobstore.support.PlainBlobMetadata
- length() - Method in class org.elasticsearch.common.bytes.BytesArray
- length() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
The length.
- length() - Method in class org.elasticsearch.common.bytes.CompositeBytesReference
- length() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
- length() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- length() - Method in class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- length() - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- length() - Method in class org.elasticsearch.common.settings.SecureString
- length() - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
The size of the expected results, including potential null values.
- length() - Method in class org.elasticsearch.index.mapper.ContentPath
- length() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
File length
- length() - Method in class org.elasticsearch.index.store.StoreFileMetadata
-
the actual file size on "disk", if compressed, the compressed size
- length() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- length() - Method in class org.elasticsearch.indices.recovery.RecoveryState.FileDetail
-
file length *
- LENGTH_REQUIRED - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server refuses to accept the request without a defined Content-Length.
- lengthType - Variable in enum class org.elasticsearch.index.mapper.RangeType
- lenient - Variable in class org.elasticsearch.index.search.MatchQueryParser
- lenient() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Gets leniency setting that controls if format based failures will be ignored.
- lenient() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- lenient() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- lenient() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns whether query parsing should be lenient.
- lenient() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Returns whether to use lenient parsing.
- lenient(boolean) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets whether format based failures will be ignored.
- lenient(boolean) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Sets whether format based failures will be ignored.
- lenient(boolean) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Specifies whether query parsing should be lenient.
- lenient(boolean) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Specifies whether to use lenient parsing, defaults to false.
- lenient(Boolean) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Sets the query string parser to be lenient when parsing field values, defaults to the index setting and if not set, defaults to false.
- LENIENT_EXPAND_OPEN - Static variable in class org.elasticsearch.action.support.IndicesOptions
- LENIENT_EXPAND_OPEN_CLOSED - Static variable in class org.elasticsearch.action.support.IndicesOptions
- LENIENT_EXPAND_OPEN_CLOSED_HIDDEN - Static variable in class org.elasticsearch.action.support.IndicesOptions
- LENIENT_EXPAND_OPEN_HIDDEN - Static variable in class org.elasticsearch.action.support.IndicesOptions
- LENIENT_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- lenientExpand() - Static method in class org.elasticsearch.action.support.IndicesOptions
- lenientExpandHidden() - Static method in class org.elasticsearch.action.support.IndicesOptions
- lenientExpandOpen() - Static method in class org.elasticsearch.action.support.IndicesOptions
- lenientExpandOpenHidden() - Static method in class org.elasticsearch.action.support.IndicesOptions
- lenientParse(String) - Static method in enum class org.elasticsearch.search.aggregations.support.ValueType
- lessThan(B, B) - Method in class org.elasticsearch.search.aggregations.bucket.terms.BucketPriorityQueue
- lessThan(SignificantTerms.Bucket, SignificantTerms.Bucket) - Method in class org.elasticsearch.search.aggregations.bucket.terms.BucketSignificancePriorityQueue
- level() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
Get the level of detail for the health information to be returned.
- level(ClusterHealthRequest.Level) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
Set the level of detail for the health information to be returned.
- levels() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- LEVENSHTEIN - Enum constant in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
String distance algorithm based on Levenshtein edit distance algorithm.
- libFile() - Method in class org.elasticsearch.env.Environment
- lifecycle - Variable in class org.elasticsearch.common.component.AbstractLifecycleComponent
- Lifecycle - Class in org.elasticsearch.common.component
-
Lifecycle state.
- Lifecycle() - Constructor for class org.elasticsearch.common.component.Lifecycle
- Lifecycle.State - Enum Class in org.elasticsearch.common.component
- LifecycleComponent - Interface in org.elasticsearch.common.component
- LifecycleListener - Class in org.elasticsearch.common.component
- LifecycleListener() - Constructor for class org.elasticsearch.common.component.LifecycleListener
- lifecycleState() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
- lifecycleState() - Method in interface org.elasticsearch.common.component.LifecycleComponent
- lifecycleState() - Method in class org.elasticsearch.repositories.FilterRepository
- like(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Return a query that will return docs like the passed lucene document ID.
- like(String, Reader...) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Return a query that will return docs like the passed Readers.
- like(Fields...) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Return a query that will return docs like the passed Fields.
- like(Terms...) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Return a query that will return docs like the passed Terms.
- likeItems() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- likeTexts() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- LIMIT - Static variable in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- LIMIT_HEAP_SETTING - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- limitStream(InputStream, long) - Static method in class org.elasticsearch.common.io.Streams
-
Limits the given input stream to the provided number of bytes
- LimitTokenOffsetAnalyzer - Class in org.elasticsearch.search.fetch.subphase.highlight
-
This analyzer limits the highlighting once it sees a token with a start offset <= the configured limit, which won't pass and will end the stream.
- LimitTokenOffsetAnalyzer(Analyzer, int) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.LimitTokenOffsetAnalyzer
-
Build an analyzer that limits the highlighting once it sees a token with a start offset <= the configured limit, which won't pass and will end the stream.
- LINEAR_COUNTING - Static variable in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
- LINEAR_DECAY_FUNCTION - Static variable in class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
- linearDecayFunction(String, Object, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- linearDecayFunction(String, Object, Object, Object) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- linearDecayFunction(String, Object, Object, Object, double) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- LinearDecayFunctionBuilder - Class in org.elasticsearch.index.query.functionscore
- LinearDecayFunctionBuilder(String, Object, Object, Object) - Constructor for class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
- LinearDecayFunctionBuilder(String, Object, Object, Object, double) - Constructor for class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
- LinearDecayFunctionBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
-
Read from a stream.
- LinearInterpolatingScorer - Class in org.elasticsearch.search.suggest.phrase
- LinearInterpolatingScorer(IndexReader, Terms, String, double, BytesRef, double, double, double) - Constructor for class org.elasticsearch.search.suggest.phrase.LinearInterpolatingScorer
- LinearInterpolation - Class in org.elasticsearch.search.suggest.phrase
-
Linear interpolation smoothing model.
- LinearInterpolation(double, double, double) - Constructor for class org.elasticsearch.search.suggest.phrase.LinearInterpolation
-
Creates a linear interpolation smoothing model.
- LinearInterpolation(StreamInput) - Constructor for class org.elasticsearch.search.suggest.phrase.LinearInterpolation
-
Read from a stream.
- LinearModel - Class in org.elasticsearch.search.aggregations.pipeline
-
Calculate a linearly weighted moving average, such that older values are linearly less important.
- LinearModel() - Constructor for class org.elasticsearch.search.aggregations.pipeline.LinearModel
- LinearModel(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.LinearModel
-
Read from a stream.
- LinearModel.LinearModelBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- LinearModelBuilder() - Constructor for class org.elasticsearch.search.aggregations.pipeline.LinearModel.LinearModelBuilder
- linearWeightedAvg(double[]) - Static method in class org.elasticsearch.search.aggregations.pipeline.MovingFunctions
-
Calculate a linearly weighted moving average, such that older values are linearly less important.
- linesIntersect(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.XTessellator
-
Determines whether two line segments intersect.
- LinkedBindingBuilder<T> - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - LinkedBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- LinkedBindingImpl(Object, Key<T>, Scoping, Key<? extends T>) - Constructor for class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- LinkedBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping, Key<? extends T>) - Constructor for class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- LinkedKeyBinding<T> - Interface in org.elasticsearch.common.inject.spi
-
A binding to a linked key.
- LinkedProviderBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- LinkedProviderBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping, Key<? extends Provider<? extends T>>) - Constructor for class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- list(String[], TimeValue) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- list(ShardId, String, DiscoveryNode[], ActionListener<NodesResponse>) - Method in interface org.elasticsearch.gateway.AsyncShardFetch.Lister
- list(ShardId, String, DiscoveryNode[], ActionListener<TransportNodesListGatewayStartedShards.NodesGatewayStartedShards>) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- list(ShardId, String, DiscoveryNode[], ActionListener<TransportNodesListShardStoreMetadata.NodesStoreFilesMetadata>) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata
- listBlobs() - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Lists all blobs in the container.
- listBlobs() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- listBlobs() - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- listBlobsByPrefix(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Lists all blobs in the container that match the specified prefix.
- listBlobsByPrefix(String) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- listBlobsByPrefix(String) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- listDanglingIndices(ListDanglingIndicesRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
List dangling indices on all nodes.
- listDanglingIndices(ListDanglingIndicesRequest, ActionListener<ListDanglingIndicesResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
List dangling indices on all nodes.
- ListDanglingIndicesAction - Class in org.elasticsearch.action.admin.indices.dangling.list
-
Represents a request to list all dangling indices known to the cluster.
- ListDanglingIndicesRequest - Class in org.elasticsearch.action.admin.indices.dangling.list
- ListDanglingIndicesRequest() - Constructor for class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesRequest
- ListDanglingIndicesRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesRequest
- ListDanglingIndicesRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesRequest
- ListDanglingIndicesResponse - Class in org.elasticsearch.action.admin.indices.dangling.list
-
Models a response to a
ListDanglingIndicesRequest
. - ListDanglingIndicesResponse(ClusterName, List<NodeListDanglingIndicesResponse>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesResponse
- ListDanglingIndicesResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesResponse
- listedNodes() - Method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.Returns the listed nodes in the transport client (ones added to it).
- ListenableActionFuture<T> - Class in org.elasticsearch.action.support
-
A
Future
andActionListener
against which which otherActionListener
s can be registered later, to support fanning-out a result to a dynamic collection of listeners. - ListenableActionFuture() - Constructor for class org.elasticsearch.action.support.ListenableActionFuture
- ListenableFuture<V> - Class in org.elasticsearch.common.util.concurrent
-
A future implementation that allows for the result to be passed to listeners waiting for notification.
- ListenableFuture() - Constructor for class org.elasticsearch.common.util.concurrent.ListenableFuture
- listener - Variable in class org.elasticsearch.action.ActionRunnable
- Listener() - Constructor for class org.elasticsearch.discovery.zen.NodesFaultDetection.Listener
- LISTENER - Enum constant in enum class org.elasticsearch.action.ThreadingModel
- LISTENER - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
-
Deprecated.
- listeners - Variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
- listeners() - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Returns a list of listeners
- ListenerTimeouts - Class in org.elasticsearch.action.support
- ListenerTimeouts() - Constructor for class org.elasticsearch.action.support.ListenerTimeouts
- listenForUpdates(ClusterSettings) - Method in class org.elasticsearch.transport.RemoteClusterAware
-
Registers this instance to listen to updates on the cluster settings.
- listenForUpdates(ClusterSettings) - Method in class org.elasticsearch.transport.RemoteClusterService
- ListKey(String) - Constructor for class org.elasticsearch.common.settings.Setting.ListKey
- listOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a type modelling a
List
whose elements are of typeelementType
. - listSetting(String, Function<String, T>, Function<Settings, List<String>>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- listSetting(String, Function<String, T>, Function<Settings, List<String>>, Setting.Validator<List<T>>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- listSetting(String, List<String>, Function<String, T>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- listSetting(String, List<String>, Function<String, T>, Setting.Validator<List<T>>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- listSetting(String, Setting<List<T>>, Function<String, T>, Function<Settings, List<String>>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- listSetting(String, Setting<List<T>>, Function<String, T>, Function<Settings, List<String>>, Setting.Validator<List<T>>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- listSetting(String, Setting<List<T>>, Function<String, T>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- listTasks(ListTasksRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
List tasks
- listTasks(ListTasksRequest, ActionListener<ListTasksResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
List active tasks
- ListTasksAction - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
-
ActionType for retrieving a list of currently running tasks
- listTasksRequest() - Static method in class org.elasticsearch.client.Requests
-
Creates a nodes tasks request against all the nodes.
- ListTasksRequest - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
-
A request to get node tasks
- ListTasksRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
- ListTasksRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
- ListTasksRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
-
Builder for the request to retrieve the list of tasks running on the specified nodes
- ListTasksRequestBuilder(ElasticsearchClient, ListTasksAction) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequestBuilder
- ListTasksResponse - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
-
Returns the list of tasks currently running on the nodes
- ListTasksResponse(List<TaskInfo>, List<TaskOperationFailure>, List<? extends ElasticsearchException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- ListTasksResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- listTasksResponseListener(Supplier<DiscoveryNodes>, String, RestChannel) - Static method in class org.elasticsearch.rest.action.admin.cluster.RestListTasksAction
-
Standard listener for extensions of
ListTasksResponse
that supportsgroup_by=nodes
. - littleQuery() - Method in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- littleQuery() - Method in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- LIV - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- LivenessRequest - Class in org.elasticsearch.action.admin.cluster.node.liveness
-
Transport level private response for the transport handler registered under "cluster:monitor/nodes/liveness"
- LivenessRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.liveness.LivenessRequest
- LivenessRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.liveness.LivenessRequest
- LivenessResponse - Class in org.elasticsearch.action.admin.cluster.node.liveness
-
Transport level private response for the transport handler registered under "cluster:monitor/nodes/liveness"
- LivenessResponse() - Constructor for class org.elasticsearch.action.admin.cluster.node.liveness.LivenessResponse
- LivenessResponse(ClusterName, DiscoveryNode) - Constructor for class org.elasticsearch.action.admin.cluster.node.liveness.LivenessResponse
- LivenessResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.liveness.LivenessResponse
- LKP - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- LN - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- LN1P - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- LN2P - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- load(Object) - Static method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
-
Loads
ContextMappings
from configuration Expected configuration: List of maps representingContextMapping
[{"name": .., "type": .., ..}, {..}] - load(String, Map<String, Object>) - Static method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
-
Loads a
name
dCategoryContextMapping
instance from a map. - load(String, Map<String, Object>) - Static method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- load(Path) - Static method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Loads information about the Elasticsearch keystore from the provided config directory.
- load(K) - Method in interface org.elasticsearch.common.cache.CacheLoader
- load(DirectoryReader, IFD) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache
- load(DirectoryReader, IFD) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.BinaryScriptFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.BooleanScriptFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.DateScriptFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.DoubleScriptFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.GeoPointScriptFieldData
- load(LeafReaderContext) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
-
Loads the atomic field data for the reader, possibly cached.
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.LongScriptFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData.Consumer
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointIndexFieldData.LatLonPointIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.StringBinaryIndexFieldData
- load(LeafReaderContext) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldData
- load(LeafReaderContext, IFD) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache
- load(LeafReaderContext, IFD) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
- loadBestOnDiskState() - Method in class org.elasticsearch.gateway.PersistedClusterStateService
-
Loads the best available on-disk cluster state.
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.BooleanScriptFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.DateScriptFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.DoubleScriptFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.GeoPointScriptFieldData
- loadDirect(LeafReaderContext) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
-
Loads directly the atomic field data for the reader, ignoring any caching involved.
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.IpScriptFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.LongScriptFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData.Consumer
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointIndexFieldData.LatLonPointIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.plain.StringBinaryIndexFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.StringScriptFieldData
- loadDirect(LeafReaderContext) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldData
- loadDocIdAndSeqNo(IndexReader, Term) - Static method in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver
-
Loads the internal docId and sequence number of the latest copy for a given uid from the provided reader.
- loadDocIdAndVersion(IndexReader, Term, boolean) - Static method in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver
-
Load the internal doc ID and version for the uid from the reader, returning null if the uid wasn't found, a doc ID and a version otherwise
- loadDocIdAndVersionUncached(IndexReader, Term, boolean) - Static method in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver
- loader(LeafReaderContext) - Method in interface org.elasticsearch.search.sort.BucketedSort.ExtraData
-
Prepare to load extra data from a leaf.
- loadExtensions(Class<T>) - Method in interface org.elasticsearch.plugins.ExtensiblePlugin.ExtensionLoader
-
Load extensions of the type from all extending plugins.
- loadExtensions(ExtensiblePlugin.ExtensionLoader) - Method in interface org.elasticsearch.plugins.ExtensiblePlugin
-
Allow this plugin to load extensions from other plugins.
- loadFieldValues(CustomUnifiedHighlighter, SearchExecutionContext, MappedFieldType, FetchSubPhase.HitContext, boolean) - Method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- loadFieldValues(MappedFieldType, SearchExecutionContext, FetchSubPhase.HitContext, boolean) - Static method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightUtils
-
Load field values for highlighting.
- loadFromDoc(long, int) - Method in interface org.elasticsearch.search.sort.BucketedSort.ExtraData.Loader
-
Load extra data from a doc.
- loadFromMap(Map<String, ?>) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Loads settings from a map.
- loadFromPath(Path) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Loads settings from a url that represents them using
Settings.fromXContent(XContentParser)
Note: Loading from a path doesn't allownull
values in the incoming xcontent - loadFromSource(String, XContentType) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Loads settings from the actual string content that represents them using
Settings.fromXContent(XContentParser)
- loadFromStream(String, InputStream, boolean) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Loads settings from a stream that represents them using
Settings.fromXContent(XContentParser)
- loadFullState() - Method in class org.elasticsearch.gateway.MetaStateService
-
Loads the full state, which includes both the global state and all the indices meta data.
- loadGeneration(Logger, NamedXContentRegistry, long, Path...) - Method in class org.elasticsearch.gateway.MetadataStateFormat
-
Tries to load the state of particular generation from the given data-locations.
- loadGlobal(DirectoryReader) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData.Global
- loadGlobal(DirectoryReader) - Method in interface org.elasticsearch.index.fielddata.IndexOrdinalsFieldData
-
Load a global view of the ordinals for the given
IndexReader
, potentially from a cache. - loadGlobal(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData.Consumer
- loadGlobal(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- loadGlobal(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- loadGlobal(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- loadGlobal(DirectoryReader) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldData
- loadGlobalDirect(DirectoryReader) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData.Global
- loadGlobalDirect(DirectoryReader) - Method in interface org.elasticsearch.index.fielddata.IndexOrdinalsFieldData
-
Load a global view of the ordinals for the given
IndexReader
. - loadGlobalDirect(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData.Consumer
- loadGlobalDirect(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- loadGlobalDirect(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- loadGlobalDirect(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- loadGlobalDirect(DirectoryReader) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldData
- loadIndexState(Index) - Method in class org.elasticsearch.gateway.MetaStateService
-
Loads the index state for the provided index name, returning null if doesn't exists.
- loadIntoContext(ShardSearchRequest, SearchContext, QueryPhase) - Method in class org.elasticsearch.indices.IndicesService
-
Loads the cache result, computing it if needed by executing the query phase and otherwise deserializing the cached value into the
context's query result
. - loadLatestState(Logger, NamedXContentRegistry, Path...) - Method in class org.elasticsearch.gateway.MetadataStateFormat
-
Tries to load the latest state from the given data-locations.
- loadLatestStateWithGeneration(Logger, NamedXContentRegistry, Path...) - Method in class org.elasticsearch.gateway.MetadataStateFormat
-
Tries to load the latest state from the given data-locations.
- loadLog4jPlugins() - Static method in class org.elasticsearch.common.logging.LogConfigurator
-
Load logging plugins so we can have
node_name
in the pattern. - loadManifestOrEmpty() - Method in class org.elasticsearch.gateway.MetaStateService
-
Loads Manifest file from disk, returns
Manifest.empty()
if there is no manifest file. - loadRetentionLeases() - Method in class org.elasticsearch.index.shard.IndexShard
-
Loads the latest retention leases from their dedicated state file.
- loadRetentionLeases(Path) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Loads the latest retention leases from their dedicated state file.
- loadSeqNoInfoFromLuceneCommit(Iterable<Map.Entry<String, String>>) - Static method in class org.elasticsearch.index.seqno.SequenceNumbers
-
Reads the sequence number stats from the commit data (maximum sequence number and local checkpoint).
- loadShardPath(Logger, NodeEnvironment, ShardId, String) - Static method in class org.elasticsearch.index.shard.ShardPath
-
This method walks through the nodes shard paths to find the data and state path for the given shard.
- loadShardPath(Logger, ShardId, String, Path[], int, Path) - Static method in class org.elasticsearch.index.shard.ShardPath
-
This method walks through the nodes shard paths to find the data and state path for the given shard.
- loadShardSnapshot(BlobContainer, SnapshotId) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Loads information about shard snapshot
- loadTermAndClusterState(PersistedClusterStateService, Environment) - Static method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- local - Variable in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- local - Variable in class org.elasticsearch.action.support.master.MasterNodeReadRequest
- local() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- local() - Method in class org.elasticsearch.action.support.master.MasterNodeReadRequest
-
Return local information, do not retrieve the state from master node (default: false).
- local(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
-
Indicate whether the receiving node should operate based on local index information or forward requests, where needed, to other nodes.
- local(boolean) - Method in class org.elasticsearch.action.support.master.MasterNodeReadRequest
- LOCAL - Enum constant in enum class org.elasticsearch.cluster.routing.Preference
-
Route to local node, if possible
- LOCAL_ABORT_AVAILABLE_VERSION - Static variable in class org.elasticsearch.persistent.CompletionPersistentTaskAction
- LOCAL_ABORTED - Enum constant in enum class org.elasticsearch.persistent.AllocatedPersistentTask.State
- LOCAL_CHECKPOINT_KEY - Static variable in class org.elasticsearch.index.seqno.SequenceNumbers
- LOCAL_CLUSTER_GROUP_KEY - Static variable in class org.elasticsearch.transport.RemoteClusterAware
- LOCAL_RESET - Enum constant in enum class org.elasticsearch.index.engine.Engine.Operation.Origin
- LOCAL_SHARDS - Enum constant in enum class org.elasticsearch.cluster.routing.RecoverySource.Type
- LOCAL_TIME_FORMATTER - Static variable in class org.elasticsearch.common.xcontent.XContentElasticsearchExtension
- LOCAL_TRANSLOG_RECOVERY - Enum constant in enum class org.elasticsearch.index.engine.Engine.Operation.Origin
- LocalAllocateDangledIndices - Class in org.elasticsearch.gateway
- LocalAllocateDangledIndices(TransportService, ClusterService, AllocationService, IndexMetadataVerifier) - Constructor for class org.elasticsearch.gateway.LocalAllocateDangledIndices
- LocalAllocateDangledIndices.AllocateDangledRequest - Class in org.elasticsearch.gateway
- LocalAllocateDangledIndices.AllocateDangledResponse - Class in org.elasticsearch.gateway
- localCheckpoint - Variable in class org.elasticsearch.index.engine.SafeCommitInfo
- localCheckpoint - Variable in class org.elasticsearch.index.seqno.SequenceNumbers.CommitInfo
- localCheckpoint() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Returns the persisted local checkpoint on the primary shard.
- localCheckpoint() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.ReplicaResponse
-
The persisted local checkpoint for the shard.
- localCheckpoint() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResponse
- LocalCheckpointTracker - Class in org.elasticsearch.index.seqno
-
This class generates sequences numbers and keeps track of the so-called "local checkpoint" which is the highest number for which all previous sequence numbers have been processed (inclusive).
- LocalCheckpointTracker(long, long) - Constructor for class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
Initialize the local checkpoint service.
- LocalClusterUpdateTask - Class in org.elasticsearch.cluster
-
Used to apply state updates on nodes that are not necessarily master
- LocalClusterUpdateTask() - Constructor for class org.elasticsearch.cluster.LocalClusterUpdateTask
- LocalClusterUpdateTask(Priority) - Constructor for class org.elasticsearch.cluster.LocalClusterUpdateTask
- localConnection - Variable in class org.elasticsearch.action.support.TransportAction
- localDateOptionalTimeParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO datetime parser where the date is mandatory and the time is optional.
- localDateParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO date parser for parsing local dates.
- locale() - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- locale() - Method in interface org.elasticsearch.common.time.DateFormatter
-
Returns the configured locale of the date formatter
- LocaleUtils - Class in org.elasticsearch.common.util
-
Utilities for for dealing with
Locale
objects - LocaleUtils() - Constructor for class org.elasticsearch.common.util.LocaleUtils
- localExecute(Request) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- localExecute(Request) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeReadAction
- localNode() - Method in class org.elasticsearch.cluster.service.ClusterService
-
The local node.
- localNode() - Method in class org.elasticsearch.tasks.TaskManager
- localNodeId(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- localNodeMaster() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff the local node is the mater node of the cluster. - LocalNodeMasterListener - Interface in org.elasticsearch.cluster
-
Enables listening to master changes events of the local node (when the local node becomes the master, and when the local node cease being a master).
- localRerouteInitiatedByNodeClient() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- localShardFailed(ShardRouting, String, Exception, ActionListener<Void>) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
Send a shard failed request to the master node to update the cluster state when a shard on the local node failed.
- localShardFailed(ShardRouting, String, Exception, ActionListener<Void>, ClusterState) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
Send a shard failed request to the master node to update the cluster state when a shard on the local node failed.
- LocalTimeOffset - Class in org.elasticsearch.common
-
Converts utc into local time and back again.
- LocalTimeOffset.Gap - Class in org.elasticsearch.common
- LocalTimeOffset.Lookup - Class in org.elasticsearch.common
-
How to get instances of
LocalTimeOffset
. - LocalTimeOffset.Overlap - Class in org.elasticsearch.common
- LocalTimeOffset.Strategy - Interface in org.elasticsearch.common
- LocalTimeOffset.Transition - Class in org.elasticsearch.common
- localTimeParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO time parser for parsing local times.
- localToUtc(long, LocalTimeOffset.Strategy) - Method in class org.elasticsearch.common.LocalTimeOffset.Gap
- localToUtc(long, LocalTimeOffset.Strategy) - Method in class org.elasticsearch.common.LocalTimeOffset
-
Convert a local time that occurs during this offset or a previous offset to utc, providing a strategy for how to resolve "funny" cases.
- localToUtc(long, LocalTimeOffset.Strategy) - Method in class org.elasticsearch.common.LocalTimeOffset.Overlap
- localToUtcInThisOffset(long) - Method in class org.elasticsearch.common.LocalTimeOffset
-
Convert a time in local millis to utc millis using this offset.
- location - Variable in class org.elasticsearch.action.support.replication.TransportWriteAction.WritePrimaryResult
- location - Variable in class org.elasticsearch.action.support.replication.TransportWriteAction.WriteReplicaResult
- location - Variable in class org.elasticsearch.repositories.RepositoryInfo
- location() - Method in class org.elasticsearch.index.translog.Translog
-
Returns all translog locations as absolute paths.
- Location(long, long, int) - Constructor for class org.elasticsearch.index.translog.Translog.Location
- LOCATION_SETTING - Static variable in class org.elasticsearch.repositories.fs.FsRepository
- locationToSync(Translog.Location, Translog.Location) - Static method in class org.elasticsearch.action.support.replication.TransportWriteAction
- lock() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
- lock(ShardId, String, long) - Method in interface org.elasticsearch.env.NodeEnvironment.ShardLocker
- lockAllForIndex(Index, IndexSettings, String, long) - Method in class org.elasticsearch.env.NodeEnvironment
-
Tries to lock all local shards for the given index.
- locked(Recycler<T>) - Static method in enum class org.elasticsearch.common.recycler.Recyclers
-
Wrap the provided recycler so that calls to
Recycler.obtain()
andReleasable.close()
are protected by a lock. - LOCKED - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The 423 (Locked) status code means the source or destination resource of a method is locked.
- lockedShards() - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns all currently lock shards.
- lockInterruptibly() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
- LOG - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- LOG_DEFAULT_LEVEL_SETTING - Static variable in class org.elasticsearch.common.logging.Loggers
- LOG_LEVEL_SETTING - Static variable in class org.elasticsearch.common.logging.Loggers
- LOG1P - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- LOG2P - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- LogConfigurator - Class in org.elasticsearch.common.logging
- LogConfigurator() - Constructor for class org.elasticsearch.common.logging.LogConfigurator
- logger - Variable in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- logger - Variable in class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction
- logger - Variable in class org.elasticsearch.action.support.TransportAction
-
Deprecated.declare your own logger.
- logger - Variable in class org.elasticsearch.client.support.AbstractClient
- logger - Variable in class org.elasticsearch.cluster.ClusterStateObserver
- logger - Variable in class org.elasticsearch.cluster.coordination.Publication
- logger - Variable in class org.elasticsearch.gateway.AsyncShardFetch
- logger - Variable in class org.elasticsearch.gateway.BaseGatewayShardAllocator
- logger - Variable in class org.elasticsearch.index.AbstractIndexComponent
- logger - Variable in class org.elasticsearch.index.engine.Engine
- logger - Variable in class org.elasticsearch.index.reindex.ScrollableHitSource
- logger - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
- logger - Static variable in class org.elasticsearch.index.translog.TruncateTranslogAction
- logger - Variable in class org.elasticsearch.indices.recovery.RecoverySourceHandler
- logger - Static variable in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- logger - Variable in class org.elasticsearch.rest.BaseRestHandler
-
Deprecated.declare your own logger.
- logger - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- logger - Variable in class org.elasticsearch.transport.RemoteConnectionStrategy
- logger - Static variable in interface org.elasticsearch.transport.TransportChannel
- logger() - Method in class org.elasticsearch.index.warmer.ShardIndexWarmerService
- LoggerInfoStream - Class in org.elasticsearch.common.lucene
-
An InfoStream (for Lucene's IndexWriter) that redirects messages to "lucene.iw.ifd" and "lucene.iw" Logger.trace.
- LoggerInfoStream(Logger) - Constructor for class org.elasticsearch.common.lucene.LoggerInfoStream
- LoggerMessageFormat - Class in org.elasticsearch.common.logging
-
Format string for Elasticsearch log messages.
- LoggerMessageFormat() - Constructor for class org.elasticsearch.common.logging.LoggerMessageFormat
- Loggers - Class in org.elasticsearch.common.logging
-
A set of utilities around Logging.
- Loggers() - Constructor for class org.elasticsearch.common.logging.Loggers
- LoggerTerminal - Class in org.elasticsearch.bootstrap.plugins
- LoggingAwareCommand - Class in org.elasticsearch.cli
-
A command that is aware of logging.
- LoggingAwareCommand(String) - Constructor for class org.elasticsearch.cli.LoggingAwareCommand
-
Construct the command with the specified command description.
- LoggingAwareMultiCommand - Class in org.elasticsearch.cli
-
A multi-command that is aware of logging.
- LoggingAwareMultiCommand(String) - Constructor for class org.elasticsearch.cli.LoggingAwareMultiCommand
-
Construct the command with the specified command description.
- LoggingDeprecationHandler - Class in org.elasticsearch.common.xcontent
-
Logs deprecations to the
DeprecationLogger
. - LoggingTaskListener<Response> - Class in org.elasticsearch.tasks
-
A TaskListener that just logs the response at the info level.
- logIfNecessary() - Static method in class org.elasticsearch.common.network.IfConfig
-
log interface configuration at debug level, if its enabled
- logMinimumMasterNodesWarningIfNecessary(ClusterState, ClusterState) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
- logsFile() - Method in class org.elasticsearch.env.Environment
- lon - Variable in class org.elasticsearch.common.geo.GeoPoint
- lon() - Method in class org.elasticsearch.common.geo.GeoPoint
- LON_FIELD - Static variable in class org.elasticsearch.common.geo.GeoBoundingBox
- LONG - Enum constant in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- LONG - Enum constant in enum class org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- LONG - Enum constant in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- LONG - Enum constant in enum class org.elasticsearch.index.mapper.RangeType
- LONG - Enum constant in enum class org.elasticsearch.search.aggregations.support.ValueType
- LONG_FIELD_RANGE_VERSION_INTRODUCED - Static variable in class org.elasticsearch.index.shard.ShardLongFieldRange
- LONG_PAGE_SIZE - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- LongAccessor() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic.LongAccessor
- LongArray - Interface in org.elasticsearch.common.util
-
Abstraction of an array of long values.
- LongBounds - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
Represent hard_bounds and extended_bounds in date-histogram aggregations.
- LongBounds(Long, Long) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.LongBounds
-
Construct with parsed bounds.
- LongBounds(String, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.LongBounds
-
Construct with unparsed bounds.
- LongBounds(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.LongBounds
-
Read from a stream.
- longEncode(double, double, int) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
-
Encode lon/lat to the geotile based long format.
- longEncode(String) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
-
Encode a geotile hash style string to a long.
- longEncodeTiles(int, long, long) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
- longestOnly() - Method in class org.elasticsearch.index.analysis.HunspellTokenFilterFactory
- longField(FieldInfo, long) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- longField(FieldInfo, long) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- longField(FieldInfo, long) - Method in class org.elasticsearch.search.internal.FilterFieldNamesProvidingStoredFieldsVisitor
- longField(FieldInfo, long) - Method in class org.elasticsearch.search.internal.FilterStoredFieldVisitor
- LongFieldScript - Class in org.elasticsearch.script
- LongFieldScript(String, Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.LongFieldScript
- LongFieldScript.Emit - Class in org.elasticsearch.script
- LongFieldScript.Factory - Interface in org.elasticsearch.script
- LongFieldScript.LeafFactory - Interface in org.elasticsearch.script
- LongFilter() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.LongFilter
- LongHash - Class in org.elasticsearch.common.util
-
Specialized hash table implementation similar to BytesRefHash that maps long values to ids.
- LongHash(long, float, BigArrays) - Constructor for class org.elasticsearch.common.util.LongHash
- LongHash(long, BigArrays) - Constructor for class org.elasticsearch.common.util.LongHash
- LONGITUDE - Static variable in class org.elasticsearch.common.geo.GeoUtils
- LongKeyedBucketOrds - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Maps owning bucket ordinals and long bucket keys to bucket ordinals.
- LongKeyedBucketOrds.BucketOrdsEnum - Interface in org.elasticsearch.search.aggregations.bucket.terms
-
An iterator for buckets inside a particular
owningBucketOrd
. - LongKeyedBucketOrds.FromMany - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Implementation that works properly when collecting from many buckets.
- LongKeyedBucketOrds.FromManySmall - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Implementation that packs the
owningbucketOrd
into the top bits of along
and uses the bottom bits for the value. - LongKeyedBucketOrds.FromSingle - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Implementation that only works if it is collecting from a single bucket.
- LongLongHash - Class in org.elasticsearch.common.util
-
Specialized hash table implementation similar to BytesRefHash that maps two long values to ids.
- LongLongHash(long, float, BigArrays) - Constructor for class org.elasticsearch.common.util.LongLongHash
- LongLongHash(long, BigArrays) - Constructor for class org.elasticsearch.common.util.LongLongHash
- LongObjectPagedHashMap<T> - Class in org.elasticsearch.common.util
-
A hash table from native longs to objects.
- LongObjectPagedHashMap(long, float, BigArrays) - Constructor for class org.elasticsearch.common.util.LongObjectPagedHashMap
- LongObjectPagedHashMap(long, BigArrays) - Constructor for class org.elasticsearch.common.util.LongObjectPagedHashMap
- LongObjectPagedHashMap.Cursor<T> - Class in org.elasticsearch.common.util
- longPage(boolean) - Method in class org.elasticsearch.common.util.PageCacheRecycler
- longRangeQuery(Object, Object, boolean, boolean, BiFunction<Long, Long, Query>) - Static method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
-
Processes query bounds into
long
s and delegates the providedbuilder
to build a range query. - LongRareTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Result of the RareTerms aggregation when the field is some kind of whole number like a integer, long, or a date.
- LongRareTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms
-
Read from a stream.
- LongRareTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- LongRareTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
-
An aggregator that finds "rare" string values (e.g.
- Longs(SortedNumericDocValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
-
Standard constructor.
- LongScriptDocValues - Class in org.elasticsearch.index.fielddata
- LongScriptFieldData - Class in org.elasticsearch.index.fielddata
- LongScriptFieldData.Builder - Class in org.elasticsearch.index.fielddata
- LongScriptFieldData.LongScriptLeafFieldData - Class in org.elasticsearch.index.fielddata
- LongScriptFieldDistanceFeatureQuery - Class in org.elasticsearch.search.runtime
- LongScriptFieldDistanceFeatureQuery(Script, Function<LeafReaderContext, AbstractLongFieldScript>, String, long, long) - Constructor for class org.elasticsearch.search.runtime.LongScriptFieldDistanceFeatureQuery
- LongScriptFieldExistsQuery - Class in org.elasticsearch.search.runtime
- LongScriptFieldExistsQuery(Script, Function<LeafReaderContext, AbstractLongFieldScript>, String) - Constructor for class org.elasticsearch.search.runtime.LongScriptFieldExistsQuery
- LongScriptFieldRangeQuery - Class in org.elasticsearch.search.runtime
- LongScriptFieldRangeQuery(Script, Function<LeafReaderContext, AbstractLongFieldScript>, String, long, long) - Constructor for class org.elasticsearch.search.runtime.LongScriptFieldRangeQuery
- LongScriptFieldTermQuery - Class in org.elasticsearch.search.runtime
- LongScriptFieldTermQuery(Script, Function<LeafReaderContext, AbstractLongFieldScript>, String, long) - Constructor for class org.elasticsearch.search.runtime.LongScriptFieldTermQuery
- LongScriptFieldTermsQuery - Class in org.elasticsearch.search.runtime
- LongScriptFieldTermsQuery(Script, Function<LeafReaderContext, AbstractLongFieldScript>, String, LongSet) - Constructor for class org.elasticsearch.search.runtime.LongScriptFieldTermsQuery
- LongScriptFieldType - Class in org.elasticsearch.index.mapper
- LongScriptFieldType(String, LongFieldScript.Factory, Script, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.LongScriptFieldType
- longSetting(String, long, long, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- LongTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Result of the
TermsAggregator
when the field is some kind of whole number like a integer, long, or a date. - LongTerms(String, BucketOrder, BucketOrder, int, long, Map<String, Object>, DocValueFormat, int, boolean, long, List<LongTerms.Bucket>, Long) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- LongTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
-
Read from a stream.
- LongTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- longToBytes(long) - Static method in class org.elasticsearch.common.Numbers
-
Converts a long to a byte array.
- longValue() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic.LongAccessor
- longValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashCellIdSource
- longValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileCellIdSource
- longValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.FieldData
- longValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
-
Get a 64 bit signed view into the values in this leaf.
- longValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
- longValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
- LongValuesComparatorSource - Class in org.elasticsearch.index.fielddata.fieldcomparator
-
Comparator source for long values.
- LongValuesComparatorSource(IndexNumericFieldData, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, Function<SortedNumericDocValues, SortedNumericDocValues>, IndexNumericFieldData.NumericType) - Constructor for class org.elasticsearch.index.fielddata.fieldcomparator.LongValuesComparatorSource
- LongValuesComparatorSource(IndexNumericFieldData, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, IndexNumericFieldData.NumericType) - Constructor for class org.elasticsearch.index.fielddata.fieldcomparator.LongValuesComparatorSource
- lonToSphericalMercator(double) - Static method in class org.elasticsearch.common.geo.SphericalMercatorUtils
-
Transforms WGS84 longitude to a Spherical mercator longitude
- lookup() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Get the lookup to use during the search.
- lookup() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Fetch the shared
SearchLookup
. - lookup() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- lookup(long) - Method in class org.elasticsearch.common.LocalTimeOffset.Lookup
-
Lookup the offset at the provided millis in utc.
- lookup(String, XContentLocation, DeprecationHandler) - Method in class org.elasticsearch.common.xcontent.ParseFieldRegistry
-
Lookup a value from the registry by name while checking that the name matches the ParseField.
- lookup(ZoneId, long, long) - Static method in class org.elasticsearch.common.LocalTimeOffset
-
Lookup offsets for a provided zone.
- Lookup() - Constructor for class org.elasticsearch.common.LocalTimeOffset.Lookup
- lookupOrd(long) - Method in interface org.elasticsearch.index.fielddata.ordinals.Ordinals.ValuesHolder
- lookupReturningNullIfNotFound(String, DeprecationHandler) - Method in class org.elasticsearch.common.xcontent.ParseFieldRegistry
-
Lookup a value from the registry by name while checking that the name matches the ParseField.
- lookupTemplateForDataStream(String, Metadata) - Static method in class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService
- LOW - Enum constant in enum class org.elasticsearch.common.Priority
- LOW - Enum constant in enum class org.elasticsearch.watcher.ResourceWatcherService.Frequency
-
Defaults to 60 seconds
- LOW_LEVEL_CANCELLATION_SETTING - Static variable in class org.elasticsearch.search.SearchService
-
Enables low-level, frequent search cancellation checks.
- LOWER - Enum constant in enum class org.elasticsearch.search.aggregations.metrics.ExtendedStats.Bounds
- LOWER_POPULATION - Enum constant in enum class org.elasticsearch.search.aggregations.metrics.ExtendedStats.Bounds
- LOWER_SAMPLING - Enum constant in enum class org.elasticsearch.search.aggregations.metrics.ExtendedStats.Bounds
- LowercaseNormalizer - Class in org.elasticsearch.index.analysis
-
Normalizer used to lowercase values
- LowercaseNormalizer() - Constructor for class org.elasticsearch.index.analysis.LowercaseNormalizer
- LowercaseNormalizerProvider - Class in org.elasticsearch.index.analysis
-
Builds an analyzer for normalization that lowercases terms.
- LowercaseNormalizerProvider(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.LowercaseNormalizerProvider
- lowFreqMinimumShouldMatch() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- lowFreqMinimumShouldMatch(String) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.Sets the minimum number of low frequent query terms that need to match in order to produce a hit.
- lowFreqOperator() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- lowFreqOperator(Operator) - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.Sets the operator to use for terms with a low document frequency (less than
CommonTermsQueryBuilder.cutoffFrequency(float)
. - lowLevelCancellation() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- lowLevelCancellation() - Method in class org.elasticsearch.search.internal.SearchContext
-
Indicates if the current index should perform frequent low level search cancellation check.
- lt(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- LT_FIELD - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- lte(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- LTE_FIELD - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- Lucene - Class in org.elasticsearch.common.lucene
- LUCENE - Enum constant in enum class org.elasticsearch.indices.analysis.PreBuiltCacheFactory.CachingStrategy
- LUCENE_DEFAULT_CODEC - Static variable in class org.elasticsearch.index.codec.CodecService
-
the raw unfiltered lucene default.
- LuceneDocument - Class in org.elasticsearch.index.mapper
-
Fork of
Document
with additional functionality. - LuceneDocument() - Constructor for class org.elasticsearch.index.mapper.LuceneDocument
- LuceneFilesExtensions - Enum Class in org.elasticsearch.index.store
- luceneVersion - Variable in class org.elasticsearch.Version
- luceneVersion(String, boolean, BiFunction<Reader, Version, Reader>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredCharFilter
-
Create a pre-configured token filter that may vary based on the Lucene version.
- luceneVersion(String, boolean, BiFunction<TokenStream, Version, TokenStream>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredTokenFilter
-
Create a pre-configured token filter that may vary based on the Lucene version.
- luceneVersion(String, Function<Version, Tokenizer>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredTokenizer
-
Create a pre-configured tokenizer that may vary based on the Lucene version.
- LZ4 - Enum constant in enum class org.elasticsearch.transport.Compression.Scheme
- lz4Decompressor() - Static method in enum class org.elasticsearch.transport.Compression.Scheme
- lz4OutputStream(OutputStream) - Static method in enum class org.elasticsearch.transport.Compression.Scheme
- Lz4TransportDecompressor - Class in org.elasticsearch.transport
-
This file is forked from the https://netty.io project.
- Lz4TransportDecompressor(PageCacheRecycler) - Constructor for class org.elasticsearch.transport.Lz4TransportDecompressor
M
- m - Variable in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLog
- MacAddressProvider - Class in org.elasticsearch.common
- MacAddressProvider() - Constructor for class org.elasticsearch.common.MacAddressProvider
- main(String[]) - Static method in class org.elasticsearch.cluster.coordination.NodeToolCli
- main(String[]) - Static method in class org.elasticsearch.index.shard.ShardToolCli
- main(String[]) - Static method in class org.elasticsearch.Version
- MainAction - Class in org.elasticsearch.action.main
- MainAction() - Constructor for class org.elasticsearch.action.main.MainAction
- MainRequest - Class in org.elasticsearch.action.main
- MainRequest() - Constructor for class org.elasticsearch.action.main.MainRequest
- MainRequestBuilder - Class in org.elasticsearch.action.main
- MainRequestBuilder(ElasticsearchClient, MainAction) - Constructor for class org.elasticsearch.action.main.MainRequestBuilder
- MainResponse - Class in org.elasticsearch.action.main
- MainResponse(String, Version, ClusterName, String, Build) - Constructor for class org.elasticsearch.action.main.MainResponse
- major - Variable in class org.elasticsearch.Version
- majorDeviceNumber - Variable in class org.elasticsearch.env.NodeEnvironment.DataPath
- makeAllocationDecision(ShardRouting, RoutingAllocation, Logger) - Method in class org.elasticsearch.gateway.BaseGatewayShardAllocator
-
Make a decision on the allocation of an unassigned shard.
- makeAllocationDecision(ShardRouting, RoutingAllocation, Logger) - Method in class org.elasticsearch.gateway.PrimaryShardAllocator
- makeAllocationDecision(ShardRouting, RoutingAllocation, Logger) - Method in class org.elasticsearch.gateway.ReplicaShardAllocator
- makeFragment(StringBuilder, int[], Field[], FieldFragList.WeightedFragInfo, String[], String[], Encoder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.SimpleFragmentsBuilder
- makeFragment(StringBuilder, int[], Field[], FieldFragList.WeightedFragInfo, String[], String[], Encoder) - Method in class org.elasticsearch.search.fetch.subphase.highlight.SourceScoreOrderFragmentsBuilder
- makeKeySafe(TypeLiteral<T>) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
Returns an equivalent type that's safe for use in a key.
- makeWrapper(ResponseCollectorService) - Static method in class org.elasticsearch.action.search.SearchExecutionStatsCollector
- MANAGED_SYSTEM_INDEX_SETTING_UPDATE_ALLOWLIST - Static variable in class org.elasticsearch.indices.SystemIndexManager
- MANAGEMENT - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- MANDATORY_SETTING - Static variable in class org.elasticsearch.plugins.PluginsService
- Manifest - Class in org.elasticsearch.cluster.metadata
-
This class represents the manifest file, which is the entry point for reading meta data from disk.
- Manifest(long, long, long, Map<Index, Long>) - Constructor for class org.elasticsearch.cluster.metadata.Manifest
- MANIFEST_FORMAT - Variable in class org.elasticsearch.gateway.MetaStateService
- MANUAL_ALLOCATION - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Forced manually to allocate
- MANY - Enum constant in enum class org.elasticsearch.search.aggregations.AggregationBuilder.BucketCardinality
- MANY - Static variable in class org.elasticsearch.search.aggregations.CardinalityUpperBound
-
Aggregator
s with this cardinality may be collected many times. - map() - Method in class org.elasticsearch.common.collect.MapBuilder
- map(IntFunction<R>) - Method in class org.elasticsearch.search.aggregations.CardinalityUpperBound
-
Map the cardinality to a value.
- map(CheckedFunction<T, Response, Exception>) - Method in interface org.elasticsearch.action.ActionListener
-
Creates a listener that wraps this listener, mapping response values via the given mapping function and passing along exceptions to this instance.
- map(CheckedFunction<T, Response, Exception>) - Method in class org.elasticsearch.action.ActionListener.MappedActionListener
- MAP - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
- MAP - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregatorFactory.ExecutionMode
- MAP - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregatorFactory.ExecutionMode
- MAP - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
- MapBinder<K,
V> - Class in org.elasticsearch.common.inject.multibindings -
An API to bind multiple map entries separately, only to later inject them as a complete map.
- MapBinder.RealMapBinder<K,
V> - Class in org.elasticsearch.common.inject.multibindings -
The actual mapbinder plays several roles:
- MapBinder.RealMapBinder.MapBinderProviderWithDependencies<K,
V> - Class in org.elasticsearch.common.inject.multibindings - MapBuilder<K,
V> - Class in org.elasticsearch.common.collect - MapBuilder() - Constructor for class org.elasticsearch.common.collect.MapBuilder
- MapBuilder(Map<K, V>) - Constructor for class org.elasticsearch.common.collect.MapBuilder
- MapDiff(DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Constructor for class org.elasticsearch.cluster.DiffableUtils.MapDiff
- MapDiff(DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>, List<K>, Map<K, Diff<T>>, Map<K, T>) - Constructor for class org.elasticsearch.cluster.DiffableUtils.MapDiff
- MapDiff(StreamInput, DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Constructor for class org.elasticsearch.cluster.DiffableUtils.MapDiff
- mapOf(Type, Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a type modelling a
Map
whose keys are of typekeyType
and whose values are of typevalueType
. - mappedFieldType - Variable in class org.elasticsearch.index.mapper.FieldMapper
- MappedFieldType - Class in org.elasticsearch.index.mapper
-
This defines the core properties and functions to operate on a field.
- MappedFieldType(String, boolean, boolean, boolean, TextSearchInfo, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.MappedFieldType
- MappedFieldType.CollapseType - Enum Class in org.elasticsearch.index.mapper
- MappedFieldType.Relation - Enum Class in org.elasticsearch.index.mapper
-
An enum used to describe the relation between the range of terms in a shard when compared with a query range
- Mapper - Class in org.elasticsearch.index.mapper
- Mapper(String) - Constructor for class org.elasticsearch.index.mapper.Mapper
- Mapper.Builder - Class in org.elasticsearch.index.mapper
- Mapper.TypeParser - Interface in org.elasticsearch.index.mapper
- MapperBuilderContext - Class in org.elasticsearch.index.mapper
-
Holds context for building Mapper objects from their Builders
- MapperException - Exception in org.elasticsearch.index.mapper
- MapperException(String) - Constructor for exception org.elasticsearch.index.mapper.MapperException
- MapperException(String, Throwable) - Constructor for exception org.elasticsearch.index.mapper.MapperException
- MapperException(String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.mapper.MapperException
- MapperException(StreamInput) - Constructor for exception org.elasticsearch.index.mapper.MapperException
- MapperParsingException - Exception in org.elasticsearch.index.mapper
- MapperParsingException(String) - Constructor for exception org.elasticsearch.index.mapper.MapperParsingException
- MapperParsingException(String, Throwable) - Constructor for exception org.elasticsearch.index.mapper.MapperParsingException
- MapperParsingException(String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.mapper.MapperParsingException
- MapperParsingException(StreamInput) - Constructor for exception org.elasticsearch.index.mapper.MapperParsingException
- MapperPlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
implementations to add custom mappers - MapperRegistry - Class in org.elasticsearch.index.mapper
-
A registry for all field mappers.
- MapperRegistry(Map<String, Mapper.TypeParser>, Map<String, RuntimeField.Parser>, Map<String, MetadataFieldMapper.TypeParser>, Function<String, Predicate<String>>) - Constructor for class org.elasticsearch.index.mapper.MapperRegistry
- mappers - Variable in class org.elasticsearch.index.mapper.ObjectMapper
- mappers() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- mappersBuilders - Variable in class org.elasticsearch.index.mapper.ObjectMapper.Builder
- mapperService() - Method in class org.elasticsearch.index.IndexService
- mapperService() - Method in class org.elasticsearch.index.shard.IndexShard
- mapperService() - Method in class org.elasticsearch.repositories.SnapshotShardContext
- MapperService - Class in org.elasticsearch.index.mapper
- MapperService(IndexSettings, IndexAnalyzers, NamedXContentRegistry, SimilarityService, MapperRegistry, Supplier<SearchExecutionContext>, BooleanSupplier, ScriptCompiler) - Constructor for class org.elasticsearch.index.mapper.MapperService
- MapperService.MergeReason - Enum Class in org.elasticsearch.index.mapper
-
The reason why a mapping is being merged.
- mapping() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Return the concrete mapping for this index or
null
if this index has no mappings at all. - mapping() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- mapping(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- mapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- mapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- mapping(String, Object...) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- mapping(String, String, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Adds mapping that will be added when the index gets created.
- mapping(String, String, XContentType) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- mapping(String, String, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Adds mapping that will be added when the index gets created.
- mapping(String, Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Adds mapping that will be added when the index gets created.
- mapping(String, Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Adds mapping that will be added when the index gets created.
- mapping(String, BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Adds mapping that will be added when the index gets created.
- mapping(String, XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Adds mapping that will be added when the index gets created.
- mapping(String, XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Adds mapping that will be added when the index gets created.
- Mapping - Class in org.elasticsearch.index.mapper
-
Wrapper around everything that defines a mapping, without references to utility classes like MapperService, ...
- Mapping(RootObjectMapper, MetadataFieldMapper[], Map<String, Object>) - Constructor for class org.elasticsearch.index.mapper.Mapping
- MAPPING_RECOVERY - Enum constant in enum class org.elasticsearch.index.mapper.MapperService.MergeReason
-
Recovery of an existing mapping, for instance because of a restart, if a shard was moved to a different node or for administrative purposes.
- MAPPING_UPDATE - Enum constant in enum class org.elasticsearch.index.mapper.MapperService.MergeReason
-
Create or update a mapping.
- MAPPING_UPDATE_PREFLIGHT - Enum constant in enum class org.elasticsearch.index.mapper.MapperService.MergeReason
-
Pre-flight check before sending a mapping update to the master
- MAPPING_UPDATE_REQUIRED - Enum constant in enum class org.elasticsearch.index.engine.Engine.Result.Type
- mappingCacheKey() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Cache key for current mapping.
- mappingForName(String, String) - Method in class org.elasticsearch.index.mapper.DynamicTemplate
- mappingLookup() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- mappingLookup() - Method in class org.elasticsearch.index.mapper.MapperService
-
Exposes a snapshot of the mappings for the current index.
- MappingLookup - Class in org.elasticsearch.index.mapper
-
A (mostly) immutable snapshot of the current mapping of an index with access to everything we need for the search phase.
- MappingLookup.CacheKey - Class in org.elasticsearch.index.mapper
-
Key for the lookup to be used in caches.
- MappingMetadata - Class in org.elasticsearch.cluster.metadata
-
Mapping configuration for a type.
- MappingMetadata(String, Map<String, Object>) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetadata
- MappingMetadata(CompressedXContent) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetadata
- MappingMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetadata
- MappingMetadata(DocumentMapper) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetadata
- MappingMetadata.Routing - Class in org.elasticsearch.cluster.metadata
- mappingOrDefault() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Sometimes, the default mapping exists and an actual mapping is not created yet (introduced), in this case, we want to return the default mapping in case it has some default mapping definitions.
- MappingParser - Class in org.elasticsearch.index.mapper
-
Parser for
Mapping
provided inCompressedXContent
format - MappingParserContext - Class in org.elasticsearch.index.mapper
-
Holds everything that is needed to parse mappings.
- MappingParserContext(Function<String, SimilarityProvider>, Function<String, Mapper.TypeParser>, Function<String, RuntimeField.Parser>, Version, Supplier<SearchExecutionContext>, DateFormatter, ScriptCompiler, IndexAnalyzers, IndexSettings, BooleanSupplier) - Constructor for class org.elasticsearch.index.mapper.MappingParserContext
- mappingRequestValidators() - Method in interface org.elasticsearch.plugins.ActionPlugin
-
Returns a collection of validators that are used by
RequestValidators
to validate aPutMappingRequest
before the executing it. - mappings() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- mappings() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- mappings() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- mappings() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
-
returns the retrieved field mapping.
- mappings() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- mappings() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- mappings() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- mappings() - Method in class org.elasticsearch.cluster.metadata.Template
- mappings(Map<String, String>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- mappings(Map<String, String>) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutRequest
- MAPPINGS - Enum constant in enum class org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
- MAPPINGS - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- MAPPINGS - Static variable in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- mappingSource() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- MappingStats - Class in org.elasticsearch.action.admin.cluster.stats
-
Usage statistics about mappings usage.
- mappingType(String) - Method in class org.elasticsearch.index.mapper.DynamicTemplate
- MappingUpdatedAction - Class in org.elasticsearch.cluster.action.index
-
Called by shards in the cluster when their mapping was dynamically updated and it needs to be updated in the cluster state meta data (and broadcast to all members).
- MappingUpdatedAction(Settings, ClusterSettings, ClusterService) - Constructor for class org.elasticsearch.cluster.action.index.MappingUpdatedAction
- MappingUpdatePerformer - Interface in org.elasticsearch.action.bulk
- mappingVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- mappingVersion(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- MappingVisitor - Class in org.elasticsearch.action.admin.cluster.stats
- Maps - Class in org.elasticsearch.common.util
- Maps() - Constructor for class org.elasticsearch.common.util.Maps
- mapScript() - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
-
Get the
map
script. - mapScript(Script) - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
-
Set the
map
script. - MapScript(Map<String, Object>, Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- MapStringTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
-
An aggregator of string values that hashes the strings on the fly rather than up front like the
GlobalOrdinalsStringTermsAggregator
. - MapStringTermsAggregator(String, AggregatorFactories, MapStringTermsAggregator.CollectorSource, Function<MapStringTermsAggregator, MapStringTermsAggregator.ResultStrategy<?, ?>>, BucketOrder, DocValueFormat, TermsAggregator.BucketCountThresholds, IncludeExclude.StringFilter, AggregationContext, Aggregator, Aggregator.SubAggCollectionMode, boolean, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator
- MapStringTermsAggregator.CollectConsumer - Interface in org.elasticsearch.search.aggregations.bucket.terms
- MapStringTermsAggregator.CollectorSource - Interface in org.elasticsearch.search.aggregations.bucket.terms
-
Abstraction on top of building collectors to fetch values so
terms
,significant_terms
, andsignificant_text
can share a bunch of aggregation code. - MapStringTermsAggregator.ValuesSourceCollectorSource - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Fetch values from a
ValuesSource
. - mark(int) - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- mark(int) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- mark(int) - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- mark(int) - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- markAllocationIdAsInSync(String, long) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Marks the shard with the provided allocation ID as in-sync with the primary shard.
- markAllocationIdAsInSync(String, long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Marks the shard with the provided allocation ID as in-sync with the primary shard.
- markAsCancelled() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- markAsCommitted(String, PendingClusterStatesQueue.StateProcessedListener) - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
Mark a previously added cluster state as committed.
- markAsCompleted() - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- markAsDone() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
mark the current recovery as done
- markAsFailed(Exception) - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
- markAsFailed(Exception) - Method in class org.elasticsearch.upgrades.SystemIndexMigrator
-
Clears the migration queue, marks the task as failed, and saves the exception for later retrieval.
- markAsFailed(ClusterState, Exception) - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
mark that the processing of the given state has failed.
- markAsLocallyAborted(String) - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
-
Indicates that this persistent task is no longer going to run on the local node.
- markAsProcessed(ClusterState) - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
indicates that a cluster state was successfully processed.
- markAsRecovering(String, RecoveryState) - Method in class org.elasticsearch.index.shard.IndexShard
-
Marks the shard as recovering based on a recovery state, fails with exception is recovering is not allowed to be set.
- markAsStale() - Method in class org.elasticsearch.cluster.routing.allocation.FailedShard
-
Whether or not to mark the shard as stale (eg.
- markAsSystemContext() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Marks this thread context as an internal system context.
- markAsUsed(long) - Method in class org.elasticsearch.search.internal.ReaderContext
-
Returns a releasable to indicate that the caller has stopped using this reader.
- markBytesRead(long) - Method in class org.elasticsearch.transport.StatsTracker
- markBytesWritten(long) - Method in class org.elasticsearch.transport.StatsTracker
- markCoordinatingOperationStarted(long, boolean) - Method in class org.elasticsearch.index.IndexingPressure
- MARKER_BYTES_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- markLastAcceptedStateAsCommitted() - Method in interface org.elasticsearch.cluster.coordination.CoordinationState.PersistedState
-
Marks the last accepted cluster state as committed.
- markMessageReceived() - Method in class org.elasticsearch.transport.StatsTracker
- markPrimaryOperationLocalToCoordinatingNodeStarted(long) - Method in class org.elasticsearch.index.IndexingPressure
- markPrimaryOperationStarted(long, boolean) - Method in class org.elasticsearch.index.IndexingPressure
- markReceivedAndCreateListener(long, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RecoveryRequestTracker
-
This method will mark that a request with a unique sequence number has been received.
- markRecoveryAsDone(long) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
mark the recovery with the given id as done (if found)
- markReplicaOperationStarted(long, boolean) - Method in class org.elasticsearch.index.IndexingPressure
- markRequestReceivedAndCreateListener(long, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- markSeqNoAsNoop(long, long, String) - Method in class org.elasticsearch.index.shard.IndexShard
- markSeqNoAsPersisted(long) - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
Marks the provided sequence number as persisted and updates the checkpoint if possible.
- markSeqNoAsProcessed(long) - Method in class org.elasticsearch.index.seqno.LocalCheckpointTracker
-
Marks the provided sequence number as processed and updates the processed checkpoint if possible.
- markSeqNoAsSeen(long) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Marks the given seq_no as seen and advances the max_seq_no of this engine to at least that value.
- markShardCopyAsStaleIfNeeded(ShardId, String, long, ActionListener<Void>) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Replicas
-
Marks shard copy as stale if needed, removing its allocation id from the set of in-sync allocation ids.
- markShardCopyAsStaleIfNeeded(ShardId, String, long, ActionListener<Void>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicasProxy
- markStoreCorrupted(IOException) - Method in class org.elasticsearch.index.store.Store
-
Marks this store as corrupted.
- markSuccess() - Method in class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
-
Mark all blob bytes as properly received by
ChunkedBlobOutputStream.write(int)
, indicating thatChunkedBlobOutputStream.close()
may finalize the blob. - markSupported() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- markSupported() - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- markSupported() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- markSupported() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- MASK_2_63 - Static variable in interface org.elasticsearch.search.DocValueFormat
- master() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingResponse
-
the current master of the node
- MASTER_ELECTION_IGNORE_NON_MASTER_PINGS_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- MASTER_ELECTION_WAIT_FOR_JOINS_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- MASTER_NODE - Enum constant in enum class org.elasticsearch.cluster.ClusterState.Metric
- MASTER_PING_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.MasterFaultDetection
- MASTER_ROLE - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
Represents the role for a master-eligible node.
- MASTER_SERVICE_SLOW_TASK_LOGGING_THRESHOLD_SETTING - Static variable in class org.elasticsearch.cluster.service.MasterService
- MASTER_SERVICE_STARVATION_LOGGING_THRESHOLD_SETTING - Static variable in class org.elasticsearch.cluster.service.MasterService
- MasterCandidate(DiscoveryNode, long) - Constructor for class org.elasticsearch.discovery.zen.ElectMasterService.MasterCandidate
- MasterFaultDetection - Class in org.elasticsearch.discovery.zen
-
A fault detection that pings the master periodically to see if its alive.
- MasterFaultDetection(Settings, ThreadPool, TransportService, Supplier<ClusterState>, MasterService, ClusterName) - Constructor for class org.elasticsearch.discovery.zen.MasterFaultDetection
- MasterFaultDetection.Listener - Interface in org.elasticsearch.discovery.zen
- MasterFaultDetection.MasterPingRequest - Class in org.elasticsearch.discovery.zen
- MasterFaultDetection.MasterPingResponseResponse - Class in org.elasticsearch.discovery.zen
- MasterFaultDetection.ThisIsNotTheMasterYouAreLookingForException - Exception in org.elasticsearch.discovery.zen
-
Thrown when a ping reaches the wrong node
- masterNode() - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- masterNode() - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection.PingRequest
- masterNodeChanged() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- MasterNodeChangePredicate - Class in org.elasticsearch.cluster
- masterNodeId(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- MasterNodeOperationRequestBuilder<Request extends MasterNodeRequest<Request>,
Response extends ActionResponse, RequestBuilder extends MasterNodeOperationRequestBuilder<Request, Response, RequestBuilder>> - Class in org.elasticsearch.action.support.master -
Base request builder for master node operations
- MasterNodeOperationRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.support.master.MasterNodeOperationRequestBuilder
- MasterNodeReadOperationRequestBuilder<Request extends MasterNodeReadRequest<Request>,
Response extends ActionResponse, RequestBuilder extends MasterNodeReadOperationRequestBuilder<Request, Response, RequestBuilder>> - Class in org.elasticsearch.action.support.master -
Base request builder for master node read operations that can be executed on the local node as well
- MasterNodeReadOperationRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.support.master.MasterNodeReadOperationRequestBuilder
- MasterNodeReadRequest<Request extends MasterNodeReadRequest<Request>> - Class in org.elasticsearch.action.support.master
-
Base request for master based read operations that allows to read the cluster state from the local node if needed
- MasterNodeReadRequest() - Constructor for class org.elasticsearch.action.support.master.MasterNodeReadRequest
- MasterNodeReadRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.master.MasterNodeReadRequest
- MasterNodeRequest<Request extends MasterNodeRequest<Request>> - Class in org.elasticsearch.action.support.master
-
A based request for master based operation.
- MasterNodeRequest() - Constructor for class org.elasticsearch.action.support.master.MasterNodeRequest
- MasterNodeRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.master.MasterNodeRequest
- masterNodeTimeout - Variable in class org.elasticsearch.action.support.master.MasterNodeRequest
- masterNodeTimeout() - Method in class org.elasticsearch.action.support.master.MasterNodeRequest
- masterNodeTimeout() - Method in interface org.elasticsearch.cluster.ack.AckedRequest
-
Returns the timeout for the request to be completed on the master node
- masterNodeTimeout() - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
-
Returns the maximum time interval to wait for the request to be completed on the master node
- masterNodeTimeout(String) - Method in class org.elasticsearch.action.support.master.MasterNodeRequest
-
A timeout value in case the master has not been discovered yet or disconnected.
- masterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.support.master.MasterNodeRequest
-
A timeout value in case the master has not been discovered yet or disconnected.
- masterNodeTimeout(TimeValue) - Method in class org.elasticsearch.cluster.ack.ClusterStateUpdateRequest
-
Sets the master node timeout
- MasterNotDiscoveredException - Exception in org.elasticsearch.discovery
- MasterNotDiscoveredException() - Constructor for exception org.elasticsearch.discovery.MasterNotDiscoveredException
- MasterNotDiscoveredException(String) - Constructor for exception org.elasticsearch.discovery.MasterNotDiscoveredException
- MasterNotDiscoveredException(Throwable) - Constructor for exception org.elasticsearch.discovery.MasterNotDiscoveredException
- MasterNotDiscoveredException(StreamInput) - Constructor for exception org.elasticsearch.discovery.MasterNotDiscoveredException
- masterOperation(ClusterAllocationExplainRequest, ClusterState, ActionListener<ClusterAllocationExplainResponse>) - Method in class org.elasticsearch.action.admin.cluster.allocation.TransportClusterAllocationExplainAction
- masterOperation(AddVotingConfigExclusionsRequest, ClusterState, ActionListener<ActionResponse.Empty>) - Method in class org.elasticsearch.action.admin.cluster.configuration.TransportAddVotingConfigExclusionsAction
- masterOperation(ClearVotingConfigExclusionsRequest, ClusterState, ActionListener<ActionResponse.Empty>) - Method in class org.elasticsearch.action.admin.cluster.configuration.TransportClearVotingConfigExclusionsAction
- masterOperation(ClusterHealthRequest, ClusterState, ActionListener<ClusterHealthResponse>) - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
- masterOperation(GetFeatureUpgradeStatusRequest, ClusterState, ActionListener<GetFeatureUpgradeStatusResponse>) - Method in class org.elasticsearch.action.admin.cluster.migration.TransportGetFeatureUpgradeStatusAction
- masterOperation(PostFeatureUpgradeRequest, ClusterState, ActionListener<PostFeatureUpgradeResponse>) - Method in class org.elasticsearch.action.admin.cluster.migration.TransportPostFeatureUpgradeAction
- masterOperation(CleanupRepositoryRequest, ClusterState, ActionListener<CleanupRepositoryResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.cleanup.TransportCleanupRepositoryAction
- masterOperation(DeleteRepositoryRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.TransportDeleteRepositoryAction
- masterOperation(GetRepositoriesRequest, ClusterState, ActionListener<GetRepositoriesResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
- masterOperation(PutRepositoryRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.TransportPutRepositoryAction
- masterOperation(VerifyRepositoryRequest, ClusterState, ActionListener<VerifyRepositoryResponse>) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.TransportVerifyRepositoryAction
- masterOperation(ClusterRerouteRequest, ClusterState, ActionListener<ClusterRerouteResponse>) - Method in class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
- masterOperation(ClusterUpdateSettingsRequest, ClusterState, ActionListener<ClusterUpdateSettingsResponse>) - Method in class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
- masterOperation(ClusterSearchShardsRequest, ClusterState, ActionListener<ClusterSearchShardsResponse>) - Method in class org.elasticsearch.action.admin.cluster.shards.TransportClusterSearchShardsAction
- masterOperation(CloneSnapshotRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.TransportCloneSnapshotAction
- masterOperation(CreateSnapshotRequest, ClusterState, ActionListener<CreateSnapshotResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.TransportCreateSnapshotAction
- masterOperation(DeleteSnapshotRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.TransportDeleteSnapshotAction
- masterOperation(GetSnapshottableFeaturesRequest, ClusterState, ActionListener<GetSnapshottableFeaturesResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.TransportSnapshottableFeaturesAction
- masterOperation(ResetFeatureStateRequest, ClusterState, ActionListener<ResetFeatureStateResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.TransportResetFeatureStateAction
- masterOperation(GetSnapshotsRequest, ClusterState, ActionListener<GetSnapshotsResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.TransportGetSnapshotsAction
- masterOperation(GetShardSnapshotRequest, ClusterState, ActionListener<GetShardSnapshotResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.TransportGetShardSnapshotAction
- masterOperation(RestoreSnapshotRequest, ClusterState, ActionListener<RestoreSnapshotResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.TransportRestoreSnapshotAction
- masterOperation(SnapshotsStatusRequest, ClusterState, ActionListener<SnapshotsStatusResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportSnapshotsStatusAction
- masterOperation(ClusterStateRequest, ClusterState, ActionListener<ClusterStateResponse>) - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
- masterOperation(DeleteStoredScriptRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportDeleteStoredScriptAction
- masterOperation(GetStoredScriptRequest, ClusterState, ActionListener<GetStoredScriptResponse>) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportGetStoredScriptAction
- masterOperation(PutStoredScriptRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.TransportPutStoredScriptAction
- masterOperation(PendingClusterTasksRequest, ClusterState, ActionListener<PendingClusterTasksResponse>) - Method in class org.elasticsearch.action.admin.cluster.tasks.TransportPendingClusterTasksAction
- masterOperation(GetAliasesRequest, ClusterState, ActionListener<AliasesExistResponse>) - Method in class org.elasticsearch.action.admin.indices.alias.exists.TransportAliasesExistAction
- masterOperation(GetAliasesRequest, ClusterState, ActionListener<GetAliasesResponse>) - Method in class org.elasticsearch.action.admin.indices.alias.get.TransportGetAliasesAction
- masterOperation(IndicesAliasesRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
- masterOperation(CloseIndexRequest, ClusterState, ActionListener<CloseIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
- masterOperation(CreateIndexRequest, ClusterState, ActionListener<CreateIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.create.AutoCreateAction.TransportAction
- masterOperation(CreateIndexRequest, ClusterState, ActionListener<CreateIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
- masterOperation(DeleteDanglingIndexRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.dangling.delete.TransportDeleteDanglingIndexAction
- masterOperation(DeleteIndexRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
- masterOperation(IndicesExistsRequest, ClusterState, ActionListener<IndicesExistsResponse>) - Method in class org.elasticsearch.action.admin.indices.exists.indices.TransportIndicesExistsAction
- masterOperation(TypesExistsRequest, ClusterState, ActionListener<TypesExistsResponse>) - Method in class org.elasticsearch.action.admin.indices.exists.types.TransportTypesExistsAction
- masterOperation(PutMappingRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportAutoPutMappingAction
- masterOperation(PutMappingRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
- masterOperation(OpenIndexRequest, ClusterState, ActionListener<OpenIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
- masterOperation(AddIndexBlockRequest, ClusterState, ActionListener<AddIndexBlockResponse>) - Method in class org.elasticsearch.action.admin.indices.readonly.TransportAddIndexBlockAction
- masterOperation(RolloverRequest, ClusterState, ActionListener<RolloverResponse>) - Method in class org.elasticsearch.action.admin.indices.rollover.TransportRolloverAction
- masterOperation(GetSettingsRequest, ClusterState, ActionListener<GetSettingsResponse>) - Method in class org.elasticsearch.action.admin.indices.settings.get.TransportGetSettingsAction
- masterOperation(UpdateSettingsRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.settings.put.TransportUpdateSettingsAction
- masterOperation(IndicesShardStoresRequest, ClusterState, ActionListener<IndicesShardStoresResponse>) - Method in class org.elasticsearch.action.admin.indices.shards.TransportIndicesShardStoresAction
- masterOperation(ResizeRequest, ClusterState, ActionListener<ResizeResponse>) - Method in class org.elasticsearch.action.admin.indices.shrink.TransportResizeAction
- masterOperation(DeleteComponentTemplateAction.Request, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteComponentTemplateAction
- masterOperation(DeleteComposableIndexTemplateAction.Request, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteComposableIndexTemplateAction
- masterOperation(DeleteIndexTemplateRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
- masterOperation(GetComponentTemplateAction.Request, ClusterState, ActionListener<GetComponentTemplateAction.Response>) - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetComponentTemplateAction
- masterOperation(GetComposableIndexTemplateAction.Request, ClusterState, ActionListener<GetComposableIndexTemplateAction.Response>) - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetComposableIndexTemplateAction
- masterOperation(GetIndexTemplatesRequest, ClusterState, ActionListener<GetIndexTemplatesResponse>) - Method in class org.elasticsearch.action.admin.indices.template.get.TransportGetIndexTemplatesAction
- masterOperation(SimulateIndexTemplateRequest, ClusterState, ActionListener<SimulateIndexTemplateResponse>) - Method in class org.elasticsearch.action.admin.indices.template.post.TransportSimulateIndexTemplateAction
- masterOperation(SimulateTemplateAction.Request, ClusterState, ActionListener<SimulateIndexTemplateResponse>) - Method in class org.elasticsearch.action.admin.indices.template.post.TransportSimulateTemplateAction
- masterOperation(PutComponentTemplateAction.Request, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutComponentTemplateAction
- masterOperation(PutComposableIndexTemplateAction.Request, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutComposableIndexTemplateAction
- masterOperation(PutIndexTemplateRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
- masterOperation(UpgradeSettingsRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeSettingsAction
- masterOperation(ModifyDataStreamsAction.Request, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.datastreams.ModifyDataStreamsTransportAction
- masterOperation(DeletePipelineRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.ingest.DeletePipelineTransportAction
- masterOperation(GetPipelineRequest, ClusterState, ActionListener<GetPipelineResponse>) - Method in class org.elasticsearch.action.ingest.GetPipelineTransportAction
- masterOperation(PutPipelineRequest, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.action.ingest.PutPipelineTransportAction
- masterOperation(CompletionPersistentTaskAction.Request, ClusterState, ActionListener<PersistentTaskResponse>) - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction.TransportAction
- masterOperation(RemovePersistentTaskAction.Request, ClusterState, ActionListener<PersistentTaskResponse>) - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.TransportAction
- masterOperation(StartPersistentTaskAction.Request, ClusterState, ActionListener<PersistentTaskResponse>) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.TransportAction
- masterOperation(UpdatePersistentTaskStatusAction.Request, ClusterState, ActionListener<PersistentTaskResponse>) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.TransportAction
- masterOperation(Task, ClusterHealthRequest, ClusterState, ActionListener<ClusterHealthResponse>) - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
- masterOperation(Task, GetSnapshotsRequest, ClusterState, ActionListener<GetSnapshotsResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.TransportGetSnapshotsAction
- masterOperation(Task, SnapshotsStatusRequest, ClusterState, ActionListener<SnapshotsStatusResponse>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportSnapshotsStatusAction
- masterOperation(Task, ClusterStateRequest, ClusterState, ActionListener<ClusterStateResponse>) - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
- masterOperation(Task, CloseIndexRequest, ClusterState, ActionListener<CloseIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
- masterOperation(Task, AddIndexBlockRequest, ClusterState, ActionListener<AddIndexBlockResponse>) - Method in class org.elasticsearch.action.admin.indices.readonly.TransportAddIndexBlockAction
- masterOperation(Task, RolloverRequest, ClusterState, ActionListener<RolloverResponse>) - Method in class org.elasticsearch.action.admin.indices.rollover.TransportRolloverAction
- masterOperation(Task, Request, ClusterState, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.info.TransportClusterInfoAction
- masterOperation(Task, Request, ClusterState, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
-
Override this operation if access to the task parameter is needed
- masterOperation(Request, ClusterState, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.info.TransportClusterInfoAction
- masterOperation(Request, ClusterState, ActionListener<Response>) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- MasterPingRequest(DiscoveryNode, DiscoveryNode, ClusterName) - Constructor for class org.elasticsearch.discovery.zen.MasterFaultDetection.MasterPingRequest
- MasterPingRequest(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.MasterFaultDetection.MasterPingRequest
- MasterPingResponseResponse() - Constructor for class org.elasticsearch.discovery.zen.MasterFaultDetection.MasterPingResponseResponse
- MasterPingResponseResponse(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.MasterFaultDetection.MasterPingResponseResponse
- MasterService - Class in org.elasticsearch.cluster.service
- MasterService(Settings, ClusterSettings, ThreadPool) - Constructor for class org.elasticsearch.cluster.service.MasterService
- mastersFirstStream() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Returns a stream of all nodes, with master nodes at the front
- masterSupportsFetchingLatestSnapshots() - Method in class org.elasticsearch.indices.recovery.plan.ShardSnapshotsService
- masterTimeout(TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutRequest
- masterTimeout(TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.RemoveRequest
- match() - Method in class org.elasticsearch.index.mapper.DynamicTemplate
- match(String) - Method in class org.elasticsearch.common.settings.Setting.AffixKey
- match(String) - Method in class org.elasticsearch.common.settings.Setting.GroupKey
- match(String) - Method in interface org.elasticsearch.common.settings.Setting.Key
- match(String) - Method in class org.elasticsearch.common.settings.Setting.ListKey
- match(String) - Method in class org.elasticsearch.common.settings.Setting
-
Returns
true
iff the given key matches the settings key or if this setting is a group setting if the given key is part of the settings group. - match(String) - Method in class org.elasticsearch.common.settings.Setting.SimpleKey
- match(String) - Method in enum class org.elasticsearch.index.IndexModule.Type
-
Returns true iff this settings matches the type.
- match(String, String, String, DynamicTemplate.XContentFieldType) - Method in class org.elasticsearch.index.mapper.DynamicTemplate
- match(URI) - Method in class org.elasticsearch.common.util.URIPattern
-
Returns true if the given uri matches the pattern
- match(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
- match(URIPattern[], URI) - Static method in class org.elasticsearch.common.util.URIPattern
- match(Task) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
- match(Task) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
- match(Task) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- Match(String, int, boolean, String, IntervalsSourceProvider.IntervalFilter, String) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.Match
- Match(StreamInput) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.Match
- MATCH - Enum constant in enum class org.elasticsearch.search.profile.query.QueryTimingType
- MATCH_ANY - Static variable in class org.elasticsearch.common.lucene.uid.Versions
-
used to indicate the write operation should succeed regardless of current version
- MATCH_COST - Static variable in class org.elasticsearch.search.runtime.AbstractScriptFieldQuery
-
We don't have the infrastructure to estimate the match cost of a script so we just use a big number.
- MATCH_DELETED - Static variable in class org.elasticsearch.common.lucene.uid.Versions
-
used to indicate that the write operation should be executed if the document is currently deleted i.e., not found in the index and/or found as deleted (with version) in the version map
- matchAllQuery() - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that matches on all documents.
- MatchAllQueryBuilder - Class in org.elasticsearch.index.query
-
A query that matches on all documents.
- MatchAllQueryBuilder() - Constructor for class org.elasticsearch.index.query.MatchAllQueryBuilder
- MatchAllQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MatchAllQueryBuilder
-
Read from a stream.
- matchBoolPrefixQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a text query with type "BOOL_PREFIX" for the provided field name and text.
- MatchBoolPrefixQueryBuilder - Class in org.elasticsearch.index.query
-
The boolean prefix query analyzes the input text and creates a boolean query containing a Term query for each term, except for the last term, which is used to create a prefix query
- MatchBoolPrefixQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
- MatchBoolPrefixQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
- matched - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition.Result
- MATCHED_FIELDS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- matchedFields() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- matchedFields(String...) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
-
Set the matched fields to highlight against this field data.
- matchedQueries(String[]) - Method in class org.elasticsearch.search.SearchHit
- MatchedQueriesPhase - Class in org.elasticsearch.search.fetch.subphase
- MatchedQueriesPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.MatchedQueriesPhase
- Matcher<T> - Interface in org.elasticsearch.common.inject.matcher
-
Returns
true
orfalse
for a given input. - MatcherAndConverter - Class in org.elasticsearch.common.inject.internal
- MatcherAndConverter(Matcher<? super TypeLiteral<?>>, TypeConverter, Object) - Constructor for class org.elasticsearch.common.inject.internal.MatcherAndConverter
- Matchers - Class in org.elasticsearch.common.inject.matcher
-
Matcher implementations.
- matches(double) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- matches(double[], int) - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldExistsQuery
- matches(double[], int) - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldRangeQuery
- matches(double[], int) - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldTermQuery
- matches(double[], int) - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldTermsQuery
- matches(int, int) - Method in class org.elasticsearch.search.runtime.BooleanScriptFieldExistsQuery
- matches(int, int) - Method in class org.elasticsearch.search.runtime.BooleanScriptFieldTermQuery
- matches(long[], int) - Method in class org.elasticsearch.search.runtime.GeoPointScriptFieldExistsQuery
- matches(long[], int) - Method in class org.elasticsearch.search.runtime.GeoPointScriptFieldGeoShapeQuery
- matches(long[], int) - Method in class org.elasticsearch.search.runtime.LongScriptFieldExistsQuery
- matches(long[], int) - Method in class org.elasticsearch.search.runtime.LongScriptFieldRangeQuery
- matches(long[], int) - Method in class org.elasticsearch.search.runtime.LongScriptFieldTermQuery
- matches(long[], int) - Method in class org.elasticsearch.search.runtime.LongScriptFieldTermsQuery
- matches(String) - Method in enum class org.elasticsearch.common.time.FormatNames
- matches(String, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.ConstantFieldType
-
Return whether the constant value of this field matches the provided
pattern
as documented inRegex.simpleMatch(java.lang.String, java.lang.String)
. - matches(String, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypeFieldType
- matches(String, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TypeFieldType
- matches(String, String) - Method in enum class org.elasticsearch.index.mapper.DynamicTemplate.MatchType
-
Whether
value
matchesregex
. - matches(List<String>) - Method in class org.elasticsearch.search.runtime.AbstractStringScriptFieldAutomatonQuery
- matches(List<String>) - Method in class org.elasticsearch.search.runtime.StringScriptFieldExistsQuery
- matches(List<String>) - Method in class org.elasticsearch.search.runtime.StringScriptFieldPrefixQuery
- matches(List<String>) - Method in class org.elasticsearch.search.runtime.StringScriptFieldRangeQuery
- matches(List<String>) - Method in class org.elasticsearch.search.runtime.StringScriptFieldTermQuery
- matches(List<String>) - Method in class org.elasticsearch.search.runtime.StringScriptFieldTermsQuery
- matches(BytesRef[], int) - Method in class org.elasticsearch.search.runtime.IpScriptFieldExistsQuery
- matches(BytesRef[], int) - Method in class org.elasticsearch.search.runtime.IpScriptFieldRangeQuery
- matches(BytesRef[], int) - Method in class org.elasticsearch.search.runtime.IpScriptFieldTermQuery
- matches(BytesRef[], int) - Method in class org.elasticsearch.search.runtime.IpScriptFieldTermsQuery
- matches(AbstractLongFieldScript, int) - Method in class org.elasticsearch.search.runtime.LongScriptFieldTermsQuery
- matches(AbstractLongFieldScript, int) - Method in class org.elasticsearch.search.runtime.GeoPointScriptFieldDistanceFeatureQuery
- matches(AbstractLongFieldScript, int) - Method in class org.elasticsearch.search.runtime.LongScriptFieldDistanceFeatureQuery
- matches(BooleanFieldScript, int) - Method in class org.elasticsearch.search.runtime.BooleanScriptFieldTermQuery
- matches(DoubleFieldScript, int) - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldTermsQuery
- matches(GeoPointFieldScript, int) - Method in class org.elasticsearch.search.runtime.GeoPointScriptFieldGeoShapeQuery
- matches(IpFieldScript, int) - Method in class org.elasticsearch.search.runtime.IpScriptFieldTermsQuery
- matches(StringFieldScript, int) - Method in class org.elasticsearch.search.runtime.StringScriptFieldWildcardQuery
- matches(S, int) - Method in class org.elasticsearch.search.runtime.AbstractScriptFieldQuery
- matches(T) - Method in interface org.elasticsearch.common.inject.matcher.Matcher
-
Returns
true
if this matchest
,false
otherwise. - matchesIndexPattern(String) - Method in class org.elasticsearch.indices.SystemIndexDescriptor
-
Checks whether an index name matches the system index name pattern for this descriptor.
- MatchNoneQueryBuilder - Class in org.elasticsearch.index.query
-
A query that matches no document.
- MatchNoneQueryBuilder() - Constructor for class org.elasticsearch.index.query.MatchNoneQueryBuilder
- MatchNoneQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MatchNoneQueryBuilder
-
Read from a stream.
- matchPhrasePrefixQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a match query with type "PHRASE_PREFIX" for the provided field name and text.
- MatchPhrasePrefixQueryBuilder - Class in org.elasticsearch.index.query
-
Match query is a query that analyzes the text and constructs a phrase prefix query as the result of the analysis.
- MatchPhrasePrefixQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- MatchPhrasePrefixQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Read from a stream.
- matchPhraseQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a text query with type "PHRASE" for the provided field name and text.
- MatchPhraseQueryBuilder - Class in org.elasticsearch.index.query
-
Match query is a query that analyzes the text and constructs a phrase query as the result of the analysis.
- MatchPhraseQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- MatchPhraseQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Read from a stream.
- matchQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a match query with type "BOOLEAN" for the provided field name and text.
- MatchQueryBuilder - Class in org.elasticsearch.index.query
-
Match query is a query that analyzes the text and constructs a query as the result of the analysis.
- MatchQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.MatchQueryBuilder
-
Constructs a new match query.
- MatchQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MatchQueryBuilder
-
Read from a stream.
- MatchQueryParser - Class in org.elasticsearch.index.search
- MatchQueryParser(SearchExecutionContext) - Constructor for class org.elasticsearch.index.search.MatchQueryParser
- MatchQueryParser.Type - Enum Class in org.elasticsearch.index.search
- matchQueryType() - Method in enum class org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
- max - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket.BucketBounds
- max - Variable in class org.elasticsearch.search.aggregations.metrics.InternalStats
- max - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- max() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- max(double[]) - Static method in class org.elasticsearch.search.aggregations.pipeline.MovingFunctions
-
Find the maximum value in a window of values.
- max(long, long) - Static method in class org.elasticsearch.index.seqno.SequenceNumbers
-
Compute the maximum of the given current maximum sequence number and the specified sequence number, accounting for the fact that the current maximum sequence number could be
SequenceNumbers.NO_OPS_PERFORMED
orSequenceNumbers.UNASSIGNED_SEQ_NO
. - max(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Max
aggregation with the given name. - max(Version, Version) - Static method in class org.elasticsearch.Version
-
Returns the maximum version between the 2
- Max - Enum constant in enum class org.elasticsearch.search.rescore.QueryRescoreMode
- Max - Interface in org.elasticsearch.search.aggregations.metrics
-
An aggregation that computes the maximum of the values in the current bucket.
- MAX - Enum constant in enum class org.elasticsearch.common.lucene.search.function.CombineFunction
- MAX - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- MAX - Enum constant in enum class org.elasticsearch.search.MultiValueMode
-
Pick the highest value.
- MAX - Enum constant in enum class org.elasticsearch.search.sort.SortMode
-
pick the highest value
- MAX - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- MAX_ACCURATE_BOUND - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
-
The maximum
long
that can accurately fit into thedouble
precision floating point bounds. - MAX_ADJACENCY_MATRIX_FILTERS_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum number of filters clauses that can be used in an adjacency_matrix aggregation.
- MAX_ANALYZED_OFFSET_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- MAX_ANALYZED_OFFSET_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
A setting describing the maximum number of characters that will be analyzed for a highlight request.
- MAX_AS_STRING - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- MAX_ASYNC_SEARCH_RESPONSE_SIZE_SETTING - Static variable in class org.elasticsearch.search.SearchService
- MAX_BOOST_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- MAX_BUCKET_SETTING - Static variable in class org.elasticsearch.search.aggregations.MultiBucketConsumerService
- MAX_BUCKET_SIZE - Static variable in class org.elasticsearch.search.sort.BucketedSort.ForFloats
-
The maximum size of buckets this can store.
- MAX_BYTES_VLONG - Static variable in enum class org.elasticsearch.common.util.ByteUtils
- MAX_CHARS - Static variable in class org.elasticsearch.script.StringFieldScript
-
The maximum number of chars a script should be allowed to emit.
- MAX_CHILDREN_FIELD - Static variable in class org.elasticsearch.search.sort.NestedSortBuilder
- MAX_CONCURRENT_GROUP_REQUESTS_FIELD - Static variable in class org.elasticsearch.search.collapse.CollapseBuilder
- MAX_CONCURRENT_SEARCH_REQUESTS_DEFAULT - Static variable in class org.elasticsearch.action.search.MultiSearchRequest
- MAX_CONCURRENT_SNAPSHOT_OPERATIONS_SETTING - Static variable in class org.elasticsearch.snapshots.SnapshotsService
-
Setting that specifies the maximum number of allowed concurrent snapshot create and delete operations in the cluster state.
- MAX_DOCS_ALL_MATCHES - Static variable in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- MAX_DOCS_PER_VALUE_DEFAULT - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- MAX_DOCS_PER_VALUE_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- MAX_DOCVALUE_FIELDS_SEARCH_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum value of allowed `docvalue_fields`that can be retrieved per search request.
- MAX_EDITS_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- MAX_EXPANSIONS_FIELD - Static variable in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- MAX_EXPANSIONS_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- MAX_FIELD - Static variable in class org.elasticsearch.search.slice.SliceBuilder
- MAX_HIT_COUNT - Static variable in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
- MAX_INDEX_BUFFER_SIZE_SETTING - Static variable in class org.elasticsearch.indices.IndexingMemoryController
-
Only applies when
indices.memory.index_buffer_size
is a %, to set a ceiling on the actual size in bytes (default: not set). - MAX_INDEX_NAME_BYTES - Static variable in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
- MAX_INDEXING_BYTES - Static variable in class org.elasticsearch.index.IndexingPressure
- MAX_INNER_RESULT_WINDOW_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum value of from + size on an individual inner hit definition or top hits aggregation.
- MAX_INSPECTIONS_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- MAX_KEEPALIVE_SETTING - Static variable in class org.elasticsearch.search.SearchService
- MAX_LAT - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Maximum valid latitude in degrees.
- MAX_LOCAL_STORAGE_NODES_SETTING - Static variable in class org.elasticsearch.env.NodeEnvironment
-
Maximum number of data nodes that should run in an environment.
- MAX_LON - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Maximum valid longitude in degrees.
- MAX_MERGE_COUNT_SETTING - Static variable in class org.elasticsearch.index.MergeSchedulerConfig
- MAX_MILLIS_BEFORE_9999 - Static variable in class org.elasticsearch.common.time.DateUtils
- MAX_MILLIS_BEFORE_MINUS_9999 - Static variable in class org.elasticsearch.common.time.DateUtils
- MAX_NANOSECOND - Static variable in class org.elasticsearch.common.time.DateUtils
- MAX_NANOSECOND_INSTANT - Static variable in class org.elasticsearch.common.time.DateUtils
-
The maximum nanosecond resolution date we can properly handle.
- MAX_NGRAM_DIFF_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing for NGramTokenizer and NGramTokenFilter the maximum difference between max_gram (maximum length of characters in a gram) and min_gram (minimum length of characters in a gram).
- MAX_NUM_SEGMENTS - Static variable in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest.Defaults
- MAX_OPEN_SCROLL_CONTEXT - Static variable in class org.elasticsearch.search.SearchService
- MAX_PASSPHRASE_LENGTH - Static variable in class org.elasticsearch.cli.KeyStoreAwareCommand
-
Arbitrarily chosen maximum passphrase length
- MAX_PENDING_CLUSTER_STATES_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- MAX_PINGS_FROM_ANOTHER_MASTER_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- MAX_PRECISION - Static variable in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- MAX_REFRESH_LISTENERS_PER_SHARD - Static variable in class org.elasticsearch.index.IndexSettings
-
The maximum number of refresh listeners allows on this shard.
- MAX_REGEX_LENGTH_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
The maximum length of regex string allowed in a regexp query.
- MAX_RESCORE_WINDOW_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum size of the rescore window.
- MAX_RESTORE_BYTES_PER_SEC - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- MAX_RESULT_WINDOW_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum value of from + size on a query.
- MAX_REWRITE_ROUNDS - Static variable in interface org.elasticsearch.index.query.Rewriteable
- MAX_SCORE - Static variable in class org.elasticsearch.search.SearchHits.Fields
- MAX_SCRIPT_FIELDS_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum value of allowed `script_fields`that can be retrieved per search request.
- MAX_SEQ_NO - Static variable in class org.elasticsearch.index.seqno.SequenceNumbers
- MAX_SHINGLE_DIFF_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing for ShingleTokenFilter the maximum difference between max_shingle_size and min_shingle_size.
- MAX_SLICES_PER_SCROLL - Static variable in class org.elasticsearch.index.IndexSettings
-
The maximum number of slices allowed in a scroll request
- MAX_SNAPSHOT_BYTES_PER_SEC - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- MAX_SNAPSHOTS_SETTING - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Setting that defines the maximum number of snapshots to which the repository may grow.
- MAX_TERM_FREQ_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- MAX_TERMS_COUNT_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
Index setting describing the maximum number of terms that can be used in Terms Query.
- MAX_THREAD_COUNT_SETTING - Static variable in class org.elasticsearch.index.MergeSchedulerConfig
- MAX_TOKEN_COUNT_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
-
A setting describing the maximum number of tokens that can be produced using _analyze API.
- MAX_UNSAFE_AUTO_ID_TIMESTAMP_COMMIT_ID - Static variable in class org.elasticsearch.index.engine.Engine
- MAX_VALUES - Static variable in class org.elasticsearch.script.AbstractFieldScript
-
The maximum number of values a script should be allowed to emit.
- MAX_ZOOM - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
-
Largest number of tiles (precision) to use.
- maxAge() - Method in class org.elasticsearch.http.CorsHandler.Config
- MaxAgeCondition - Class in org.elasticsearch.action.admin.indices.rollover
-
Condition for index maximum age.
- MaxAgeCondition(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- MaxAgeCondition(TimeValue) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- MaxAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- MaxAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
- MaxAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
-
Read from a stream.
- MaxAggregationBuilder(MaxAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
- maxAnalyzedOffset - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- maxAnalyzedOffset() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- maxAnalyzedOffset() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- maxAnalyzedOffset(Integer) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set to a non-negative value which represents the max offset used to analyze the field thus avoiding exceptions if the field exceeds this limit.
- maxBoost() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Returns the maximum boost that will be applied by function score.
- maxBoost(float) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Sets the maximum boost that will be applied by function score.
- maxBound() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Get the current maximum bound that is set on this builder.
- maxBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- maxBucketOrd() - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Return an upper bound of the maximum bucket ordinal seen so far.
- MaxBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- MaxBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.MaxBucketPipelineAggregationBuilder
- MaxBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.MaxBucketPipelineAggregationBuilder
-
Read from a stream.
- MaxBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- MaxBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.MaxBucketPipelineAggregator
-
Read from a stream.
- maxConcurrentSearchRequests() - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
Returns the amount of search requests specified in this multi search requests are allowed to be ran concurrently.
- maxConcurrentSearchRequests(int) - Method in class org.elasticsearch.action.search.MultiSearchRequest
-
Sets how many search requests specified in this multi search requests are allowed to be ran concurrently.
- maxContentLength - Variable in class org.elasticsearch.http.AbstractHttpServerTransport
- maxContentLength() - Method in class org.elasticsearch.http.HttpInfo
- maxDeterminizedStates() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- maxDeterminizedStates() - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- maxDeterminizedStates(int) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Protects against too-difficult regular expression queries.
- maxDeterminizedStates(int) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
-
Sets the regexp maxDeterminizedStates.
- maxDoc() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Returns the maximum document ID this builder can associate with an ordinal
- maxDoc() - Method in class org.elasticsearch.search.dfs.AggregatedDfs
- maxDoc() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- maxDoc(int) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- maxDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.AbstractRareTermsAggregator
- maxDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
- maxDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
-
Set the maximum document count terms should have in order to appear in the response.
- maxDocFreq - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- maxDocFreq() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- maxDocFreq(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Set the maximum frequency in which words may still appear.
- maxDocs(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Maximum number of processed documents.
- MaxDocsCondition - Class in org.elasticsearch.action.admin.indices.rollover
-
Condition for maximum index docs.
- MaxDocsCondition(Long) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- MaxDocsCondition(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- maxDocsPerValue() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
-
Get the max num docs to be returned per value.
- maxDocsPerValue(int) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
-
Set the max num docs to be returned per value.
- maxEdits() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- maxEdits() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the maximum edit distance setting.
- maxEdits(int) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- maxEdits(int) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets the maximum edit distance candidate suggestions can have in order to be considered as a suggestion.
- maxEdits(Integer) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets the maximum edit distance candidate suggestions can have in order to be considered as a suggestion.
- maxErrors() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the maxErrors setting
- maxErrors(float) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets the maximum percentage of the terms that at most considered to be misspellings in order to form a correction.
- MAXERRORS_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- maxExpansions - Variable in class org.elasticsearch.index.search.MatchQueryParser
- maxExpansions() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- maxExpansions() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Get the (optional) number of term expansions when using fuzzy or prefix type query.
- maxExpansions() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Get the (optional) number of term expansions when using fuzzy or prefix type query.
- maxExpansions() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Get the (optional) number of term expansions when using fuzzy or prefix type query.
- maxExpansions() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- maxExpansions(int) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- maxExpansions(int) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
When using fuzzy or prefix type query, the number of term expansions to use.
- maxExpansions(int) - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
The number of term expansions to use.
- maxExpansions(int) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
When using fuzzy or prefix type query, the number of term expansions to use.
- maxExpansions(int) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
When using fuzzy or prefix type query, the number of term expansions to use.
- MAXIMUM_METADATA_BYTES - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- MAXIMUM_VOTING_CONFIG_EXCLUSIONS_SETTING - Static variable in class org.elasticsearch.action.admin.cluster.configuration.TransportAddVotingConfigExclusionsAction
- maxInspections() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- maxInspections() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the factor for inspecting more candidate suggestions setting.
- maxInspections(int) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- maxInspections(int) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
A factor that is used to multiply with the size in order to inspect more candidate suggestions.
- maxInspections(Integer) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
A factor that is used to multiply with the size in order to inspect more candidate suggestions.
- maxNumSegments() - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Will merge the index down to <= maxNumSegments.
- maxNumSegments(int) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Will merge the index down to <= maxNumSegments.
- maxNumTerms - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- maxOrd() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
-
Get the number of data structures
- maxOrd() - Method in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- maxOwningBucketOrd() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromMany
- maxOwningBucketOrd() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromManySmall
- maxOwningBucketOrd() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromSingle
- maxOwningBucketOrd() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds
-
The maximum possible used
owningBucketOrd
. - maxPrimaryShardSize - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition.Stats
- MaxPrimaryShardSizeCondition - Class in org.elasticsearch.action.admin.indices.rollover
-
A size-based condition for the primary shards within an index.
- MaxPrimaryShardSizeCondition(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxPrimaryShardSizeCondition
- MaxPrimaryShardSizeCondition(ByteSizeValue) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxPrimaryShardSizeCondition
- maxQueryTerms() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- maxQueryTerms(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the maximum number of query terms that will be included in any generated query.
- maxRadialDistanceMeters(double, double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Returns the maximum distance/radius (in meters) from the point 'center' before overlapping
- MaxRetryAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
An allocation decider that prevents shards from being allocated on any node if the shards allocation has been retried N times without success.
- MaxRetryAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.MaxRetryAllocationDecider
- maxScore - Variable in class org.elasticsearch.common.lucene.search.TopDocsAndMaxScore
- maxScore - Variable in class org.elasticsearch.search.internal.ScrollContext
- MaxScoreCollector - Class in org.elasticsearch.action.search
-
A collector that computes the maximum score.
- MaxScoreCollector() - Constructor for class org.elasticsearch.action.search.MaxScoreCollector
- maxSeenAutoIdTimestampOnPrimary() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- maxSeqNo - Variable in class org.elasticsearch.index.seqno.SequenceNumbers.CommitInfo
- maxSeqNoOfUpdatesOrDeletes() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Returns the maximum seq_no of updates (index operations overwrite Lucene) or deletes on the primary.
- maxSeqNoOfUpdatesOrDeletesOnPrimary() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- MaxSizeCondition - Class in org.elasticsearch.action.admin.indices.rollover
-
A size-based condition for an index size.
- MaxSizeCondition(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- MaxSizeCondition(ByteSizeValue) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- maxTermFreq - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- maxTermFreq() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- maxTermFreq() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the maximum term frequency threshold setting.
- maxTermFreq(float) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- maxTermFreq(float) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets a maximum threshold in number of documents a suggest text token can exist in order to be corrected.
- maxTermFreq(float) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets a maximum threshold in number of documents a suggest text token can exist in order to be corrected.
- maxValue() - Method in enum class org.elasticsearch.index.mapper.RangeType
- maxWordLength - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- maxWordLength() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- maxWordLength(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the maximum word length above which words will be ignored.
- maybeApplyMinimumShouldMatch(Query, String) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
Potentially apply minimum should match value if we have a query that it can be applied to, otherwise return the original query.
- maybeCheckIndex() - Method in class org.elasticsearch.index.shard.IndexShard
- maybeDieOnAnotherThread(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
-
If the specified cause is an unrecoverable error, this method will rethrow the cause on a separate thread so that it can not be caught and bubbles up to the uncaught exception handler.
- maybeError(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
-
Unwrap the specified throwable looking for any suppressed errors or errors as a root cause of the specified throwable.
- maybeFailEngine(String, Exception) - Method in class org.elasticsearch.index.engine.Engine
-
Check whether the engine should be failed
- maybeFailEngine(String, Exception) - Method in class org.elasticsearch.index.engine.InternalEngine
- maybeGetMasterApplyElapsedMillis() - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- maybeGetPublicationCommitElapsedMillis() - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- maybeGetPublicationCompletionElapsedMillis() - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- maybeGetPublicationContextConstructionElapsedMillis() - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- maybeOverrideConnectionProfile(ConnectionProfile) - Method in class org.elasticsearch.transport.TcpTransport
- maybePause(int) - Method in class org.elasticsearch.common.util.CombinedRateLimiter
- maybePruneDeletes() - Method in class org.elasticsearch.index.engine.Engine
-
Tries to prune buffered deletes from the version map.
- maybePruneDeletes() - Method in class org.elasticsearch.index.engine.InternalEngine
- maybePruneDeletes() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- maybeRateLimitRestores(InputStream) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Wrap the restore rate limiter (controlled by the repository setting `max_restore_bytes_per_sec` and the cluster setting `indices.recovery.max_bytes_per_sec`) around the given stream.
- maybeRateLimitRestores(InputStream, RateLimitingInputStream.Listener) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Wrap the restore rate limiter (controlled by the repository setting `max_restore_bytes_per_sec` and the cluster setting `indices.recovery.max_bytes_per_sec`) around the given stream.
- maybeRateLimitSnapshots(InputStream) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Wrap the snapshot rate limiter (controlled by the repository setting `max_snapshot_bytes_per_sec`) around the given stream.
- maybeRateLimitSnapshots(InputStream, RateLimitingInputStream.Listener) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Wrap the snapshot rate limiter (controlled by the repository setting `max_snapshot_bytes_per_sec`) around the given stream.
- maybeRefresh(String) - Method in class org.elasticsearch.index.engine.Engine
-
Synchronously refreshes the engine for new search operations to reflect the latest changes unless another thread is already refreshing the engine concurrently.
- maybeRefresh(String) - Method in class org.elasticsearch.index.engine.InternalEngine
- maybeRefresh(String) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- maybeSyncGlobalCheckpoint(String) - Method in class org.elasticsearch.index.shard.IndexShard
-
Syncs the global checkpoint to the replicas if the global checkpoint on at least one replica is behind the global checkpoint on the primary.
- maybeThrowRuntimeAndSuppress(List<T>) - Static method in class org.elasticsearch.ExceptionsHelper
-
Throws a runtime exception with all given exceptions added as suppressed.
- MB - Enum constant in enum class org.elasticsearch.common.unit.ByteSizeUnit
- md5() - Static method in class org.elasticsearch.common.hash.MessageDigests
-
Returns a
MessageDigest
instance for MD5 digests; note that the instance returned is thread local and must not be shared amongst threads. - mean() - Method in class org.elasticsearch.common.metrics.MeanMetric
- MeanMetric - Class in org.elasticsearch.common.metrics
- MeanMetric() - Constructor for class org.elasticsearch.common.metrics.MeanMetric
- MEDIAN - Enum constant in enum class org.elasticsearch.search.MultiValueMode
-
Pick the median of the values.
- MEDIAN - Enum constant in enum class org.elasticsearch.search.sort.SortMode
-
Use the median of all values as sort value.
- medianAbsoluteDeviation(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
MedianAbsoluteDeviation
aggregation with the given name - MedianAbsoluteDeviation - Interface in org.elasticsearch.search.aggregations.metrics
-
An aggregation that approximates the median absolute deviation of a numeric field
- MedianAbsoluteDeviationAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- MedianAbsoluteDeviationAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- MedianAbsoluteDeviationAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- MedianAbsoluteDeviationAggregationBuilder(MedianAbsoluteDeviationAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- MedianAbsoluteDeviationAggregator - Class in org.elasticsearch.search.aggregations.metrics
- MedianAbsoluteDeviationAggregatorFactory - Class in org.elasticsearch.search.aggregations.metrics
- MedianAbsoluteDeviationAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.metrics
- MEDIUM - Enum constant in enum class org.elasticsearch.watcher.ResourceWatcherService.Frequency
-
Defaults to 30 seconds
- mega() - Method in class org.elasticsearch.common.unit.SizeValue
- MEGA - Enum constant in enum class org.elasticsearch.common.unit.SizeUnit
- megaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- Mem(long) - Constructor for class org.elasticsearch.monitor.process.ProcessStats.Mem
- Mem(long, long) - Constructor for class org.elasticsearch.monitor.os.OsStats.Mem
- Mem(long, long, long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- Mem(long, long, long, long, long, List<JvmStats.MemoryPool>) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.Mem
- Mem(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- Mem(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.Mem
- Mem(StreamInput) - Constructor for class org.elasticsearch.monitor.os.OsStats.Mem
- Mem(StreamInput) - Constructor for class org.elasticsearch.monitor.process.ProcessStats.Mem
- MEM - Enum constant in enum class org.elasticsearch.monitor.jvm.HotThreads.ReportType
- memberKey(Member) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
- members() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
- MembershipAction - Class in org.elasticsearch.discovery.zen
- MembershipAction(TransportService, MembershipAction.MembershipListener, Collection<BiConsumer<DiscoveryNode, ClusterState>>) - Constructor for class org.elasticsearch.discovery.zen.MembershipAction
- MembershipAction.JoinCallback - Interface in org.elasticsearch.discovery.zen
- MembershipAction.JoinRequest - Class in org.elasticsearch.discovery.zen
- MembershipAction.LeaveRequest - Class in org.elasticsearch.discovery.zen
- MembershipAction.MembershipListener - Interface in org.elasticsearch.discovery.zen
- MembersInjector<T> - Interface in org.elasticsearch.common.inject
-
Injects dependencies into the fields and methods on instances of type
T
. - MembersInjectorLookup<T> - Class in org.elasticsearch.common.inject.spi
-
A lookup of the members injector for a type.
- MembersInjectorLookup(Object, TypeLiteral<T>) - Constructor for class org.elasticsearch.common.inject.spi.MembersInjectorLookup
- memberType(Member) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
Returns
Field.class
,Method.class
orConstructor.class
. - MEMORY - Enum constant in enum class org.elasticsearch.common.breaker.CircuitBreaker.Type
- MEMORY - Enum constant in enum class org.elasticsearch.index.query.GeoExecType
- MEMORY_LOCK_SETTING - Static variable in class org.elasticsearch.bootstrap.BootstrapSettings
- memoryInBytes - Variable in class org.elasticsearch.index.engine.Segment
- MemoryPool(String, long, long, long, long) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- MemoryPool(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- memorySizeSetting(String, String, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
-
Creates a setting which specifies a memory size.
- memorySizeSetting(String, Function<Settings, String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
-
Creates a setting which specifies a memory size.
- memorySizeSetting(String, ByteSizeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
-
Creates a setting which specifies a memory size.
- MemorySizeValue - Enum Class in org.elasticsearch.common.unit
-
Utility methods to get memory sizes.
- memoryUsage(int) - Static method in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
-
Return the expected per-bucket memory usage for the given precision.
- MERCATOR_BOUNDS - Static variable in class org.elasticsearch.common.geo.SphericalMercatorUtils
- MergableCustomMetadata<T extends Metadata.Custom> - Interface in org.elasticsearch.cluster
-
Interface to allow merging
Metadata.Custom
. - merge - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- merge() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- merge(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- merge(boolean, SearchPhaseController.ReducedQueryPhase, Collection<? extends SearchPhaseResult>, IntFunction<SearchPhaseResult>) - Method in class org.elasticsearch.action.search.SearchPhaseController
-
Enriches search hits and completion suggestion hits from
sortedDocs
usingfetchResultsArr
, merges suggestions, aggregations and profile results Expects sortedDocs to have top search docs across all shards, optionally followed by top suggest docs for each named completion suggestion ordered by suggestion name - merge(long, AbstractHyperLogLogPlusPlus, long) - Method in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- merge(String, Map<String, Object>, MapperService.MergeReason) - Method in class org.elasticsearch.index.mapper.MapperService
- merge(String, CompressedXContent, MapperService.MergeReason) - Method in class org.elasticsearch.index.mapper.MapperService
- merge(Collection<Message>) - Method in class org.elasticsearch.common.inject.internal.Errors
- merge(Map<String, Map<String, Object>>, MapperService.MergeReason) - Method in class org.elasticsearch.index.mapper.MapperService
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.elasticsearch.common.util.LazyMap
- merge(PointRangeQuery, PointRangeQuery) - Static method in class org.elasticsearch.search.aggregations.bucket.filter.MergedPointRangeQuery
-
Merge two PointRangeQuerys into a MergedPointRangeQuery that matches points that match both filters.
- merge(Sort, int, int, CollapseTopFieldDocs[], boolean) - Static method in class org.apache.lucene.search.grouping.CollapseTopFieldDocs
-
Returns a new CollapseTopDocs, containing topN collapsed results across the provided CollapseTopDocs, sorting by score.
- merge(DataStreamAlias) - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
-
Returns a new
DataStreamAlias
instance containing data streams referenced in this instance and the other instance. - merge(IndexMetadata, MapperService.MergeReason) - Method in class org.elasticsearch.index.mapper.MapperService
- merge(Errors) - Method in class org.elasticsearch.common.inject.internal.Errors
- merge(SetBackedScalingCuckooFilter) - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
-
Merge `other` cuckoo filter into this cuckoo.
- merge(AnalysisMode) - Method in enum class org.elasticsearch.index.analysis.AnalysisMode
-
Returns a mode that is compatible with both this mode and the other mode, that is: ALL.merge(INDEX_TIME) == INDEX_TIME ALL.merge(SEARCH_TIME) == SEARCH_TIME INDEX_TIME.merge(SEARCH_TIME) throws an
IllegalStateException
- merge(SegmentsStats.FileStats, SegmentsStats.FileStats) - Static method in class org.elasticsearch.index.engine.SegmentsStats.FileStats
- merge(FieldMapper.MultiFields) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields
- merge(Mapper) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
- merge(Mapper) - Method in class org.elasticsearch.index.mapper.FieldMapper
- merge(Mapper) - Method in class org.elasticsearch.index.mapper.Mapper
-
Return the merge of
mergeWith
into this. - merge(Mapper) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- merge(Mapper, MapperService.MergeReason) - Method in class org.elasticsearch.index.mapper.NestedObjectMapper
- merge(Mapper, MapperService.MergeReason) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- merge(Mapper, MapperService.MergeReason) - Method in class org.elasticsearch.index.mapper.RootObjectMapper
- merge(Mapping, MapperService.MergeReason) - Method in class org.elasticsearch.index.mapper.Mapping
-
Merges a new mapping into the existing one.
- merge(RepositoryStats) - Method in class org.elasticsearch.repositories.RepositoryStats
- merge(IncludeExclude, IncludeExclude) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- merge(Suggest.Suggestion.Entry<O>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
-
Merge any extra fields for this subtype.
- merge(Suggest.Suggestion.Entry<PhraseSuggestion.Entry.Option>) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- merge(T) - Method in interface org.elasticsearch.cluster.MergableCustomMetadata
-
Merges this custom metadata with other, returning either this or
other
custom metadata. - Merge - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- mergeDefaults(Map<String, Object>, Map<String, Object>) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Merges the defaults provided as the second parameter into the content of the first.
- MergedPointRangeQuery - Class in org.elasticsearch.search.aggregations.bucket.filter
-
Query merging two point in range queries.
- mergeFieldValues(List<Object>, char) - Static method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- mergeId - Variable in class org.elasticsearch.index.engine.Segment
- mergeInto(Suggest.Suggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- mergeInto(Suggest.Suggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- mergeInto(Suggest.Suggestion.Entry.Option) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- mergeMappings(DocumentMapper, Mapping, MapperService.MergeReason) - Static method in class org.elasticsearch.index.mapper.MapperService
- mergePhaseInitialBucketCount(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregator
- mergePipelineTreeForBWCSerialization(PipelineAggregator.PipelineTree) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Merge a PipelineAggregator.PipelineTree into this aggregation result tree before serializing to a node older than 7.8.0.
- mergePipelineTreeForBWCSerialization(PipelineAggregator.PipelineTree) - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
Merge a PipelineAggregator.PipelineTree into this aggregation result tree before serializing to a node older than 7.8.0.
- MergePolicyConfig - Class in org.elasticsearch.index
-
A shard in elasticsearch is a Lucene index, and a Lucene index is broken down into segments.
- MergeSchedulerConfig - Class in org.elasticsearch.index
-
The merge scheduler (
ConcurrentMergeScheduler
) controls the execution of merge operations once they are needed (according to the merge policy). - mergeStats() - Method in class org.elasticsearch.index.shard.IndexShard
- MergeStats - Class in org.elasticsearch.index.merge
- MergeStats() - Constructor for class org.elasticsearch.index.merge.MergeStats
- MergeStats(StreamInput) - Constructor for class org.elasticsearch.index.merge.MergeStats
- message(String, String) - Method in class org.elasticsearch.common.lucene.LoggerInfoStream
- Message - Class in org.elasticsearch.common.inject.spi
-
An error message and the context in which it occurred.
- Message(Object, String) - Constructor for class org.elasticsearch.common.inject.spi.Message
- Message(Object, Throwable) - Constructor for class org.elasticsearch.common.inject.spi.Message
- Message(String) - Constructor for class org.elasticsearch.common.inject.spi.Message
- Message(List<Object>, String, Throwable) - Constructor for class org.elasticsearch.common.inject.spi.Message
- MESSAGE_LENGTH_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- MessageDigests - Class in org.elasticsearch.common.hash
-
This MessageDigests class provides convenience methods for obtaining thread local
MessageDigest
instances for MD5, SHA-1, SHA-256 and SHA-512 message digests. - MessageDigests() - Constructor for class org.elasticsearch.common.hash.MessageDigests
- messageReceived(LivenessRequest, TransportChannel, Task) - Method in class org.elasticsearch.action.admin.cluster.node.liveness.TransportLivenessAction
- messageReceived(T, TransportChannel, Task) - Method in interface org.elasticsearch.transport.TransportRequestHandler
- meta() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
Return merged metadata across indices.
- meta() - Method in class org.elasticsearch.action.fieldcaps.IndexFieldCapabilities
- meta() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Get the metadata associated with this field.
- meta() - Method in class org.elasticsearch.index.mapper.RuntimeField.Builder
- META - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- META_ADDRESS - Static variable in class org.elasticsearch.common.transport.TransportAddress
-
A non-routeable v4 meta transport address that can be used for testing or in scenarios where targets should be marked as non-applicable from a transport perspective.
- META_FIELDS_BEFORE_7DOT8 - Static variable in class org.elasticsearch.index.mapper.MapperService
-
Deprecated.
- META_KEY - Static variable in class org.elasticsearch.ingest.Pipeline
- metadata - Variable in class org.elasticsearch.gateway.PersistedClusterStateService.OnDiskState
- metadata - Variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- metadata - Variable in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- metadata - Variable in class org.elasticsearch.search.aggregations.AggregatorFactory
- metadata - Variable in class org.elasticsearch.search.aggregations.InternalAggregation
- metadata - Variable in class org.elasticsearch.search.aggregations.ParsedAggregation
- metadata - Variable in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- metadata() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- metadata() - Method in class org.elasticsearch.bootstrap.BootstrapContext
- metadata() - Method in class org.elasticsearch.cluster.ClusterState
- metadata() - Method in class org.elasticsearch.cluster.metadata.ComponentTemplate
- metadata() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- metadata() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Get metadata of routing nodes
- metadata() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodeGatewayMetaState
- metadata() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns the StoreFileMetadata for this file info.
- metadata() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- metadata() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- metadata() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- metadata(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- metadata(Map<String, Object>) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.Builder
- metadata(Metadata) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- metadata(Metadata.Builder) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- Metadata - Class in org.elasticsearch.cluster.metadata
-
Metadata
is the part of theClusterState
which persists across restarts. - METADATA - Enum constant in enum class org.elasticsearch.cluster.ClusterState.Metric
- METADATA - Enum constant in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
- METADATA_DIRECTORY_NAME - Static variable in class org.elasticsearch.gateway.PersistedClusterStateService
- METADATA_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- METADATA_FIELD_INTRODUCED - Static variable in class org.elasticsearch.snapshots.SnapshotInfo
- METADATA_FORMAT - Variable in class org.elasticsearch.gateway.MetaStateService
- METADATA_NAME_FORMAT - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- METADATA_PREFIX - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- METADATA_READ - Enum constant in enum class org.elasticsearch.cluster.block.ClusterBlockLevel
- METADATA_VERIFICATION - Enum constant in enum class org.elasticsearch.index.IndexService.IndexCreationContext
- METADATA_WRITE - Enum constant in enum class org.elasticsearch.cluster.block.ClusterBlockLevel
- Metadata.Builder - Class in org.elasticsearch.cluster.metadata
- Metadata.Custom - Interface in org.elasticsearch.cluster.metadata
-
Custom metadata that persists (via XContent) across restarts.
- Metadata.NonRestorableCustom - Interface in org.elasticsearch.cluster.metadata
- Metadata.XContentContext - Enum Class in org.elasticsearch.cluster.metadata
- metadataChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff the metadata for the cluster has changed between the previous cluster state and the new cluster state. - MetadataCreateDataStreamService - Class in org.elasticsearch.cluster.metadata
- MetadataCreateDataStreamService(ThreadPool, ClusterService, MetadataCreateIndexService) - Constructor for class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService
- MetadataCreateDataStreamService.CreateDataStreamClusterStateUpdateRequest - Class in org.elasticsearch.cluster.metadata
- MetadataCreateIndexService - Class in org.elasticsearch.cluster.metadata
-
Service responsible for submitting create index requests
- MetadataCreateIndexService(Settings, ClusterService, IndicesService, AllocationService, AliasValidator, ShardLimitValidator, Environment, IndexScopedSettings, ThreadPool, NamedXContentRegistry, SystemIndices, boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
- MetadataDataStreamsService - Class in org.elasticsearch.cluster.metadata
-
Handles data stream modification requests.
- MetadataDataStreamsService(ClusterService, IndicesService) - Constructor for class org.elasticsearch.cluster.metadata.MetadataDataStreamsService
- MetadataDeleteIndexService - Class in org.elasticsearch.cluster.metadata
-
Deletes indices.
- MetadataDeleteIndexService(Settings, ClusterService, AllocationService) - Constructor for class org.elasticsearch.cluster.metadata.MetadataDeleteIndexService
- MetadataFieldMapper - Class in org.elasticsearch.index.mapper
-
A mapper for a builtin field containing metadata about a document.
- MetadataFieldMapper(MappedFieldType) - Constructor for class org.elasticsearch.index.mapper.MetadataFieldMapper
- MetadataFieldMapper(MappedFieldType, NamedAnalyzer) - Constructor for class org.elasticsearch.index.mapper.MetadataFieldMapper
- MetadataFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- MetadataFieldMapper.ConfigurableTypeParser - Class in org.elasticsearch.index.mapper
- MetadataFieldMapper.FixedTypeParser - Class in org.elasticsearch.index.mapper
-
A type parser for an unconfigurable metadata field.
- MetadataFieldMapper.TypeParser - Interface in org.elasticsearch.index.mapper
- MetadataIndexAliasesService - Class in org.elasticsearch.cluster.metadata
-
Service responsible for submitting add and remove aliases requests
- MetadataIndexAliasesService(ClusterService, IndicesService, AliasValidator, MetadataDeleteIndexService, NamedXContentRegistry) - Constructor for class org.elasticsearch.cluster.metadata.MetadataIndexAliasesService
- MetadataIndexStateService - Class in org.elasticsearch.cluster.metadata
-
Service responsible for submitting open/close index requests as well as for adding index blocks
- MetadataIndexStateService(ClusterService, AllocationService, IndexMetadataVerifier, IndicesService, ShardLimitValidator, ThreadPool, TransportVerifyShardBeforeCloseAction, TransportVerifyShardIndexBlockAction) - Constructor for class org.elasticsearch.cluster.metadata.MetadataIndexStateService
- MetadataIndexTemplateService - Class in org.elasticsearch.cluster.metadata
-
Service responsible for submitting index templates updates
- MetadataIndexTemplateService(ClusterService, MetadataCreateIndexService, AliasValidator, IndicesService, IndexScopedSettings, NamedXContentRegistry) - Constructor for class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
- MetadataIndexTemplateService.PutListener - Interface in org.elasticsearch.cluster.metadata
- MetadataIndexTemplateService.PutRequest - Class in org.elasticsearch.cluster.metadata
- MetadataIndexTemplateService.PutResponse - Class in org.elasticsearch.cluster.metadata
- MetadataIndexTemplateService.RemoveListener - Interface in org.elasticsearch.cluster.metadata
- MetadataIndexTemplateService.RemoveRequest - Class in org.elasticsearch.cluster.metadata
- metadataMapper(Class<T>) - Method in class org.elasticsearch.index.mapper.DocumentMapper
- MetadataMappingService - Class in org.elasticsearch.cluster.metadata
-
Service responsible for submitting mapping changes
- MetadataMappingService(ClusterService, IndicesService) - Constructor for class org.elasticsearch.cluster.metadata.MetadataMappingService
- MetadataMigrateToDataStreamService - Class in org.elasticsearch.cluster.metadata
- MetadataMigrateToDataStreamService(ThreadPool, ClusterService, IndicesService, MetadataCreateIndexService) - Constructor for class org.elasticsearch.cluster.metadata.MetadataMigrateToDataStreamService
- MetadataMigrateToDataStreamService.MigrateToDataStreamClusterStateUpdateRequest - Class in org.elasticsearch.cluster.metadata
- MetadataRolloverService - Class in org.elasticsearch.action.admin.indices.rollover
-
Service responsible for handling rollover requests for write aliases and data streams
- MetadataRolloverService(ThreadPool, MetadataCreateIndexService, MetadataIndexAliasesService, IndexNameExpressionResolver, SystemIndices) - Constructor for class org.elasticsearch.action.admin.indices.rollover.MetadataRolloverService
- MetadataRolloverService.NameResolution - Class in org.elasticsearch.action.admin.indices.rollover
- MetadataRolloverService.RolloverResult - Class in org.elasticsearch.action.admin.indices.rollover
- metadataSize(Map<String, Object>) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- metadataSnapshot() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- MetadataSnapshot(Map<String, StoreFileMetadata>, Map<String, String>, long) - Constructor for class org.elasticsearch.index.store.Store.MetadataSnapshot
- MetadataSnapshot(StreamInput) - Constructor for class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Read from a stream.
- MetadataStateFormat<T> - Class in org.elasticsearch.gateway
-
MetadataStateFormat is a base class to write checksummed XContent based files to one or more directories in a standardized directory structure.
- MetadataStateFormat(String) - Constructor for class org.elasticsearch.gateway.MetadataStateFormat
-
Creates a new
MetadataStateFormat
instance - metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.FailedNodeException
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.common.breaker.CircuitBreakingException
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.common.ParsingException
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.ElasticsearchException
-
Renders additional per exception information into the XContent
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.script.ScriptException
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
- metadataToXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.search.SearchParseException
- MetadataUpdateSettingsService - Class in org.elasticsearch.cluster.metadata
-
Service responsible for submitting update index settings requests
- MetadataUpdateSettingsService(ClusterService, AllocationService, IndexScopedSettings, IndicesService, ShardLimitValidator, ThreadPool) - Constructor for class org.elasticsearch.cluster.metadata.MetadataUpdateSettingsService
- MetadataUpgrader - Class in org.elasticsearch.plugins
- MetadataUpgrader(Collection<UnaryOperator<Map<String, IndexTemplateMetadata>>>) - Constructor for class org.elasticsearch.plugins.MetadataUpgrader
- metaParam() - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Declares a metadata parameter
- MetaStateService - Class in org.elasticsearch.gateway
- MetaStateService(NodeEnvironment, NamedXContentRegistry) - Constructor for class org.elasticsearch.gateway.MetaStateService
- MeteredBlobStoreRepository - Class in org.elasticsearch.repositories.blobstore
- MeteredBlobStoreRepository(RepositoryMetadata, boolean, NamedXContentRegistry, ClusterService, BigArrays, RecoverySettings, Map<String, String>) - Constructor for class org.elasticsearch.repositories.blobstore.MeteredBlobStoreRepository
- METERS - Enum constant in enum class org.elasticsearch.common.unit.DistanceUnit
- method() - Method in class org.elasticsearch.http.HttpPipelinedRequest
- method() - Method in interface org.elasticsearch.http.HttpRequest
-
Returns the HTTP method used in the HTTP request.
- method() - Method in class org.elasticsearch.rest.RestRequest
-
Returns the HTTP method used in the REST request.
- method() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
-
Deprecated.
- method(PercentilesMethod) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
-
Deprecated.
- METHOD - Static variable in class org.elasticsearch.common.hash.Murmur3Hasher
- METHOD_NOT_ALLOWED - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The method specified in the Request-Line is not allowed for the resource identified by the Request-URI.
- methods() - Method in class org.elasticsearch.script.ScriptContextInfo
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.GlobalOrdCardinalityAggregator
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregator
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.MinAggregator
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.SingleValue
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.SumAggregator
- metric(long) - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregator
- metric(String, long) - Method in class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.MultiValue
- metric(TimeSeriesParams.MetricType) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.Builder
- MetricAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.metrics
- MetricInspectionHelper - Class in org.elasticsearch.search.aggregations.metrics
-
Counterpart to
AggregationInspectionHelper
, providing helpers for some aggs that have package-private getters. - MetricInspectionHelper() - Constructor for class org.elasticsearch.search.aggregations.metrics.MetricInspectionHelper
- metricName() - Method in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
- metricName() - Method in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- metricNames() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
- metricNames() - Method in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- metricNames() - Method in class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- metricNames() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.MetricsAggregationBuilder
-
Generated metrics from this aggregation that can be accessed via
InternalAggregation.getProperty(String)
- metricNames() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.SingleMetricAggregationBuilder
- metricParam(Function<FieldMapper, TimeSeriesParams.MetricType>, TimeSeriesParams.MetricType...) - Static method in class org.elasticsearch.index.mapper.TimeSeriesParams
- MetricsAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.MetricsAggregationBuilder
- MetricsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.MetricsAggregationBuilder
- MetricsAggregationBuilder(ValuesSourceAggregationBuilder.LeafOnly<VS, AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.MetricsAggregationBuilder
- MetricsAggregator - Class in org.elasticsearch.search.aggregations.metrics
- MetricsAggregator(String, AggregationContext, Aggregator, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.MetricsAggregator
- mightContain(long) - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
-
Returns true if the set might contain the provided value, false otherwise.
- mightContain(BytesRef) - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
-
Returns true if the set might contain the provided value, false otherwise.
- mightMatchNestedDocs(Query) - Method in class org.elasticsearch.index.search.NestedHelper
-
Returns true if the given query might match nested documents.
- mightMatchNonNestedDocs(Query, String) - Method in class org.elasticsearch.index.search.NestedHelper
-
Returns true if the given query might match parent documents or documents that are nested under a different path.
- migrateToDataStream(MetadataMigrateToDataStreamService.MigrateToDataStreamClusterStateUpdateRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataMigrateToDataStreamService
- MigrateToDataStreamClusterStateUpdateRequest(String, TimeValue, TimeValue) - Constructor for class org.elasticsearch.cluster.metadata.MetadataMigrateToDataStreamService.MigrateToDataStreamClusterStateUpdateRequest
- MIGRATION_NEEDED - Enum constant in enum class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.UpgradeStatus
- MigrationResultsUpdateTask - Class in org.elasticsearch.upgrades
-
Handles updating the
FeatureMigrationResults
in the cluster state. - MILES - Enum constant in enum class org.elasticsearch.common.unit.DistanceUnit
- MILLIMETERS - Enum constant in enum class org.elasticsearch.common.unit.DistanceUnit
- MILLIS_PARSER - Static variable in class org.elasticsearch.index.mapper.DateFieldMapper
- MILLISECONDS - Enum constant in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
- min - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket.BucketBounds
- min - Variable in class org.elasticsearch.search.aggregations.metrics.InternalStats
- min - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- min() - Method in class org.elasticsearch.common.lucene.RegExp
-
Limits for repeatable type expressions.
- min() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- min(double[]) - Static method in class org.elasticsearch.search.aggregations.pipeline.MovingFunctions
-
Find the minimum value in a window of values If all values are missing/null/NaN, the return value will be NaN
- min(long, long) - Static method in class org.elasticsearch.index.seqno.SequenceNumbers
-
Compute the minimum of the given current minimum sequence number and the specified sequence number, accounting for the fact that the current minimum sequence number could be
SequenceNumbers.NO_OPS_PERFORMED
orSequenceNumbers.UNASSIGNED_SEQ_NO
. - min(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Min
aggregation with the given name. - min(Version, Version) - Static method in class org.elasticsearch.Version
-
Returns the minimum version between the 2.
- Min - Enum constant in enum class org.elasticsearch.search.rescore.QueryRescoreMode
- Min - Interface in org.elasticsearch.search.aggregations.metrics
-
An aggregation that computes the minimum of the values in the current bucket.
- MIN - Enum constant in enum class org.elasticsearch.common.lucene.search.function.CombineFunction
- MIN - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- MIN - Enum constant in enum class org.elasticsearch.search.MultiValueMode
-
Pick the lowest value.
- MIN - Enum constant in enum class org.elasticsearch.search.sort.SortMode
-
pick the lowest value
- MIN - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- MIN_AS_STRING - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- MIN_DOC_COUNT_FIELD - Static variable in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
- MIN_DOC_COUNT_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- MIN_DOC_FREQ_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- MIN_INDEX_BUFFER_SIZE_SETTING - Static variable in class org.elasticsearch.indices.IndexingMemoryController
-
Only applies when
indices.memory.index_buffer_size
is a %, to set a floor on the actual size in bytes (default: 48 MB). - MIN_LAT - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Minimum valid latitude in degrees.
- MIN_LON - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
Minimum valid longitude in degrees.
- MIN_PRECISION - Static variable in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- MIN_RETAINED_SEQNO - Static variable in class org.elasticsearch.index.engine.Engine
- MIN_SCORE_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- MIN_SCORE_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- MIN_SCORE_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- MIN_WORD_LENGTH_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- MinAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- MinAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
- MinAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
-
Read from a stream.
- MinAggregationBuilder(MinAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
- MinAggregator - Class in org.elasticsearch.search.aggregations.metrics
- MinAndMax<T extends Comparable<? super T>> - Class in org.elasticsearch.search.sort
-
A class that encapsulates a minimum and a maximum, that are of the same type and
Comparable
. - MinAndMax(StreamInput) - Constructor for class org.elasticsearch.search.sort.MinAndMax
- MinAndMax(T, T) - Constructor for class org.elasticsearch.search.sort.MinAndMax
- minBound() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Get the current minimum bound that is set on this builder.
- minBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- MinBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- MinBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.MinBucketPipelineAggregationBuilder
- MinBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.MinBucketPipelineAggregationBuilder
-
Read from a stream.
- MinBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- MinBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.MinBucketPipelineAggregator
-
Read from a stream.
- minCompatibleShardNode() - Method in class org.elasticsearch.action.search.SearchRequest
-
Returns the minimum compatible shard version the search request needs to run on.
- minCompatibleVersion(Version, RepositoryData, Collection<SnapshotId>) - Method in class org.elasticsearch.snapshots.SnapshotsService
-
Determines the minimum
Version
that the snapshot repository must be compatible with from the current nodes in the cluster and the contents of the repository. - minDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- minDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- minDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- minDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Return the minimum count of documents that buckets need to have in order to be included in the response.
- minDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregatorFactory
- minDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Return the minimum count of documents that buckets need to have in order to be included in the response.
- minDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregatorFactory
- minDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Returns the minimum document count required per term
- minDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set the minimum count of matching documents that buckets need to have and return this builder so that calls can be chained.
- minDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Set the minimum count of matching documents that buckets need to have and return this builder so that calls can be chained.
- minDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
-
Set the minimum document count terms should have in order to appear in the response.
- minDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
-
Set the minimum document count terms should have in order to appear in the response.
- minDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Set the minimum document count terms should have in order to appear in the response.
- minDocFreq - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- minDocFreq() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- minDocFreq() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- minDocFreq() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the minimal threshold for the frequency of a term appearing in the document set setting.
- minDocFreq(float) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- minDocFreq(float) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets a minimal threshold in number of documents a suggested term should appear in.
- minDocFreq(float) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets a minimal threshold in number of documents a suggested term should appear in.
- minDocFreq(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the frequency at which words will be ignored which do not occur in at least this many docs.
- MinDocQuery - Class in org.apache.lucene.queries
-
A
Query
that only matches documents that are greater than or equal to a configured doc ID. - MinDocQuery(int) - Constructor for class org.apache.lucene.queries.MinDocQuery
-
Sole constructor.
- minimize() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Gets whether the model should be fit to the data using a cost minimizing algorithm.
- minimize(boolean) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Sets whether the model should be fit to the data using a cost minimizing algorithm.
- minimize(MovAvgModel, EvictingQueue<Double>, double[]) - Static method in class org.elasticsearch.search.aggregations.pipeline.SimulatedAnealingMinimizer
-
Runs the simulated annealing algorithm and produces a model with new coefficients that, theoretically fit the data better and generalizes to future forecasts without overfitting.
- minimizeByDefault() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- minimizeByDefault() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
-
Should this model be fit to the data via a cost minimizing algorithm by default?
- MINIMUM_SHOULD_MATCH_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- minimumCompatibilityVersion() - Method in class org.elasticsearch.Version
-
Returns the minimum compatible version based on the current version.
- minimumCompatibleVersion() - Method in class org.elasticsearch.index.shard.IndexShard
- minimumDelayMillis() - Method in class org.elasticsearch.action.support.RetryableAction
- minimumIndexCompatibilityVersion() - Method in class org.elasticsearch.Version
-
Returns the minimum created index version that this version supports.
- minimumMasterNodes() - Method in class org.elasticsearch.discovery.zen.ElectMasterService
- minimumMasterNodes(int) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
- minimumMasterNodesOnPublishingMaster(int) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- minimumScore() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- minimumScore() - Method in class org.elasticsearch.search.internal.SearchContext
- minimumScore(float) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- minimumScore(float) - Method in class org.elasticsearch.search.internal.SearchContext
- minimumScore(float) - Method in class org.elasticsearch.search.internal.SubSearchContext
- MinimumScoreCollector - Class in org.elasticsearch.common.lucene
- MinimumScoreCollector(Collector, float) - Constructor for class org.elasticsearch.common.lucene.MinimumScoreCollector
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Gets the minimumShouldMatch value
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Gets the minimumShouldMatch value
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- minimumShouldMatch() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns the minimumShouldMatch to apply to the resulting query should that be a Boolean query.
- minimumShouldMatch(int) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Specifies a minimum number of the optional (should) boolean clauses which must be satisfied.
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Sets the minimum should match parameter using the special syntax (for example, supporting percentage).
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Sets optional minimumShouldMatch value to apply to the query
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets optional minimumShouldMatch value to apply to the query
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Number of terms that must match the generated query expressed in the common syntax for minimum should match.
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- minimumShouldMatch(String) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Specifies the minimumShouldMatch to apply to the resulting query should that be a Boolean query.
- minor - Variable in class org.elasticsearch.Version
- minorDeviceNumber - Variable in class org.elasticsearch.env.NodeEnvironment.DataPath
- minScore() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the minimum score below which docs will be filtered out.
- minScore(float) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets the minimum score below which docs will be filtered out.
- minTermFreq - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- minTermFreq() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- minTermFreq(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
The frequency below which terms will be ignored in the source doc.
- minus(long, TemporalUnit) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minus(TemporalAmount) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- MINUS_ONE - Static variable in class org.elasticsearch.common.unit.ByteSizeValue
- minusDays(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusHours(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusMinutes(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusMonths(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusNanos(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusSeconds(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusWeeks(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- minusYears(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- MINUTE - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- minutes(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- MINUTES_OF_HOUR - Enum constant in enum class org.elasticsearch.common.rounding.DateTimeUnit
- MINUTES_OF_HOUR - Enum constant in enum class org.elasticsearch.common.Rounding.DateTimeUnit
- minValue() - Method in enum class org.elasticsearch.index.mapper.RangeType
- minWordLength - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- minWordLength() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- minWordLength() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- minWordLength() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the minimum length of a text term to be corrected setting.
- minWordLength(int) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the minimum word length below which words will be ignored.
- minWordLength(int) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- minWordLength(int) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
The minimum length a suggest text term must have in order to be corrected.
- minWordLength(int) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
The minimum length a suggest text term must have in order to be corrected.
- misplacedBindingAnnotation(Member, Annotation) - Method in class org.elasticsearch.common.inject.internal.Errors
- missing - Variable in class org.elasticsearch.index.store.Store.RecoveryDiff
-
Files that exist in the source but not in the target
- missing() - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- missing() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Gets the value to use when the aggregation finds a missing value in a document
- missing() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- missing() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Returns the value used when a field is missing in a doc.
- missing(double) - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
-
Value used instead of the field value for documents that don't have that field defined.
- missing(Object) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Sets the value to use when the aggregation finds a missing value in a document
- missing(Object) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Sets the value when a field is missing in a doc.
- missing(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Missing
aggregation with the given name. - Missing - Interface in org.elasticsearch.search.aggregations.bucket.missing
-
A
missing
aggregation. - MISSING - Enum constant in enum class org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- MISSING - Enum constant in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
-
Only suggest terms in the suggest text that aren't in the index.
- MISSING - Static variable in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
-
Shard snapshot status for shards that could not be snapshotted because their index was deleted from before the shard snapshot started.
- MISSING - Static variable in class org.elasticsearch.search.sort.FieldSortBuilder
- MISSING_UUID - Static variable in class org.elasticsearch.repositories.RepositoryData
-
Sentinel value for the repository UUID indicating that it is not set.
- MISSING_VALUE_MARKER - Static variable in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfigExclusion
- MissingAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.missing
- MissingAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- MissingAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
-
Read from a stream.
- MissingAggregationBuilder(MissingAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- MissingAggregator - Class in org.elasticsearch.search.aggregations.bucket.missing
- MissingAggregator(String, AggregatorFactories, ValuesSourceConfig, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregator
- MissingAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.missing
- MissingAggregatorFactory(String, ValuesSourceConfig, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>, MissingAggregatorSupplier) - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregatorFactory
- MissingAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.bucket.missing
- missingBucket - Variable in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSource
- missingBucket() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
False if documents with missing values are ignored, otherwise missing values are represented by an explicit `null` value.
- missingBucket(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
If
true
an explicitnull
bucket will represent documents with missing values. - missingConstantValues() - Method in class org.elasticsearch.common.inject.internal.Errors
- missingConstructor(Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
- MissingHistoryOperationsException - Exception in org.elasticsearch.index.engine
-
Exception indicating that not all requested operations from
LuceneChangesSnapshot
are available. - missingImplementation(Key) - Method in class org.elasticsearch.common.inject.internal.Errors
-
We use a fairly generic error message here.
- missingObject(Object, boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.LongValuesComparatorSource
- missingObject(Object, boolean) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
-
Return the missing object value according to the reduced type of the comparator.
- missingOrder - Variable in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSource
- missingOrder() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
The
MissingOrder
policy used for ordering missing values. - missingOrder(String) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Sets the
MissingOrder
policy to use for ordering missing values. - missingOrder(MissingOrder) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Sets the
MissingOrder
policy to use for ordering missing values. - MissingOrder - Enum Class in org.elasticsearch.search.aggregations.bucket.composite
- missingRuntimeRetention(Object) - Method in class org.elasticsearch.common.inject.internal.Errors
- missingScopeAnnotation() - Method in class org.elasticsearch.common.inject.internal.Errors
- missingValue - Variable in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- missingValue(boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
- missingValue(boolean) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
-
Return a missing value that is understandable by
SortField.setMissingValue(Object)
. - MissingValues - Enum Class in org.elasticsearch.search.aggregations.support
-
Utility class that allows to return views of
ValuesSource
s that replace the missing value with a configured value. - MMAPFS - Enum constant in enum class org.elasticsearch.index.IndexModule.Type
- mode - Variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- model() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Gets a MovAvgModel for the Moving Average.
- model(MovAvgModel) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Sets a MovAvgModel for the Moving Average.
- modelBuilder(MovAvgModelBuilder) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Sets a MovAvgModel for the Moving Average.
- modeName() - Method in class org.elasticsearch.transport.ProxyConnectionStrategy.ProxyModeInfo
- modeName() - Method in interface org.elasticsearch.transport.RemoteConnectionInfo.ModeInfo
- modeName() - Method in class org.elasticsearch.transport.SniffConnectionStrategy.SniffModeInfo
- modeType() - Method in class org.elasticsearch.transport.ProxyConnectionStrategy.ProxyModeInfo
- modeType() - Method in interface org.elasticsearch.transport.RemoteConnectionInfo.ModeInfo
- modeType() - Method in class org.elasticsearch.transport.SniffConnectionStrategy.SniffModeInfo
- modifier() - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- modifier(FieldValueFactorFunction.Modifier) - Method in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- modifyDataStream(ModifyDataStreamsAction.Request, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataDataStreamsService
- ModifyDataStreamsAction - Class in org.elasticsearch.action.datastreams
- ModifyDataStreamsAction.Request - Class in org.elasticsearch.action.datastreams
- ModifyDataStreamsTransportAction - Class in org.elasticsearch.action.datastreams
- ModifyDataStreamsTransportAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, MetadataDataStreamsService) - Constructor for class org.elasticsearch.action.datastreams.ModifyDataStreamsTransportAction
- Module - Interface in org.elasticsearch.common.inject
-
A module contributes configuration information, typically interface bindings, which will be used to create an
Injector
. - Modules - Class in org.elasticsearch.common.inject.util
-
Static utility methods for creating and working with instances of
Module
. - Modules.OverriddenModuleBuilder - Interface in org.elasticsearch.common.inject.util
-
See the EDSL example at
override()
. - ModulesBuilder - Class in org.elasticsearch.common.inject
- ModulesBuilder() - Constructor for class org.elasticsearch.common.inject.ModulesBuilder
- modulesFile() - Method in class org.elasticsearch.env.Environment
- MonitorService - Class in org.elasticsearch.monitor
- MonitorService(Settings, NodeEnvironment, ThreadPool) - Constructor for class org.elasticsearch.monitor.MonitorService
- MONTH - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- MONTH_OF_YEAR - Enum constant in enum class org.elasticsearch.common.rounding.DateTimeUnit
- MONTH_OF_YEAR - Enum constant in enum class org.elasticsearch.common.Rounding.DateTimeUnit
- moreLikeThisQuery(String[]) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A more like this query that finds documents that are "like" the provided texts which is checked against the "_all" field.
- moreLikeThisQuery(String[], String[], MoreLikeThisQueryBuilder.Item[]) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A more like this query that finds documents that are "like" the provided texts or documents which is checked against the fields the query is constructed with.
- moreLikeThisQuery(String[], MoreLikeThisQueryBuilder.Item[]) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A more like this query that finds documents that are "like" the provided texts or documents which is checked against the "_all" field.
- moreLikeThisQuery(MoreLikeThisQueryBuilder.Item[]) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A more like this query that finds documents that are "like" the provided documents which is checked against the "_all" field.
- MoreLikeThisQuery - Class in org.elasticsearch.common.lucene.search
- MoreLikeThisQuery() - Constructor for class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- MoreLikeThisQuery(String, String[], NamedAnalyzer) - Constructor for class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- MoreLikeThisQueryBuilder - Class in org.elasticsearch.index.query
-
A more like this query that finds documents that are "like" the provided set of document(s).
- MoreLikeThisQueryBuilder(String[], String[], MoreLikeThisQueryBuilder.Item[]) - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the field names that will be used when generating the 'More Like This' query.
- MoreLikeThisQueryBuilder(String[], MoreLikeThisQueryBuilder.Item[]) - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Constructs a new more like this query which uses the default search field.
- MoreLikeThisQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Read from a stream.
- MoreLikeThisQueryBuilder.Item - Class in org.elasticsearch.index.query
-
A single item to be used for a
MoreLikeThisQueryBuilder
. - MoreTypes - Class in org.elasticsearch.common.inject.internal
-
Static methods for working with types that we aren't publishing in the public
Types
API. - MoreTypes.GenericArrayTypeImpl - Class in org.elasticsearch.common.inject.internal
- MoreTypes.MemberImpl - Class in org.elasticsearch.common.inject.internal
-
We cannot serialize the built-in Java member classes, which prevents us from using Members in our exception types.
- MoreTypes.ParameterizedTypeImpl - Class in org.elasticsearch.common.inject.internal
- MoreTypes.WildcardTypeImpl - Class in org.elasticsearch.common.inject.internal
-
The WildcardType interface supports multiple upper bounds and multiple lower bounds.
- MOST_FIELDS - Enum constant in enum class org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Uses the sum of the matching boolean fields to score the query
- MovAvgModel - Class in org.elasticsearch.search.aggregations.pipeline
- MovAvgModel() - Constructor for class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
- MovAvgModel.AbstractModelParser - Class in org.elasticsearch.search.aggregations.pipeline
-
Abstract class which also provides some concrete parsing functionality.
- MovAvgModelBuilder - Interface in org.elasticsearch.search.aggregations.pipeline
-
Represents the common interface that all moving average models share.
- MovAvgPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- MovAvgPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
- MovAvgPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Read from a stream.
- MovAvgPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- MovAvgPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregator
-
Read from a stream.
- moveActiveReplicaToPrimary() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Make the active shard primary unless it's not primary
- MoveAllocationCommand - Class in org.elasticsearch.cluster.routing.allocation.command
-
A command that moves a shard from a specific node to another node.
Note: The shard needs to be in the stateShardRoutingState.STARTED
in order to be moved. - MoveAllocationCommand(String, int, String, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- MoveAllocationCommand(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
-
Read from a stream.
- moveBlobAtomic(String, String, boolean) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- MOVED_PERMANENTLY - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The requested resource has been assigned a new permanent URI and any future references to this resource SHOULD use one of the returned URIs.
- MoveDecision - Class in org.elasticsearch.cluster.routing.allocation
-
Represents a decision to move a started shard, either because it is no longer allowed to remain on its current node or because moving it to another node will form a better cluster balance.
- MoveDecision(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.MoveDecision
- moveShards() - Method in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator.Balancer
-
Move started shards that can not be allocated to a node anymore For each shard to be moved this function executes a move operation to the minimal eligible node with respect to the weight function.
- moveToClosed() - Method in class org.elasticsearch.common.component.Lifecycle
- moveToDone(long, ShardSnapshotResult) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- moveToFailed(long, String) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- moveToFinalize(long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- moveToStarted() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Set the shards state to
STARTED
. - moveToStarted() - Method in class org.elasticsearch.common.component.Lifecycle
- moveToStarted(long, int, int, long, long) - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- moveToStopped() - Method in class org.elasticsearch.common.component.Lifecycle
- moveToUnassigned(UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Moves the shard to unassigned state.
- moveUnassignedFromPrimary() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Set the unassigned primary shard to non-primary
- MovFnPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- MovFnPipelineAggregationBuilder(String, String, Script, int) - Constructor for class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- MovFnPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- MovFnPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
-
This pipeline aggregation gives the user the ability to script functions that "move" across a window of data, instead of single data points.
- MovFnPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregator
- movingAvg(String, String) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
-
Deprecated.
- movingFunction(String, Script, String, int) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- MovingFunctions - Class in org.elasticsearch.search.aggregations.pipeline
-
Provides a collection of static utility methods that can be referenced from MovingFunction script contexts
- MovingFunctions() - Constructor for class org.elasticsearch.search.aggregations.pipeline.MovingFunctions
- MovingFunctionScript - Class in org.elasticsearch.search.aggregations.pipeline
-
This class provides a custom script context for the Moving Function pipeline aggregation, so that we can expose a number of pre-baked moving functions like min, max, movavg, etc
- MovingFunctionScript() - Constructor for class org.elasticsearch.search.aggregations.pipeline.MovingFunctionScript
- MovingFunctionScript.Factory - Interface in org.elasticsearch.search.aggregations.pipeline
- Multi() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- MULTI_ALLOW_EXPLICIT_INDEX - Static variable in class org.elasticsearch.rest.BaseRestHandler
- MULTI_DELETE_VERSION - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- MULTI_STATUS - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The 207 (Multi-Status) status code provides status for multiple independent operations (see Section 13 for more information).
- MULTI_VALUE_MODE - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionParser
- Multibinder<T> - Class in org.elasticsearch.common.inject.multibindings
-
An API to bind multiple values separately, only to later inject them as a complete collection.
- Multibinder.RealMultibinder<T> - Class in org.elasticsearch.common.inject.multibindings
-
The actual multibinder plays several roles:
- MultiBucketCollector - Class in org.elasticsearch.search.aggregations
-
A
BucketCollector
which allows running a bucket collection with severalBucketCollector
s. - multiBucketConsumer() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
- multiBucketConsumer() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- MultiBucketConsumer(int, CircuitBreaker) - Constructor for class org.elasticsearch.search.aggregations.MultiBucketConsumerService.MultiBucketConsumer
- MultiBucketConsumerService - Class in org.elasticsearch.search.aggregations
-
An aggregation service that creates instances of
MultiBucketConsumerService.MultiBucketConsumer
. - MultiBucketConsumerService(ClusterService, Settings, CircuitBreaker) - Constructor for class org.elasticsearch.search.aggregations.MultiBucketConsumerService
- MultiBucketConsumerService.MultiBucketConsumer - Class in org.elasticsearch.search.aggregations
-
An
IntConsumer
that throws aMultiBucketConsumerService.TooManyBucketsException
when the sum of the provided values is above the limit (`search.max_buckets`). - MultiBucketConsumerService.TooManyBucketsException - Exception in org.elasticsearch.search.aggregations
- MultiBucketsAggregation - Interface in org.elasticsearch.search.aggregations.bucket
-
An aggregation that returns multiple buckets
- MultiBucketsAggregation.Bucket - Interface in org.elasticsearch.search.aggregations.bucket
-
A bucket represents a criteria to which all documents that fall in it adhere to.
- MultiCandidateGeneratorWrapper - Class in org.elasticsearch.search.suggest.phrase
- MultiCandidateGeneratorWrapper(int, CandidateGenerator...) - Constructor for class org.elasticsearch.search.suggest.phrase.MultiCandidateGeneratorWrapper
- MultiChunkTransfer<Source,
Request extends MultiChunkTransfer.ChunkRequest> - Class in org.elasticsearch.indices.recovery -
File chunks are sent/requested sequentially by at most one thread at any time.
- MultiChunkTransfer(Logger, ThreadContext, ActionListener<Void>, int, List<Source>) - Constructor for class org.elasticsearch.indices.recovery.MultiChunkTransfer
- MultiChunkTransfer.ChunkRequest - Interface in org.elasticsearch.indices.recovery
- multiFields - Variable in class org.elasticsearch.index.mapper.FieldMapper
- multiFields() - Method in class org.elasticsearch.index.mapper.FieldMapper
- multiFieldsBuilder - Variable in class org.elasticsearch.index.mapper.FieldMapper.Builder
- MultiFileWriter - Class in org.elasticsearch.indices.recovery
- MultiFileWriter(Store, RecoveryState.Index, String, Logger, Runnable) - Constructor for class org.elasticsearch.indices.recovery.MultiFileWriter
- MultiGeoPointValues - Class in org.elasticsearch.index.fielddata
-
A stateful lightweight per document set of
GeoPoint
values. - MultiGeoPointValues() - Constructor for class org.elasticsearch.index.fielddata.MultiGeoPointValues
-
Creates a new
MultiGeoPointValues
instance - multiGet(MultiGetRequest) - Method in interface org.elasticsearch.client.Client
-
Multi get documents.
- multiGet(MultiGetRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- multiGet(MultiGetRequest, ActionListener<MultiGetResponse>) - Method in interface org.elasticsearch.client.Client
-
Multi get documents.
- multiGet(MultiGetRequest, ActionListener<MultiGetResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- MultiGetAction - Class in org.elasticsearch.action.get
- MultiGetItemResponse - Class in org.elasticsearch.action.get
-
A single multi get response.
- MultiGetItemResponse(GetResponse, MultiGetResponse.Failure) - Constructor for class org.elasticsearch.action.get.MultiGetItemResponse
- MultiGetRequest - Class in org.elasticsearch.action.get
- MultiGetRequest() - Constructor for class org.elasticsearch.action.get.MultiGetRequest
- MultiGetRequest(StreamInput) - Constructor for class org.elasticsearch.action.get.MultiGetRequest
- MultiGetRequest.Item - Class in org.elasticsearch.action.get
-
A single get item.
- MultiGetRequestBuilder - Class in org.elasticsearch.action.get
-
A multi get document action request builder.
- MultiGetRequestBuilder(ElasticsearchClient, MultiGetAction) - Constructor for class org.elasticsearch.action.get.MultiGetRequestBuilder
- MultiGetResponse - Class in org.elasticsearch.action.get
- MultiGetResponse(MultiGetItemResponse[]) - Constructor for class org.elasticsearch.action.get.MultiGetResponse
- MultiGetResponse.Failure - Class in org.elasticsearch.action.get
-
Represents a failure.
- MultiGetShardRequest - Class in org.elasticsearch.action.get
- MultiGetShardResponse - Class in org.elasticsearch.action.get
- multiMatchQuery(Object, String...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a match query with type "BOOLEAN" for the provided field name and text.
- MultiMatchQueryBuilder - Class in org.elasticsearch.index.query
-
Same as
MatchQueryBuilder
but supports multiple fields. - MultiMatchQueryBuilder(Object, String...) - Constructor for class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Constructs a new text query.
- MultiMatchQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Read from a stream.
- MultiMatchQueryBuilder.Type - Enum Class in org.elasticsearch.index.query
- MultiMatchQueryParser - Class in org.elasticsearch.index.search
- MultiMatchQueryParser(SearchExecutionContext) - Constructor for class org.elasticsearch.index.search.MultiMatchQueryParser
- MultiOrdinals - Class in org.elasticsearch.index.fielddata.ordinals
-
Ordinals
implementation which is efficient at storing field data ordinals for multi-valued or sparse fields. - MultiOrdinals(OrdinalsBuilder, float) - Constructor for class org.elasticsearch.index.fielddata.ordinals.MultiOrdinals
- MultiPhrasePrefixQuery - Class in org.elasticsearch.common.lucene.search
- MultiPhrasePrefixQuery(String) - Constructor for class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
- multiPhraseQuery(TokenStream, int, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- multiPhraseQuery(TokenStream, int, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- multiPhraseQuery(TokenStream, int, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- MULTIPLE_CHOICES - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The requested resource corresponds to any one of a set of representations, each with its own specific location, and agent-driven negotiation information (section 12) is being provided so that the user (or user agent) can select a preferred representation and redirect its request to that location.
- MULTIPLE_REPOSITORIES_SUPPORT_ADDED - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- MULTIPLICATIVE - Enum constant in enum class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.SeasonalityType
- multiply(int) - Method in class org.elasticsearch.search.aggregations.CardinalityUpperBound
-
Get the rough measure of the number of buckets a fixed-bucket
Aggregator
will collect. - Multiply - Enum constant in enum class org.elasticsearch.search.rescore.QueryRescoreMode
- MULTIPLY - Enum constant in enum class org.elasticsearch.common.lucene.search.function.CombineFunction
- MULTIPLY - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- multiSearch(MultiSearchRequest) - Method in interface org.elasticsearch.client.Client
-
Performs multiple search requests.
- multiSearch(MultiSearchRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- multiSearch(MultiSearchRequest, ActionListener<MultiSearchResponse>) - Method in interface org.elasticsearch.client.Client
-
Performs multiple search requests.
- multiSearch(MultiSearchRequest, ActionListener<MultiSearchResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- MultiSearchAction - Class in org.elasticsearch.action.search
- MultiSearchRequest - Class in org.elasticsearch.action.search
-
A multi search API request.
- MultiSearchRequest() - Constructor for class org.elasticsearch.action.search.MultiSearchRequest
- MultiSearchRequest(StreamInput) - Constructor for class org.elasticsearch.action.search.MultiSearchRequest
- MultiSearchRequestBuilder - Class in org.elasticsearch.action.search
-
A request builder for multiple search requests.
- MultiSearchRequestBuilder(ElasticsearchClient, MultiSearchAction) - Constructor for class org.elasticsearch.action.search.MultiSearchRequestBuilder
- MultiSearchResponse - Class in org.elasticsearch.action.search
-
A multi search response.
- MultiSearchResponse(MultiSearchResponse.Item[], long) - Constructor for class org.elasticsearch.action.search.MultiSearchResponse
- MultiSearchResponse(StreamInput) - Constructor for class org.elasticsearch.action.search.MultiSearchResponse
- MultiSearchResponse.Item - Class in org.elasticsearch.action.search
-
A search response item, holding the actual search response, or an error message if it failed.
- MultiTermQueryBuilder - Interface in org.elasticsearch.index.query
- multiTermVectors(MultiTermVectorsRequest) - Method in interface org.elasticsearch.client.Client
-
Multi get term vectors.
- multiTermVectors(MultiTermVectorsRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- multiTermVectors(MultiTermVectorsRequest, ActionListener<MultiTermVectorsResponse>) - Method in interface org.elasticsearch.client.Client
-
Multi get term vectors.
- multiTermVectors(MultiTermVectorsRequest, ActionListener<MultiTermVectorsResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- MultiTermVectorsAction - Class in org.elasticsearch.action.termvectors
- MultiTermVectorsItemResponse - Class in org.elasticsearch.action.termvectors
-
A single multi get response.
- MultiTermVectorsItemResponse(TermVectorsResponse, MultiTermVectorsResponse.Failure) - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
- MultiTermVectorsRequest - Class in org.elasticsearch.action.termvectors
- MultiTermVectorsRequest() - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- MultiTermVectorsRequest(StreamInput) - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- MultiTermVectorsRequestBuilder - Class in org.elasticsearch.action.termvectors
- MultiTermVectorsRequestBuilder(ElasticsearchClient, MultiTermVectorsAction) - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsRequestBuilder
- MultiTermVectorsResponse - Class in org.elasticsearch.action.termvectors
- MultiTermVectorsResponse(MultiTermVectorsItemResponse[]) - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsResponse
- MultiTermVectorsResponse(StreamInput) - Constructor for class org.elasticsearch.action.termvectors.MultiTermVectorsResponse
- MultiTermVectorsResponse.Failure - Class in org.elasticsearch.action.termvectors
-
Represents a failure.
- MultiTermVectorsShardRequest - Class in org.elasticsearch.action.termvectors
- MultiTermVectorsShardResponse - Class in org.elasticsearch.action.termvectors
- MULTIVAL_SEP_CHAR - Static variable in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
- MultiValue(String, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
- MultiValue(String, AggregationContext, Aggregator, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.MultiValue
- MultiValue(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
-
Read from a stream.
- MultiValueAggregation - Interface in org.elasticsearch.search.aggregations.metrics
- MultiValueMode - Enum Class in org.elasticsearch.search
-
Defines what values to pick in the case a document contains multiple values for a particular field.
- MultiValuesSource<VS extends ValuesSource> - Class in org.elasticsearch.search.aggregations.support
-
Class to encapsulate a set of ValuesSource objects labeled by field name
- MultiValuesSource() - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSource
- MultiValuesSource.NumericMultiValuesSource - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSourceAggregationBuilder<AB extends MultiValuesSourceAggregationBuilder<AB>> - Class in org.elasticsearch.search.aggregations.support
-
Similar to
ValuesSourceAggregationBuilder
, except it references multiple ValuesSources (e.g. - MultiValuesSourceAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- MultiValuesSourceAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
-
Read from a stream.
- MultiValuesSourceAggregationBuilder(MultiValuesSourceAggregationBuilder<AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- MultiValuesSourceAggregationBuilder.LeafOnly<AB extends MultiValuesSourceAggregationBuilder<AB>> - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSourceAggregatorFactory - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSourceAggregatorFactory(String, Map<String, ValuesSourceConfig>, DocValueFormat, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregatorFactory
- MultiValuesSourceFieldConfig - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSourceFieldConfig(String, Object, Script, ZoneId, QueryBuilder, ValueType, String) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- MultiValuesSourceFieldConfig(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- MultiValuesSourceFieldConfig.Builder - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSourceFieldConfig.ParserBuilder - Interface in org.elasticsearch.search.aggregations.support
- MultiValuesSourceParseHelper - Class in org.elasticsearch.search.aggregations.support
- MultiValuesSourceParseHelper() - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSourceParseHelper
- Murmur3Hasher - Class in org.elasticsearch.common.hash
-
Wraps
MurmurHash3
to provide an interface similar toMessageDigest
that allows hashing of byte arrays passed through multiple calls toMurmur3Hasher.update(byte[])
. - Murmur3Hasher(long) - Constructor for class org.elasticsearch.common.hash.Murmur3Hasher
- Murmur3HashFunction - Class in org.elasticsearch.cluster.routing
-
Hash function based on the Murmur3 algorithm, which is the default as of Elasticsearch 2.0.
- murmur64(long) - Static method in enum class org.elasticsearch.common.hash.MurmurHash3
-
A 64-bit variant which accepts a long to hash, and returns the 64bit long hash.
- MurmurHash3 - Enum Class in org.elasticsearch.common.hash
-
MurmurHash3 hashing functions.
- MurmurHash3.Hash128 - Class in org.elasticsearch.common.hash
-
A 128-bits hash.
- must() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Gets the queries that must appear in the matching documents.
- must(QueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Adds a query that must appear in the matching documents and will contribute to scoring.
- MUST_JOIN_ELECTED_MASTER - Static variable in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfiguration
- mustAck(DiscoveryNode) - Method in interface org.elasticsearch.cluster.AckedClusterStateTaskListener
-
Called to determine which nodes the acknowledgement is expected from.
- mustAck(DiscoveryNode) - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
-
Called to determine which nodes the acknowledgement is expected from
- mustExist() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- mustExist(Boolean) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- mustNot() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Gets the queries that must not appear in the matching documents.
- mustNot(QueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Adds a query that must not appear in the matching documents.
- mustReduceOnSingleInternalAgg() - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- mustReduceOnSingleInternalAgg() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Signal the framework if the InternalAggregation.reduce(List, ReduceContext) phase needs to be called when there is only one InternalAggregation.
- mustReduceOnSingleInternalAgg() - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
- mustReduceOnSingleInternalAgg() - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- mustReduceOnSingleInternalAgg() - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- mustReduceOnSingleInternalAgg() - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation
- mustReduceOnSingleInternalAgg() - Method in class org.elasticsearch.search.aggregations.metrics.InternalScriptedMetric
- mustReduceOnSingleInternalAgg() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTopHits
- mustReschedule() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
-
Test any external conditions that determine whether the task should be scheduled.
- mustVisitAllDocs() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- mutableIterator() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- MutualInformation - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- MutualInformation(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.MutualInformation
- MutualInformation(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.MutualInformation
-
Read from a stream.
- MutualInformation.MutualInformationBuilder - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- MutualInformationBuilder(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.MutualInformation.MutualInformationBuilder
- MVT - Static variable in class org.elasticsearch.common.geo.SimpleVectorTileFormatter
N
- N - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.Frequencies
- N_0 - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.Frequencies
- N_1 - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.Frequencies
- N0_ - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.Frequencies
- N00 - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.Frequencies
- N01 - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.Frequencies
- N1_ - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.Frequencies
- N10 - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.Frequencies
- N11 - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.Frequencies
- name - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition
- name - Variable in class org.elasticsearch.common.io.stream.NamedWriteableRegistry.Entry
-
A name for the writeable which is unique to the
NamedWriteableRegistry.Entry.categoryClass
. - name - Variable in class org.elasticsearch.index.analysis.NameOrDefinition
- name - Variable in class org.elasticsearch.index.analysis.PreConfiguredAnalysisComponent
- name - Variable in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- name - Variable in class org.elasticsearch.index.mapper.Mapper.Builder
- name - Variable in enum class org.elasticsearch.index.mapper.RangeType
- name - Variable in class org.elasticsearch.repositories.RepositoryInfo
- name - Variable in class org.elasticsearch.script.ScriptContext
-
A unique identifier for this context.
- name - Variable in class org.elasticsearch.script.ScriptContextInfo
- name - Variable in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo
- name - Variable in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo.ParameterInfo
- name - Variable in class org.elasticsearch.search.aggregations.AggregationBuilder
- name - Variable in class org.elasticsearch.search.aggregations.AggregatorBase
- name - Variable in class org.elasticsearch.search.aggregations.AggregatorFactory
- name - Variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- name - Variable in class org.elasticsearch.search.aggregations.InternalAggregation
- name - Variable in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
- name - Variable in class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
- name - Variable in class org.elasticsearch.search.suggest.completion.context.ContextBuilder
- name - Variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- name - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion
- name() - Method in class org.elasticsearch.action.ActionType
-
The name of the action.
- name() - Method in class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryRequest
- name() - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
-
The name of the repository.
- name() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
The name of the repository.
- name() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
-
The name of the repository.
- name() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Returns the alias name
- name() - Method in class org.elasticsearch.action.admin.indices.rollover.Condition
- name() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
-
The index template name to delete.
- name() - Method in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Request
-
The name of the component templates.
- name() - Method in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Request
-
The name of the index templates.
- name() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction.Request
-
The name of the index template.
- name() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
-
The name of the index template.
- name() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The name of the index template.
- name() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- name() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
-
Returns repository name
- name() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
- name() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand
- name() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
- name() - Method in interface org.elasticsearch.cluster.routing.allocation.command.AllocationCommand
-
Get the name of the command
- name() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- name() - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- name() - Method in interface org.elasticsearch.common.blobstore.BlobMetadata
-
Gets the name of the blob.
- name() - Method in class org.elasticsearch.common.blobstore.support.PlainBlobMetadata
- name() - Method in class org.elasticsearch.index.analysis.AbstractCharFilterFactory
- name() - Method in class org.elasticsearch.index.analysis.AbstractIndexAnalyzerProvider
-
Returns the injected name of the analyzer.
- name() - Method in class org.elasticsearch.index.analysis.AbstractTokenFilterFactory
- name() - Method in class org.elasticsearch.index.analysis.AbstractTokenizerFactory
- name() - Method in interface org.elasticsearch.index.analysis.AnalyzerProvider
- name() - Method in interface org.elasticsearch.index.analysis.CharFilterFactory
- name() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
-
The name of the analyzer.
- name() - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProvider
- name() - Method in class org.elasticsearch.index.analysis.ShingleTokenFilterFactory.Factory
- name() - Method in interface org.elasticsearch.index.analysis.TokenFilterFactory
- name() - Method in interface org.elasticsearch.index.analysis.TokenizerFactory
- name() - Method in class org.elasticsearch.index.mapper.CompositeRuntimeField
- name() - Method in class org.elasticsearch.index.mapper.CustomDocValuesField
- name() - Method in class org.elasticsearch.index.mapper.DynamicTemplate
- name() - Method in class org.elasticsearch.index.mapper.FieldAliasMapper.Builder
- name() - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
- name() - Method in class org.elasticsearch.index.mapper.FieldMapper
- name() - Method in class org.elasticsearch.index.mapper.LeafRuntimeField
- name() - Method in class org.elasticsearch.index.mapper.MappedFieldType
- name() - Method in class org.elasticsearch.index.mapper.Mapper.Builder
- name() - Method in class org.elasticsearch.index.mapper.Mapper
-
Returns the canonical name which uniquely identifies the mapper against other mappers in a type.
- name() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- name() - Method in interface org.elasticsearch.index.mapper.RuntimeField
-
Exposes the name of the runtime field
- name() - Method in class org.elasticsearch.index.similarity.SimilarityProvider
-
Return the name of this
Similarity
. - name() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns the base file name
- name() - Method in class org.elasticsearch.index.store.StoreFileMetadata
-
Returns the name of this file
- name() - Method in exception org.elasticsearch.indices.IndexTemplateMissingException
- name() - Method in exception org.elasticsearch.indices.InvalidIndexTemplateException
- name() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- name() - Method in class org.elasticsearch.indices.recovery.RecoveryState.FileDetail
-
file name *
- name() - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- name() - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Return the name of this aggregator.
- name() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- name() - Method in class org.elasticsearch.search.aggregations.AggregatorFactory
- name() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- name() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- name() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- name() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
- name() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
-
The name of the field highlighted.
- name() - Method in class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext.ScriptField
- name() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- name() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- name() - Method in class org.elasticsearch.snapshots.RestoreInfo
-
Snapshot name
- name() - Method in class org.elasticsearch.threadpool.ExecutorBuilder
- name(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryRequest
- name(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
-
Sets the name of the repository to unregister.
- name(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Sets the name of the repository.
- name(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
-
Sets the name of the repository to unregister.
- name(String) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Modify the alias name only
- name(String) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
-
Set the index template name to delete.
- name(String) - Method in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Request
-
Sets the name of the component templates.
- name(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Sets the name of the index template.
- NAME - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.SortBy
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.health.ClusterHealthAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.liveness.TransportLivenessAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.features.SnapshottableFeaturesAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.state.ClusterStateAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptContextAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptLanguageAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptAction
- NAME - Static variable in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.close.CloseIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.create.AutoCreateAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.create.CreateIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.dangling.delete.DeleteDanglingIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.dangling.find.FindDanglingIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.dangling.import_index.ImportDanglingIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.delete.DeleteIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.diskusage.AnalyzeIndexDiskUsageAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.flush.FlushAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.flush.SyncedFlushAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.get.GetIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.mapping.put.AutoPutMappingAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.open.OpenIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.recovery.RecoveryAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.refresh.RefreshAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- NAME - Static variable in class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- NAME - Static variable in class org.elasticsearch.action.admin.indices.rollover.MaxPrimaryShardSizeCondition
- NAME - Static variable in class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- NAME - Static variable in class org.elasticsearch.action.admin.indices.rollover.RolloverAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.shrink.ResizeAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.shrink.ShrinkAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.stats.IndicesStatsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.delete.DeleteComponentTemplateAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.delete.DeleteComposableIndexTemplateAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Response
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Response
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsAction
- NAME - Static variable in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryAction
- NAME - Static variable in class org.elasticsearch.action.bulk.BulkAction
- NAME - Static variable in class org.elasticsearch.action.datastreams.ModifyDataStreamsAction
- NAME - Static variable in class org.elasticsearch.action.delete.DeleteAction
- NAME - Static variable in class org.elasticsearch.action.explain.ExplainAction
- NAME - Static variable in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesAction
- NAME - Static variable in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- NAME - Static variable in class org.elasticsearch.action.get.GetAction
- NAME - Static variable in class org.elasticsearch.action.get.MultiGetAction
- NAME - Static variable in class org.elasticsearch.action.index.IndexAction
- NAME - Static variable in class org.elasticsearch.action.ingest.DeletePipelineAction
- NAME - Static variable in class org.elasticsearch.action.ingest.GetPipelineAction
- NAME - Static variable in class org.elasticsearch.action.ingest.PutPipelineAction
- NAME - Static variable in class org.elasticsearch.action.ingest.SimulatePipelineAction
- NAME - Static variable in class org.elasticsearch.action.main.MainAction
- NAME - Static variable in class org.elasticsearch.action.search.ClearScrollAction
- NAME - Static variable in class org.elasticsearch.action.search.ClosePointInTimeAction
- NAME - Static variable in class org.elasticsearch.action.search.MultiSearchAction
- NAME - Static variable in class org.elasticsearch.action.search.OpenPointInTimeAction
- NAME - Static variable in class org.elasticsearch.action.search.SearchAction
- NAME - Static variable in class org.elasticsearch.action.search.SearchScrollAction
- NAME - Static variable in class org.elasticsearch.action.support.replication.ReplicationTask.Status
- NAME - Static variable in class org.elasticsearch.action.termvectors.MultiTermVectorsAction
- NAME - Static variable in class org.elasticsearch.action.termvectors.TermVectorsAction
- NAME - Static variable in class org.elasticsearch.action.update.UpdateAction
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.AwarenessAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ConcurrentRebalanceAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.MaxRetryAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.NodeReplacementAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.NodeVersionAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.RebalanceOnlyWhenActiveAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ResizeAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.RestoreInProgressAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.SameShardAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.SnapshotInProgressAllocationDecider
- NAME - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
- NAME - Static variable in class org.elasticsearch.index.mapper.AllFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.DocCountFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.IdFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.IdFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.IgnoredFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.IgnoredFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.IndexFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.RoutingFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.SourceFieldMapper.Defaults
- NAME - Static variable in class org.elasticsearch.index.mapper.SourceFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.TypeFieldMapper
- NAME - Static variable in class org.elasticsearch.index.mapper.TypeFieldType
- NAME - Static variable in class org.elasticsearch.index.mapper.VersionFieldMapper
- NAME - Static variable in class org.elasticsearch.index.query.BoolQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.BoostingQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- NAME - Static variable in class org.elasticsearch.index.query.ConstantScoreQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.DisMaxQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.DistanceFeatureQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.ExistsQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.FieldMaskingSpanQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.ExponentialDecayFunctionBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.FieldValueFactorFunctionBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.GaussDecayFunctionBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.functionscore.WeightBuilder
- NAME - Static variable in class org.elasticsearch.index.query.FuzzyQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.
- NAME - Static variable in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.IdsQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.IntervalQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.IntervalsSourceProvider.Combine
- NAME - Static variable in class org.elasticsearch.index.query.IntervalsSourceProvider.Disjunction
- NAME - Static variable in class org.elasticsearch.index.query.IntervalsSourceProvider.Fuzzy
- NAME - Static variable in class org.elasticsearch.index.query.IntervalsSourceProvider.IntervalFilter
- NAME - Static variable in class org.elasticsearch.index.query.IntervalsSourceProvider.Match
- NAME - Static variable in class org.elasticsearch.index.query.IntervalsSourceProvider.Prefix
- NAME - Static variable in class org.elasticsearch.index.query.IntervalsSourceProvider.Wildcard
- NAME - Static variable in class org.elasticsearch.index.query.MatchAllQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.MatchNoneQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
-
The name for the match query
- NAME - Static variable in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.NestedQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.PrefixQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.QueryStringQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.RegexpQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.ScriptQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Name for (de-)serialization.
- NAME - Static variable in class org.elasticsearch.index.query.SpanContainingQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanFirstQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanNearQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanNotQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanOrQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanTermQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.SpanWithinQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.TermQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.TermsQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.TermsSetQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.TypeQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.WildcardQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.query.WrapperQueryBuilder
- NAME - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- NAME - Static variable in class org.elasticsearch.index.reindex.DeleteByQueryAction
- NAME - Static variable in class org.elasticsearch.index.reindex.ReindexAction
- NAME - Static variable in class org.elasticsearch.index.reindex.UpdateByQueryAction
- NAME - Static variable in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- NAME - Static variable in class org.elasticsearch.persistent.CompletionPersistentTaskAction
- NAME - Static variable in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- NAME - Static variable in class org.elasticsearch.persistent.RemovePersistentTaskAction
- NAME - Static variable in class org.elasticsearch.persistent.StartPersistentTaskAction
- NAME - Static variable in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction
- NAME - Static variable in class org.elasticsearch.repositories.IndexId
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ChiSquare
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.GND
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.JLHScore
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.MutualInformation
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.PercentageScore
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.PercentileRanksAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.InternalBucketMetricValue
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.LinearModel
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.MaxBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.MinBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.SimpleModel
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.StatsBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.aggregations.pipeline.SumBucketPipelineAggregationBuilder
- NAME - Static variable in class org.elasticsearch.search.DocValueFormat.DateTime
- NAME - Static variable in class org.elasticsearch.search.DocValueFormat.Decimal
- NAME - Static variable in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- NAME - Static variable in class org.elasticsearch.search.sort.FieldSortBuilder
- NAME - Static variable in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- NAME - Static variable in class org.elasticsearch.search.sort.ScoreSortBuilder
- NAME - Static variable in class org.elasticsearch.search.sort.ScriptSortBuilder
- NAME - Static variable in class org.elasticsearch.search.sort.ShardDocSortField
- NAME - Static variable in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext
- NAME - Static variable in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
- NAME - Static variable in class org.elasticsearch.search.suggest.phrase.Laplace
- NAME - Static variable in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- NAME - Static variable in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- NAME - Static variable in class org.elasticsearch.search.suggest.Suggest
- NAME - Static variable in class org.elasticsearch.tasks.RawTaskStatus
- NAME_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- NAME_FIELD - Static variable in class org.elasticsearch.index.query.AbstractQueryBuilder
- NAME_FIELD - Static variable in class org.elasticsearch.index.query.InnerHitBuilder
- named(String) - Static method in class org.elasticsearch.common.inject.name.Names
-
Creates a
Named
annotation withname
as the value. - Named - Annotation Interface in org.elasticsearch.common.inject.name
-
Annotates named things.
- NAMED_STOP_WORDS - Static variable in class org.elasticsearch.index.analysis.Analysis
- NamedAnalyzer - Class in org.elasticsearch.index.analysis
-
Named analyzer is an analyzer wrapper around an actual analyzer (
NamedAnalyzer.analyzer
that is associated with a name (NamedAnalyzer.name()
. - NamedAnalyzer(String, AnalyzerScope, Analyzer) - Constructor for class org.elasticsearch.index.analysis.NamedAnalyzer
- NamedAnalyzer(String, AnalyzerScope, Analyzer, int) - Constructor for class org.elasticsearch.index.analysis.NamedAnalyzer
- NamedAnalyzer(NamedAnalyzer, int) - Constructor for class org.elasticsearch.index.analysis.NamedAnalyzer
- NamedDiff<T extends Diffable<T>> - Interface in org.elasticsearch.cluster
-
Diff that also support NamedWriteable interface
- NamedDiffable<T> - Interface in org.elasticsearch.cluster
-
Diff that also support
VersionedNamedWriteable
interface - NamedDiffableValueSerializer<T extends NamedDiffable<T>> - Class in org.elasticsearch.cluster
-
Value Serializer for named diffables
- NamedDiffableValueSerializer(Class<T>) - Constructor for class org.elasticsearch.cluster.NamedDiffableValueSerializer
- namedFilters() - Method in class org.elasticsearch.index.query.ParsedQuery
- NamedRegistry<T> - Class in org.elasticsearch.common
-
A registry from String to some class implementation.
- NamedRegistry(String) - Constructor for class org.elasticsearch.common.NamedRegistry
- NamedWriteable - Interface in org.elasticsearch.common.io.stream
-
A
Writeable
object identified by its name. - NamedWriteableAwareStreamInput - Class in org.elasticsearch.common.io.stream
-
Wraps a
StreamInput
and associates it with aNamedWriteableRegistry
- NamedWriteableAwareStreamInput(StreamInput, NamedWriteableRegistry) - Constructor for class org.elasticsearch.common.io.stream.NamedWriteableAwareStreamInput
- namedWriteableRegistry - Variable in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- namedWriteableRegistry() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- namedWriteableRegistry() - Method in class org.elasticsearch.common.io.stream.NamedWriteableAwareStreamInput
- namedWriteableRegistry() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Get the registry of named writeables if this stream has one,
null
otherwise. - NamedWriteableRegistry - Class in org.elasticsearch.common.io.stream
-
A registry for
Writeable.Reader
readers ofNamedWriteable
. - NamedWriteableRegistry(List<NamedWriteableRegistry.Entry>) - Constructor for class org.elasticsearch.common.io.stream.NamedWriteableRegistry
-
Constructs a new registry from the given entries.
- NamedWriteableRegistry.Entry - Class in org.elasticsearch.common.io.stream
-
An entry in the registry, made up of a category class and name, and a reader for that category class.
- namedWriteables() - Static method in class org.elasticsearch.search.sort.SortValue
-
Get the list of NamedWriteables that this class needs.
- NamedXContentProvider - Interface in org.elasticsearch.plugins.spi
-
Provides named XContent parsers.
- namedXContentRegistry - Static variable in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- NameOrDefinition - Class in org.elasticsearch.index.analysis
- NameOrDefinition(String) - Constructor for class org.elasticsearch.index.analysis.NameOrDefinition
- NameOrDefinition(Map<String, ?>) - Constructor for class org.elasticsearch.index.analysis.NameOrDefinition
- NameOrDefinition(StreamInput) - Constructor for class org.elasticsearch.index.analysis.NameOrDefinition
- nameResolvedInstant(long) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
At what point in time the provided name was resolved into the index name
- names() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- names() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteComponentTemplateAction.Request
-
The index template names to delete.
- names() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteComposableIndexTemplateAction.Request
-
The index template names to delete.
- names() - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
-
The names of the index templates.
- names() - Method in class org.elasticsearch.common.settings.Settings
- names(String...) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- Names - Class in org.elasticsearch.common.inject.name
-
Utility methods for use with
@
Named
. - Names() - Constructor for class org.elasticsearch.index.mapper.FieldAliasMapper.Names
- Names() - Constructor for class org.elasticsearch.threadpool.ThreadPool.Names
- NANOS_PARSER - Static variable in class org.elasticsearch.index.mapper.DateFieldMapper
- NANOSECONDS - Enum constant in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
- nativeControllerPath(Path) - Static method in class org.elasticsearch.plugins.Platforms
-
The path to the native controller for a plugin with native components.
- NAUTICALMILES - Enum constant in enum class org.elasticsearch.common.unit.DistanceUnit
- NEAR - Enum constant in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- needs_score() - Method in interface org.elasticsearch.script.AggregationScript.LeafFactory
-
Return
true
if the script needs_score
calculated, orfalse
otherwise. - needs_score() - Method in interface org.elasticsearch.script.NumberSortScript.LeafFactory
-
Return
true
if the script needs_score
calculated, orfalse
otherwise. - needs_score() - Method in interface org.elasticsearch.script.ScoreScript.LeafFactory
-
Return
true
if the script needs_score
calculated, orfalse
otherwise. - needsField(FieldInfo) - Method in class org.elasticsearch.index.fieldvisitor.CustomFieldsVisitor
- needsField(FieldInfo) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- needsField(FieldInfo) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- needsField(FieldInfo) - Method in class org.elasticsearch.search.internal.FilterFieldNamesProvidingStoredFieldsVisitor
- needsField(FieldInfo) - Method in class org.elasticsearch.search.internal.FilterStoredFieldVisitor
- needsReassignment(PersistentTasksCustomMetadata.Assignment, DiscoveryNodes) - Static method in class org.elasticsearch.persistent.PersistentTasksClusterService
-
Returns true if the task is not assigned or is assigned to a non-existing node
- needsRefresh() - Method in class org.elasticsearch.common.util.SingleObjectCache
-
Returns
true
iff the cache needs to be refreshed. - needsScores() - Method in class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction
- needsScores() - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.FilterScoreFunction
- needsScores() - Method in class org.elasticsearch.common.lucene.search.function.RandomScoreFunction
- needsScores() - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
-
Indicates if document scores are needed by this function.
- needsScores() - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
- needsScores() - Method in class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- needsScores() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator.CollectorSource
-
Does this
MapStringTermsAggregator.CollectorSource
need queries to calculate the score? - needsScores() - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator.ValuesSourceCollectorSource
- needsScores() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSource
- needsScores() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.Script
- needsScores() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithScript
- needsScores() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource
-
Whether this values source needs scores.
- needsScores() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
- needsScores() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
- needsScores() - Method in class org.elasticsearch.search.sort.BucketedSort.ForDoubles
- needsScores() - Method in class org.elasticsearch.search.sort.BucketedSort.ForLongs
- needsScores() - Method in class org.elasticsearch.search.sort.BucketedSort
-
Does this sort need scores? Most don't, but sorting on
_score
does. - negativeBoost() - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
-
Get the negative boost factor.
- negativeBoost(float) - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
-
Set the negative boost factor.
- negativeQuery() - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
-
Get the negative query for this boosting query.
- negLeft - Variable in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- negRight - Variable in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- neighboringModel() - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- neighboringModel() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
- neighboringModel() - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- neighboringModel() - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel
- neighboringModel() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
-
Generates a "neighboring" model, where one of the tunable parameters has been randomly mutated within the allowed range.
- neighboringModel() - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel
- nested - Variable in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- nested() - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- nested(String, String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Nested
aggregation with the given name. - Nested - Interface in org.elasticsearch.search.aggregations.bucket.nested
-
A
nested
aggregation. - Nested(BitSetProducer, Query, NestedSortBuilder, IndexSearcher) - Constructor for class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
- NESTED_FIELD - Static variable in class org.elasticsearch.search.sort.NestedSortBuilder
- NESTED_FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.IdFieldMapper.Defaults
- NESTED_FIELD_TYPE - Static variable in class org.elasticsearch.index.mapper.TypeFieldMapper.Defaults
- NESTED_FILTER_FIELD - Static variable in class org.elasticsearch.search.sort.SortBuilder
- NESTED_PATH_FIELD - Static variable in class org.elasticsearch.search.sort.SortBuilder
- NestedAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.nested
- NestedAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- NestedAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
-
Read from a stream.
- NestedAggregationBuilder(NestedAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- NestedAggregator - Class in org.elasticsearch.search.aggregations.bucket.nested
- NestedAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.nested
- NestedDocuments - Class in org.elasticsearch.search
-
Manages loading information about nested documents
- NestedDocuments(MappingLookup, Version, Function<Query, BitSetProducer>) - Constructor for class org.elasticsearch.search.NestedDocuments
-
Create a new NestedDocuments object for an index
- NestedHelper - Class in org.elasticsearch.index.search
-
Utility class to filter parent and children clauses when building nested queries.
- NestedHelper(Function<String, ObjectMapper>, Predicate<String>) - Constructor for class org.elasticsearch.index.search.NestedHelper
- nestedIdentity() - Method in interface org.elasticsearch.search.LeafNestedDocuments
-
The NestedIdentity of the current doc
- NestedIdentity(String, int, SearchHit.NestedIdentity) - Constructor for class org.elasticsearch.search.SearchHit.NestedIdentity
- nestedMappings() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- NestedObjectMapper - Class in org.elasticsearch.index.mapper
-
A Mapper for nested objects
- NestedObjectMapper.Builder - Class in org.elasticsearch.index.mapper
- NestedObjectMapper.TypeParser - Class in org.elasticsearch.index.mapper
- nestedQuery(String, QueryBuilder, ScoreMode) - Static method in class org.elasticsearch.index.query.QueryBuilders
- NestedQueryBuilder - Class in org.elasticsearch.index.query
- NestedQueryBuilder(String, QueryBuilder, ScoreMode) - Constructor for class org.elasticsearch.index.query.NestedQueryBuilder
- NestedQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.NestedQueryBuilder
-
Read from a stream.
- nestedScope() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- nestedScope() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Access the nested scope.
- nestedScope() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- NestedScope - Class in org.elasticsearch.index.query.support
-
During query parsing this keeps track of the current nested level.
- NestedScope() - Constructor for class org.elasticsearch.index.query.support.NestedScope
- NestedSortBuilder - Class in org.elasticsearch.search.sort
- NestedSortBuilder(String) - Constructor for class org.elasticsearch.search.sort.NestedSortBuilder
- NestedSortBuilder(StreamInput) - Constructor for class org.elasticsearch.search.sort.NestedSortBuilder
- nestedTypeFilter() - Method in class org.elasticsearch.index.mapper.NestedObjectMapper
- nestedTypePath() - Method in class org.elasticsearch.index.mapper.NestedObjectMapper
- NestedValueFetcher - Class in org.elasticsearch.index.mapper
- NestedValueFetcher(String, FieldFetcher) - Constructor for class org.elasticsearch.index.mapper.NestedValueFetcher
- netNewSystemIndexAccessException(ThreadContext, Collection<String>) - Method in class org.elasticsearch.indices.SystemIndices
- NETWORK_SERVER - Static variable in class org.elasticsearch.common.network.NetworkService
- NetworkAddress - Class in org.elasticsearch.common.network
-
Utility functions for presentation of network addresses.
- NetworkExceptionHelper - Class in org.elasticsearch.common.transport
- NetworkExceptionHelper() - Constructor for class org.elasticsearch.common.transport.NetworkExceptionHelper
- NetworkMessage - Class in org.elasticsearch.transport
-
Represents a transport message sent over the network.
- NetworkModule - Class in org.elasticsearch.common.network
-
A module to handle registering and binding all network related classes.
- NetworkModule(Settings, boolean, List<NetworkPlugin>, ThreadPool, BigArrays, PageCacheRecycler, CircuitBreakerService, NamedWriteableRegistry, NamedXContentRegistry, NetworkService, HttpServerTransport.Dispatcher, ClusterSettings) - Constructor for class org.elasticsearch.common.network.NetworkModule
-
Creates a network module that custom networking classes can be plugged into.
- NetworkPlugin - Interface in org.elasticsearch.plugins
-
Plugin for extending network and transport related classes
- networkService - Variable in class org.elasticsearch.http.AbstractHttpServerTransport
- networkService - Variable in class org.elasticsearch.transport.TcpTransport
- NetworkService - Class in org.elasticsearch.common.network
- NetworkService(List<NetworkService.CustomNameResolver>) - Constructor for class org.elasticsearch.common.network.NetworkService
- NetworkService.CustomNameResolver - Interface in org.elasticsearch.common.network
-
A custom name resolver can support custom lookup keys (my_net_key:ipv4) and also change the default inet address used in case no settings is provided.
- NetworkTraceFlag - Class in org.elasticsearch.transport
- NetworkUtils - Class in org.elasticsearch.common.network
-
Utilities for network interfaces / addresses binding and publishing.
- neverSerialize() - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Never serialize this parameter, no matter its value
- NEW_FEATURES_VERSION - Static variable in class org.elasticsearch.cluster.metadata.DataStream
-
The version when data stream metadata, hidden and replicated data streams, and dates in backing index names was introduced.
- NEW_INDEX_RESTORED - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of restoring into a new index.
- NEW_PRIMARIES - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
- NEW_SHARD_GEN - Static variable in class org.elasticsearch.repositories.ShardGenerations
-
Special generation that signifies that a shard is new and the repository does not yet contain a valid
BlobStoreIndexShardSnapshots
blob for it. - newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilter
- newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.global.InternalGlobal
- newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
-
Create a new empty sub aggregation.
- newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.missing.InternalMissing
- newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.nested.InternalNested
- newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.nested.InternalReverseNested
- newAggregation(String, long, InternalAggregations) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
- newAliasMetadata(AliasMetadata, String) - Static method in class org.elasticsearch.cluster.metadata.AliasMetadata
-
Creates a new AliasMetadata instance with same content as the given one, but with a different alias name
- newAliasMetadataBuilder(String) - Static method in class org.elasticsearch.cluster.metadata.AliasMetadata
- newAutoQueueFixed(String, int, int, int, int, int, TimeValue, ThreadFactory, ThreadContext) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
-
Return a new executor that will automatically adjust the queue size based on queue throughput.
- newBecomeMasterTask() - Static method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor
- newBlockingQueue() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.BinaryScriptFieldData
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.GeoPointScriptFieldData
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
-
Build a sort implementation specialized for aggregations.
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.IndexNumericFieldData
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData.Consumer
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointIndexFieldData
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.plain.StringBinaryIndexFieldData
- newBucketedSort(BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldData
- newBucketedSort(BigArrays, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
- newBucketedSort(BigArrays, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.DoubleValuesComparatorSource
- newBucketedSort(BigArrays, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.FloatValuesComparatorSource
- newBucketedSort(BigArrays, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.LongValuesComparatorSource
- newBucketedSort(BigArrays, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
-
Create a BucketedSort which is useful for sorting inside of aggregations.
- newBucketedSort(IndexNumericFieldData.NumericType, BigArrays, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, SortOrder, DocValueFormat, int, BucketedSort.ExtraData) - Method in class org.elasticsearch.index.fielddata.IndexNumericFieldData
-
Builds a BucketedSort for the
targetNumericType
, casting the values if their native type doesn't match. - newBuilder() - Static method in class org.elasticsearch.common.logging.ESJsonLayout
- newBuilder() - Method in class org.elasticsearch.rest.AbstractRestChannel
- newBuilder() - Method in interface org.elasticsearch.rest.RestChannel
- newBuilder(XContentType, boolean) - Method in class org.elasticsearch.rest.AbstractRestChannel
-
Creates a new
XContentBuilder
for a response to be sent using this channel. - newBuilder(XContentType, boolean) - Method in interface org.elasticsearch.rest.RestChannel
- newBuilder(XContentType, XContentType, boolean) - Method in class org.elasticsearch.rest.AbstractRestChannel
-
Creates a new
XContentBuilder
for a response to be sent using this channel. - newBuilder(XContentType, XContentType, boolean) - Method in interface org.elasticsearch.rest.RestChannel
- newByteArray(long) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
ByteArray
initialized with zeros. - newByteArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
ByteArray
. - newBytesOutput() - Method in class org.elasticsearch.http.DefaultRestChannel
- newBytesOutput() - Method in class org.elasticsearch.rest.AbstractRestChannel
- newChangesSnapshot(String, long, long, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
-
Creates a new changes snapshot for reading operations whose seq_no are between
fromSeqNo
(inclusive) andtoSeqNo
(inclusive). - newChangesSnapshot(String, MapperService, long, long, boolean) - Method in class org.elasticsearch.index.engine.Engine
-
Creates a new history snapshot from Lucene for reading operations whose seqno in the requesting seqno range (both inclusive).
- newChangesSnapshot(String, MapperService, long, long, boolean) - Method in class org.elasticsearch.index.engine.InternalEngine
- newChangesSnapshot(String, MapperService, long, long, boolean) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- newClusterInfoService(Settings, ClusterService, ThreadPool, NodeClient) - Method in class org.elasticsearch.node.Node
-
Constructs a ClusterInfoService which may be mocked for tests.
- newComparator(String, int, int, boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
- newComparator(String, int, int, boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.DoubleValuesComparatorSource
- newComparator(String, int, int, boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.FloatValuesComparatorSource
- newComparator(String, int, int, boolean) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.LongValuesComparatorSource
- newConcurrentHashSet() - Static method in class org.elasticsearch.common.util.set.Sets
- newConcurrentMap() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
- newConcurrentMapWithAggressiveConcurrency() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
-
Creates a new CHM with an aggressive concurrency level, aimed at high concurrent update rate long living maps.
- newConcurrentMapWithAggressiveConcurrency(int) - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
-
Creates a new CHM with an aggressive concurrency level, aimed at high concurrent update rate long living maps.
- newConcurrentSet() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
- newCondition() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
- newConfigurationException(String, String, String, Exception) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- newConfigurationException(String, String, String, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- newConsumer(DirectoryReader) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- newDefaultQuery(String) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser
- newDeque() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
- newDirectory(Path) - Method in class org.elasticsearch.gateway.MetadataStateFormat
- newDirectory(IndexSettings, ShardPath) - Method in class org.elasticsearch.index.store.FsDirectoryFactory
- newDirectory(IndexSettings, ShardPath) - Method in interface org.elasticsearch.plugins.IndexStorePlugin.DirectoryFactory
-
Creates a new directory per shard.
- newDone(long, long, int, int, long, long, ShardGeneration) - Static method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- newDoubleArray(long) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
DoubleArray
of the given capacity. - newDoubleArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
DoubleArray
. - newEntry(StreamInput) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- newEntry(StreamInput) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
- newEntry(StreamInput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- newEntry(StreamInput) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- newErrorBuilder() - Method in class org.elasticsearch.rest.AbstractRestChannel
- newErrorBuilder() - Method in interface org.elasticsearch.rest.RestChannel
- newFactory(String, Supplier<Tokenizer>) - Static method in interface org.elasticsearch.index.analysis.TokenizerFactory
- newFactory(String, Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.BooleanFieldScript.Factory
- newFactory(String, Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.CompositeFieldScript.Factory
- newFactory(String, Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.DoubleFieldScript.Factory
- newFactory(String, Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.GeoPointFieldScript.Factory
- newFactory(String, Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.IpFieldScript.Factory
- newFactory(String, Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.LongFieldScript.Factory
- newFactory(String, Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.StringFieldScript.Factory
- newFactory(String, Map<String, Object>, SearchLookup, DateFormatter) - Method in interface org.elasticsearch.script.DateFieldScript.Factory
- newFactory(Map<String, Object>) - Method in interface org.elasticsearch.script.StringSortScript.Factory
- newFactory(Map<String, Object>, Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.ScriptedMetricAggContexts.MapScript.Factory
- newFactory(Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.AggregationScript.Factory
- newFactory(Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.FieldScript.Factory
- newFactory(Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.FilterScript.Factory
- newFactory(Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.NumberSortScript.Factory
- newFactory(Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.ScoreScript.Factory
- newFactory(Map<String, Object>, SearchLookup) - Method in interface org.elasticsearch.script.TermsSetQueryScript.Factory
- newFailed(String) - Static method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- newFilter() - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractRareTermsAggregator
- newFilter(SearchExecutionContext, String, boolean) - Static method in class org.elasticsearch.index.query.ExistsQueryBuilder
- newFinishElectionTask() - Static method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor
-
a task that is used to signal the election is stopped and we should process pending joins.
- newFixed(String, int, int, ThreadFactory, ThreadContext) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- newFloatArray(long) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
FloatArray
of the given capacity. - newFloatArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
FloatArray
. - newFSDirectory(Path, LockFactory, IndexSettings) - Method in class org.elasticsearch.index.store.FsDirectoryFactory
- newFuture() - Static method in class org.elasticsearch.action.support.PlainActionFuture
- newFuzzyQuery(String, int) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser
- newFuzzyQuery(Term, float, int) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- newGeneration() - Static method in class org.elasticsearch.repositories.ShardGeneration
- newGeneration(Random) - Static method in class org.elasticsearch.repositories.ShardGeneration
- newHashPublisher() - Method in class org.elasticsearch.common.settings.ConsistentSettingsService
-
Returns a
LocalNodeMasterListener
that will publish hashes of all the settings passed in the constructor. - newHashSet(Iterable<T>) - Static method in class org.elasticsearch.common.util.set.Sets
- newHashSet(Iterator<T>) - Static method in class org.elasticsearch.common.util.set.Sets
- newHashSet(T...) - Static method in class org.elasticsearch.common.util.set.Sets
- newHttpTransport(NetworkModule) - Method in class org.elasticsearch.node.Node
-
Constructs a
HttpServerTransport
which may be mocked for tests. - newIndexMapperService(NamedXContentRegistry, MapperRegistry, ScriptService) - Method in class org.elasticsearch.index.IndexModule
-
creates a new mapper service to do administrative work like mapping updates.
- newIndexService(IndexService.IndexCreationContext, NodeEnvironment, NamedXContentRegistry, IndexService.ShardStoreDeleter, CircuitBreakerService, BigArrays, ThreadPool, ScriptService, ClusterService, Client, IndicesQueryCache, MapperRegistry, IndicesFieldDataCache, NamedWriteableRegistry, BooleanSupplier, ValuesSourceRegistry, IndexStorePlugin.IndexFoldersDeletionListener, Map<String, IndexStorePlugin.SnapshotCommitSupplier>) - Method in class org.elasticsearch.index.IndexModule
- newInitializing() - Static method in class org.elasticsearch.cluster.routing.AllocationId
-
Creates a new allocation id for initializing allocation.
- newInitializing(String) - Static method in class org.elasticsearch.cluster.routing.AllocationId
-
Creates a new allocation id for initializing allocation based on an existing id.
- newInitializing(ShardGeneration) - Static method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus
- newInstance() - Method in class org.elasticsearch.common.recycler.AbstractRecyclerC
- newInstance() - Method in interface org.elasticsearch.common.recycler.Recycler.C
-
Create a new empty instance of the given size.
- newInstance() - Method in interface org.elasticsearch.index.query.IntervalFilterScript.Factory
- newInstance() - Method in interface org.elasticsearch.script.SignificantTermsHeuristicScoreScript.Factory
- newInstance() - Method in interface org.elasticsearch.script.SimilarityScript.Factory
- newInstance() - Method in interface org.elasticsearch.script.SimilarityWeightScript.Factory
- newInstance() - Method in interface org.elasticsearch.search.aggregations.pipeline.MovingFunctionScript.Factory
- newInstance(String[]) - Static method in class org.elasticsearch.common.logging.ClusterIdConverter
-
Called by log4j2 to initialize this converter.
- newInstance(String[]) - Static method in class org.elasticsearch.common.logging.NodeAndClusterIdConverter
-
Called by log4j2 to initialize this converter.
- newInstance(String[]) - Static method in class org.elasticsearch.common.logging.NodeIdConverter
-
Called by log4j2 to initialize this converter.
- newInstance(String[]) - Static method in class org.elasticsearch.common.logging.NodeNamePatternConverter
-
Called by log4j2 to initialize this converter.
- newInstance(String[]) - Static method in class org.elasticsearch.common.logging.ProductOriginConverter
-
Called by log4j2 to initialize this converter.
- newInstance(String[]) - Static method in class org.elasticsearch.common.logging.TraceIdConverter
-
Called by log4j2 to initialize this converter.
- newInstance(Map<String, Object>) - Method in interface org.elasticsearch.script.BucketAggregationScript.Factory
- newInstance(Map<String, Object>) - Method in interface org.elasticsearch.script.BucketAggregationSelectorScript.Factory
- newInstance(Map<String, Object>) - Method in interface org.elasticsearch.script.IngestConditionalScript.Factory
- newInstance(Map<String, Object>) - Method in interface org.elasticsearch.script.IngestScript.Factory
- newInstance(Map<String, Object>) - Method in interface org.elasticsearch.script.TemplateScript.Factory
- newInstance(Map<String, Object>, List<Object>) - Method in interface org.elasticsearch.script.ScriptedMetricAggContexts.ReduceScript.Factory
- newInstance(Map<String, Object>, Map<String, Object>) - Method in interface org.elasticsearch.script.ScriptedMetricAggContexts.CombineScript.Factory
- newInstance(Map<String, Object>, Map<String, Object>) - Method in interface org.elasticsearch.script.ScriptedMetricAggContexts.InitScript.Factory
- newInstance(Map<String, Object>, Map<String, Object>) - Method in interface org.elasticsearch.script.UpdateScript.Factory
- newInstance(Configuration, String[]) - Static method in class org.elasticsearch.common.logging.ESMessageFieldConverter
-
Called by log4j2 to initialize this converter.
- newInstance(Configuration, String[]) - Static method in class org.elasticsearch.common.logging.JsonThrowablePatternConverter
-
Gets an instance of the class.
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.AggregationScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.BooleanFieldScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.CompositeFieldScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.DateFieldScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.DoubleFieldScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.FieldScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.GeoPointFieldScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.IpFieldScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.LongFieldScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.ScriptedMetricAggContexts.MapScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.StringFieldScript.LeafFactory
- newInstance(LeafReaderContext) - Method in interface org.elasticsearch.script.TermsSetQueryScript.LeafFactory
- newInstance(DocReader) - Method in interface org.elasticsearch.script.FilterScript.LeafFactory
- newInstance(DocReader) - Method in interface org.elasticsearch.script.NumberSortScript.LeafFactory
- newInstance(DocReader) - Method in interface org.elasticsearch.script.ScoreScript.LeafFactory
- newInstance(DocReader) - Method in interface org.elasticsearch.script.StringSortScript.LeafFactory
- newIntArray(long) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
IntArray
. - newIntArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
IntArray
. - newIntersectsQuery(String, byte[]) - Static method in class org.apache.lucene.document.BinaryRange
-
Create a query for matching indexed ip ranges that
INTERSECT
the defined range. - newLenientFieldQuery(String, RuntimeException) - Static method in class org.elasticsearch.common.lucene.search.Queries
- newLongArray(long) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
LongArray
. - newLongArray(long, boolean) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
LongArray
. - newMap(int) - Static method in class org.elasticsearch.common.collect.HppcMaps
-
Returns a new map with the given number of expected elements.
- newMapBinder(Binder, Class<K>, Class<V>) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a new mapbinder that collects entries of
keyType
/valueType
in aMap
that is itself bound with no binding annotation. - newMapBinder(Binder, Class<K>, Class<V>, Annotation) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a new mapbinder that collects entries of
keyType
/valueType
in aMap
that is itself bound withannotation
. - newMapBinder(Binder, Class<K>, Class<V>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a new mapbinder that collects entries of
keyType
/valueType
in aMap
that is itself bound withannotationType
. - newMapBinder(Binder, TypeLiteral<K>, TypeLiteral<V>) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a new mapbinder that collects entries of
keyType
/valueType
in aMap
that is itself bound with no binding annotation. - newMapBinder(Binder, TypeLiteral<K>, TypeLiteral<V>, Annotation) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a new mapbinder that collects entries of
keyType
/valueType
in aMap
that is itself bound withannotation
. - newMapBinder(Binder, TypeLiteral<K>, TypeLiteral<V>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.multibindings.MapBinder
-
Returns a new mapbinder that collects entries of
keyType
/valueType
in aMap
that is itself bound withannotationType
. - newMapBuilder() - Static method in class org.elasticsearch.common.collect.MapBuilder
- newMapBuilder(Map<K, V>) - Static method in class org.elasticsearch.common.collect.MapBuilder
- newMasterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- newMatchAllDocsQuery() - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- newMatchAllQuery() - Static method in class org.elasticsearch.common.lucene.search.Queries
- newMatchNoDocsQuery(String) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
Return a query that matches no document.
- newNestedFilter() - Static method in class org.elasticsearch.common.lucene.search.Queries
- newNode(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
- newNodeRequest(NodesRequest) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
- newNodeRequest(NodesHotThreadsRequest) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
- newNodeRequest(NodesInfoRequest) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
- newNodeRequest(NodesReloadSecureSettingsRequest) - Method in class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction
- newNodeRequest(NodesStatsRequest) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
- newNodeRequest(NodesUsageRequest) - Method in class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction
- newNodeRequest(TransportNodesSnapshotsStatus.Request) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- newNodeRequest(ClusterStatsRequest) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
- newNodeRequest(FindDanglingIndexRequest) - Method in class org.elasticsearch.action.admin.indices.dangling.find.TransportFindDanglingIndexAction
- newNodeRequest(ListDanglingIndicesRequest) - Method in class org.elasticsearch.action.admin.indices.dangling.list.TransportListDanglingIndicesAction
- newNodeRequest(TransportNodesListGatewayMetaState.Request) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- newNodeRequest(TransportNodesListGatewayStartedShards.Request) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- newNodeRequest(TransportNodesListShardStoreMetadata.Request) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata
- newNodeResponse(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
- newNodeResponse(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
- newNodeResponse(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction
- newNodeResponse(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
- newNodeResponse(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction
- newNodeResponse(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- newNodeResponse(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
- newNodeResponse(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.action.admin.indices.dangling.find.TransportFindDanglingIndexAction
- newNodeResponse(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.action.admin.indices.dangling.list.TransportListDanglingIndicesAction
- newNodeResponse(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
- newNodeResponse(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- newNodeResponse(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- newNodeResponse(StreamInput, DiscoveryNode) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata
- newNonNestedFilter(Version) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
Creates a new non-nested docs query
- newNoNullKeysMap() - Static method in class org.elasticsearch.common.collect.HppcMaps
-
Returns a map like
HppcMaps.newMap(int)
that does not acceptnull
keys - newNoNullKeysMap(int) - Static method in class org.elasticsearch.common.collect.HppcMaps
-
Returns a map like
HppcMaps.newMap(int)
that does not acceptnull
keys - newObjectArray(long) - Method in class org.elasticsearch.common.util.BigArrays
-
Allocate a new
ObjectArray
. - newOption(StreamInput) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry
- newOption(StreamInput) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- newOption(StreamInput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- newOption(StreamInput) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry
- newParameterizedType(Type, Type...) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a new parameterized type, applying
typeArguments
torawType
. - newParameterizedTypeWithOwner(Type, Type, Type...) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a new parameterized type, applying
typeArguments
torawType
and enclosed byownerType
. - newPermissionCollection() - Method in class org.elasticsearch.script.ClassPermission
- newPhraseQuery(String, int) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser
- newPrefixQuery(String) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser
- newPrivateBinder() - Method in interface org.elasticsearch.common.inject.Binder
-
Creates a new private child environment for bindings and other configuration.
- newPublicationContext(ClusterStatePublicationEvent) - Method in class org.elasticsearch.cluster.coordination.PublicationTransportHandler
- newQueue() - Static method in class org.elasticsearch.common.util.concurrent.ConcurrentCollections
- newReadWriteEngine(EngineConfig) - Method in interface org.elasticsearch.index.engine.EngineFactory
- newReadWriteEngine(EngineConfig) - Method in class org.elasticsearch.index.engine.InternalEngineFactory
- newRecoveryState(ShardRouting, DiscoveryNode, DiscoveryNode) - Method in interface org.elasticsearch.plugins.IndexStorePlugin.RecoveryStateFactory
-
Creates a new
RecoveryState
per shard. - newRejectedException(Runnable, ThreadPoolExecutor, boolean) - Method in class org.elasticsearch.common.util.concurrent.EsRejectedExecutionHandler
- newRelocation(AllocationId) - Static method in class org.elasticsearch.cluster.routing.AllocationId
-
Creates a new allocation id for a shard that moves to be relocated, populating the transient holder for relocationId.
- newReplicasProxy() - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- newReplicasProxy() - Method in class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction
- newReplicasProxy() - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- newReplicasProxy() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- newReplicasProxy() - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- newRequest(StreamInput) - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- newResponse(boolean) - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- newResponse(int, int, int, List<DefaultShardOperationFailedException>) - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
- newResponse(int, int, int, List<DefaultShardOperationFailedException>) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
- newResponse(int, int, int, List<DefaultShardOperationFailedException>) - Method in class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- newResponse(NodesRequest, List<NodeResponse>, List<FailedNodeException>) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
Create a new
TransportNodesAction
(multi-node response). - newResponse(NodesHotThreadsRequest, List<NodeHotThreads>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
- newResponse(NodesInfoRequest, List<NodeInfo>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
- newResponse(NodesReloadSecureSettingsRequest, List<NodesReloadSecureSettingsResponse.NodeResponse>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction
- newResponse(NodesStatsRequest, List<NodeStats>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
- newResponse(CancelTasksRequest, List<TaskInfo>, List<TaskOperationFailure>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.TransportCancelTasksAction
- newResponse(ListTasksRequest, List<TaskInfo>, List<TaskOperationFailure>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
- newResponse(NodesUsageRequest, List<NodeUsage>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction
- newResponse(TransportNodesSnapshotsStatus.Request, List<TransportNodesSnapshotsStatus.NodeSnapshotStatus>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- newResponse(ClusterStatsRequest, List<ClusterStatsNodeResponse>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
- newResponse(ClearIndicesCacheRequest, int, int, int, List<TransportBroadcastByNodeAction.EmptyResult>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
- newResponse(FindDanglingIndexRequest, List<NodeFindDanglingIndexResponse>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.indices.dangling.find.TransportFindDanglingIndexAction
- newResponse(ListDanglingIndicesRequest, List<NodeListDanglingIndicesResponse>, List<FailedNodeException>) - Method in class org.elasticsearch.action.admin.indices.dangling.list.TransportListDanglingIndicesAction
- newResponse(AnalyzeIndexDiskUsageRequest, AtomicReferenceArray<?>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.diskusage.TransportAnalyzeIndexDiskUsageAction
- newResponse(ForceMergeRequest, int, int, int, List<TransportBroadcastByNodeAction.EmptyResult>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
- newResponse(RecoveryRequest, int, int, int, List<RecoveryState>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- newResponse(IndicesSegmentsRequest, int, int, int, List<ShardSegments>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
- newResponse(FieldUsageStatsRequest, int, int, int, List<FieldUsageShardResponse>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.stats.TransportFieldUsageAction
- newResponse(IndicesStatsRequest, int, int, int, List<ShardStats>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
- newResponse(UpgradeStatusRequest, int, int, int, List<ShardUpgradeStatus>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
- newResponse(UpgradeRequest, int, int, int, List<ShardUpgradeResult>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
- newResponse(ValidateQueryRequest, AtomicReferenceArray<?>, ClusterState) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- newResponse(StreamInput) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- newResponse(StreamInput) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- newResponse(TransportNodesListGatewayMetaState.Request, List<TransportNodesListGatewayMetaState.NodeGatewayMetaState>, List<FailedNodeException>) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- newResponse(TransportNodesListGatewayStartedShards.Request, List<TransportNodesListGatewayStartedShards.NodeGatewayStartedShards>, List<FailedNodeException>) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- newResponse(TransportNodesListShardStoreMetadata.Request, List<TransportNodesListShardStoreMetadata.NodeStoreFilesMetadata>, List<FailedNodeException>) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata
- newResponse(Request, int, int, int, List<ShardOperationResult>, List<DefaultShardOperationFailedException>, ClusterState) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Creates a new response to the underlying request.
- newResponse(Request, AtomicReferenceArray<?>, ClusterState) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- newResponse(TasksRequest, AtomicReferenceArray<?>) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- newResponse(TasksRequest, List<TaskResponse>, List<TaskOperationFailure>, List<FailedNodeException>) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- newResponseAsync(Task, NodesRequest, List<NodeResponse>, List<FailedNodeException>, ActionListener<NodesResponse>) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
Create a new
TransportNodesAction
, possibly asynchronously. - newResponseAsync(Task, ClusterStatsRequest, List<ClusterStatsNodeResponse>, List<FailedNodeException>, ActionListener<ClusterStatsResponse>) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
- newResponseInstance(StreamInput) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- newResponseInstance(StreamInput) - Method in class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
- newResponseInstance(StreamInput) - Method in class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction
- newResponseInstance(StreamInput) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
- newResponseInstance(StreamInput) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- newResponseInstance(StreamInput) - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- newResponseInstance(StreamInput) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- newResponseInstance(StreamInput) - Method in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- newResponseInstance(StreamInput) - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- newResponseInstance(StreamInput) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- newRestorableContext(boolean) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Returns a supplier that gathers a
ThreadContext.newStoredContext(boolean)
and restores it once the returned supplier is invoked. - newScaling(String, int, int, long, TimeUnit, boolean, ThreadFactory, ThreadContext) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- newScorer(IndexReader, Terms, String, double, BytesRef) - Method in interface org.elasticsearch.search.suggest.phrase.WordScorer.WordScorerFactory
- newScriptService(Settings, Map<String, ScriptEngine>, Map<String, ScriptContext<?>>) - Method in class org.elasticsearch.node.Node
-
Creates a new the ScriptService.
- newSearchExecutionContext(int, int, IndexSearcher, LongSupplier, String, Map<String, Object>) - Method in class org.elasticsearch.index.IndexService
-
Creates a new QueryShardContext.
- newSearchService(ClusterService, IndicesService, ThreadPool, ScriptService, BigArrays, FetchPhase, ResponseCollectorService, CircuitBreakerService, ExecutorSelector) - Method in class org.elasticsearch.node.Node
-
Creates a new the SearchService.
- newSetBinder(Binder, Class<T>) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a new multibinder that collects instances of
type
in aSet
that is itself bound with no binding annotation. - newSetBinder(Binder, Class<T>, Annotation) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a new multibinder that collects instances of
type
in aSet
that is itself bound withannotation
. - newSetBinder(Binder, Class<T>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a new multibinder that collects instances of
type
in aSet
that is itself bound withannotationType
. - newSetBinder(Binder, TypeLiteral<T>) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a new multibinder that collects instances of
type
in aSet
that is itself bound with no binding annotation. - newSetBinder(Binder, TypeLiteral<T>, Annotation) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a new multibinder that collects instances of
type
in aSet
that is itself bound withannotation
. - newSetBinder(Binder, TypeLiteral<T>, Class<? extends Annotation>) - Static method in class org.elasticsearch.common.inject.multibindings.Multibinder
-
Returns a new multibinder that collects instances of
type
in aSet
that is itself bound withannotationType
. - newShapeQueryBuilder(String, Supplier<Geometry>, String, String) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
creates a new ShapeQueryBuilder from the provided field name, supplier, indexed shape id, and indexed shape type
- newShapeQueryBuilder(String, Supplier<Geometry>, String, String) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- newShapeQueryBuilder(String, Geometry) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
creates a new ShapeQueryBuilder from the provided field name and shape builder
- newShapeQueryBuilder(String, Geometry) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- newShardRequest(int, ShardRouting, AnalyzeIndexDiskUsageRequest) - Method in class org.elasticsearch.action.admin.indices.diskusage.TransportAnalyzeIndexDiskUsageAction
- newShardRequest(int, ShardRouting, ValidateQueryRequest) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- newShardRequest(int, ShardRouting, Request) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- newShardRequest(FlushRequest, ShardId) - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
- newShardRequest(RefreshRequest, ShardId) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
- newShardRequest(Request, ShardId) - Method in class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- newShardResponse() - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
- newShardResponse() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
- newShardResponse() - Method in class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- newSinglePrioritizing(String, ThreadFactory, ThreadContext, ScheduledExecutorService, PrioritizedEsThreadPoolExecutor.StarvationWatcher) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- newSingletonArrayList(E) - Static method in class org.elasticsearch.common.util.CollectionUtils
- newSnapshot() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- newSnapshot() - Method in class org.elasticsearch.index.translog.Translog
- newSnapshot() - Method in class org.elasticsearch.index.translog.TranslogWriter
- newSnapshot(long, long) - Method in class org.elasticsearch.index.translog.Translog
-
Creates a new translog snapshot containing operations from the given range.
- newSoftDeletesField() - Static method in class org.elasticsearch.common.lucene.Lucene
-
Returns a numeric docvalues which can be used to soft-delete documents.
- newStoredContext(boolean) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Just like
ThreadContext.stashContext()
but no default context is set. - newStoredContext(boolean, Collection<String>) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Just like
ThreadContext.stashContext()
but no default context is set. - newTargetRelocation(AllocationId) - Static method in class org.elasticsearch.cluster.routing.AllocationId
-
Creates a new allocation id for the target initializing shard that is the result of a relocation.
- newTaskFor(Runnable, T) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- newTaskFor(Callable<T>) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- newTermExtractor(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.CustomQueryScorer
- newTermQuery(Term, float) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser
- newTransportService(Settings, Transport, ThreadPool, TransportInterceptor, Function<BoundTransportAddress, DiscoveryNode>, ClusterSettings, Set<String>) - Method in class org.elasticsearch.node.Node
- newUnassigned(ShardId, boolean, RecoverySource, UnassignedInfo) - Static method in class org.elasticsearch.cluster.routing.ShardRouting
-
Creates a new unassigned shard.
- newUnmappedFieldQuery(String) - Static method in class org.elasticsearch.common.lucene.search.Queries
- newUnmappedFieldsQuery(Collection<String>) - Static method in class org.elasticsearch.common.lucene.search.Queries
- newXContentBuilder(XContentType, OutputStream) - Method in class org.elasticsearch.gateway.MetadataStateFormat
- newZenPing(Settings, ThreadPool, TransportService, SeedHostsProvider) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- next() - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- next() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- next() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
- next() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- next() - Method in class org.elasticsearch.index.fielddata.HistogramValue
-
Advance this instance to the next value of the histogram
- next() - Method in class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
-
Proxy to the original next() call, but estimates the overhead of loading the next term.
- next() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
-
Returns the next operation in the snapshot or
null
if we reached the end. - next() - Method in class org.elasticsearch.search.aggregations.bucket.IteratorAndCurrent
- next() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.BytesKeyedBucketOrds.BucketOrdsEnum
-
Advance to the next value.
- next() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.BucketOrdsEnum
-
Advance to the next value.
- next() - Method in interface org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLog.RunLenIterator
-
Moves the iterator to the next element if it exists.
- next() - Method in interface org.elasticsearch.search.aggregations.metrics.AbstractLinearCounting.HashesIterator
-
Moves the iterator to the next element if it exists.
- next() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks.Iter
- next() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles.Iter
- next() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks.Iter
- next() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles.Iter
- next() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket.Iter
- next(int) - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- next(Collection<Double>) - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- next(Collection<Double>) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
- next(Collection<Double>) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- next(Collection<Double>) - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel
- next(Collection<Double>) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
-
Returns the next value in the series, according to the underlying smoothing model
- next(Collection<Double>) - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel
- next(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
-
Calculate a Holt-Linear (doubly exponential weighted) moving average
- next(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
-
Calculate a doubly exponential weighted moving average
- NEXT_DOC - Enum constant in enum class org.elasticsearch.search.profile.query.QueryTimingType
- nextChunkRequest(Source) - Method in class org.elasticsearch.indices.recovery.MultiChunkTransfer
- nextDoc() - Method in class org.elasticsearch.index.fielddata.AbstractBinaryDocValues
- nextDoc() - Method in class org.elasticsearch.index.fielddata.AbstractNumericDocValues
- nextDoc() - Method in class org.elasticsearch.index.fielddata.AbstractSortedDocValues
- nextDoc() - Method in class org.elasticsearch.index.fielddata.AbstractSortedNumericDocValues
- nextDoc() - Method in class org.elasticsearch.index.fielddata.AbstractSortedSetDocValues
- nextDoc() - Method in class org.elasticsearch.index.fielddata.AbstractSortingNumericDocValues
- nextDown(Object) - Method in enum class org.elasticsearch.index.mapper.RangeType
- nextKey(Number) - Method in interface org.elasticsearch.search.aggregations.bucket.histogram.HistogramFactory
-
Given a key returned by
HistogramFactory.getKey(org.elasticsearch.search.aggregations.bucket.MultiBucketsAggregation.Bucket)
, compute the lowest key that is greater than it. - nextKey(Number) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- nextKey(Number) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- nextKey(Number) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- nextKey(Number) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- nextLevel(NestedObjectMapper) - Method in class org.elasticsearch.index.query.support.NestedScope
-
Sets the new current nested level and pushes old current nested level down the stack returns that level.
- nextOrdinal() - Method in class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
-
Advances the
OrdinalsBuilder
to the next ordinal and return the current ordinal. - nextOrNull() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
Returns the next shard, or
null
if none available. - nextOrNull() - Method in class org.elasticsearch.common.util.PlainIterator
- nextPossibleMasters(Collection<DiscoveryNode>, int) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
-
Returns a list of the next possible masters.
- nextRoundingValue(long) - Method in class org.elasticsearch.common.Rounding
-
Deprecated.
- nextRoundingValue(long) - Method in interface org.elasticsearch.common.Rounding.Prepared
-
Given the rounded value (which was potentially generated by
Rounding.Prepared.round(long)
, returns the next rounding value. - nextRoundingValue(long) - Method in class org.elasticsearch.common.rounding.Rounding
-
Deprecated.Given the rounded value (which was potentially generated by
Rounding.round(long)
, returns the next rounding value. - nextSeed() - Method in class org.elasticsearch.cluster.routing.RotationShardShuffler
- nextSeed() - Method in class org.elasticsearch.cluster.routing.ShardShuffler
-
Return a new seed.
- nextSetBit(int) - Method in class org.apache.lucene.util.CombinedBitSet
- nextSetBit(long) - Method in class org.elasticsearch.common.util.BitArray
- nextToken() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- nextUp(Object) - Method in enum class org.elasticsearch.index.mapper.RangeType
- nextValue() - Method in class org.elasticsearch.index.fielddata.BooleanScriptDocValues
- nextValue() - Method in class org.elasticsearch.index.fielddata.DoubleScriptDocValues
- nextValue() - Method in interface org.elasticsearch.index.fielddata.FormattedDocValues
-
Load and format the next value.
- nextValue() - Method in class org.elasticsearch.index.fielddata.GeoPointScriptDocValues
- nextValue() - Method in class org.elasticsearch.index.fielddata.IpScriptDocValues
- nextValue() - Method in class org.elasticsearch.index.fielddata.LongScriptDocValues
- nextValue() - Method in class org.elasticsearch.index.fielddata.MultiGeoPointValues
-
Return the next value associated with the current document.
- nextValue() - Method in class org.elasticsearch.index.fielddata.SortedBinaryDocValues
-
Iterates to the next value in the current document.
- nextValue() - Method in class org.elasticsearch.index.fielddata.SortedNumericDoubleValues
-
Iterates to the next value in the current document.
- nextValue() - Method in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
- nextValue() - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
- nextValue() - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
- nextWriteIndexAndGeneration(Metadata, Version) - Method in class org.elasticsearch.cluster.metadata.DataStream
-
Performs a dummy rollover on a
DataStream
instance and returns the tuple of the next write index name and next generation that thisDataStream
should roll over to usingDataStream.rollover(Index, long)
. - NGRAM - Enum constant in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
String distance algorithm based on character n-grams.
- NIOFS - Enum constant in enum class org.elasticsearch.index.IndexModule.Type
- no(UnassignedInfo.AllocationStatus, List<NodeAllocationResult>) - Static method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Returns a NO decision with the given
UnassignedInfo.AllocationStatus
, and the individual node-level decisions that comprised the final NO decision if in explain mode. - no(UnassignedInfo.AllocationStatus, List<NodeAllocationResult>, boolean) - Static method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Returns a NO decision with the given
UnassignedInfo.AllocationStatus
, and the individual node-level decisions that comprised the final NO decision if in explain mode. - NO - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
The shard cannot be allocated, which can happen for any number of reasons, including the allocation deciders gave a NO decision for allocating.
- NO - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
- NO - Enum constant in enum class org.elasticsearch.persistent.decider.AssignmentDecision.Type
- NO - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.Decision
- NO_API_RESTORE_UUID - Static variable in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- NO_ATTEMPT - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
No attempt was made to allocate the shard
- NO_ATTEMPT - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
-
No allocation attempt has been made yet
- NO_CONTENT - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server has fulfilled the request but does not need to return an entity-body, and might want to return updated meta information.
- NO_FEATURE_STATES_VALUE - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- NO_FOLDER_FOUND - Enum constant in enum class org.elasticsearch.indices.IndicesService.ShardDeletionCheckResult
- NO_INGEST_TOOK - Static variable in class org.elasticsearch.action.bulk.BulkResponse
- NO_LIMIT - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- NO_LOCAL_STORAGE - Enum constant in enum class org.elasticsearch.indices.IndicesService.ShardDeletionCheckResult
- NO_LONGER_ASSIGNED - Enum constant in enum class org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices.IndexRemovalReason
-
Shard of this index were previously assigned to this node but all shards have been relocated.
- NO_MASTER_BLOCK_ALL - Static variable in class org.elasticsearch.cluster.coordination.NoMasterBlockService
- NO_MASTER_BLOCK_ID - Static variable in class org.elasticsearch.cluster.coordination.NoMasterBlockService
- NO_MASTER_BLOCK_METADATA_WRITES - Static variable in class org.elasticsearch.cluster.coordination.NoMasterBlockService
- NO_MASTER_BLOCK_SETTING - Static variable in class org.elasticsearch.cluster.coordination.NoMasterBlockService
- NO_MASTER_BLOCK_WRITES - Static variable in class org.elasticsearch.cluster.coordination.NoMasterBlockService
- NO_MATCH_SIZE_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- NO_MIGRATION_NEEDED - Enum constant in enum class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.UpgradeStatus
- NO_NESTED_MAPPERS - Static variable in interface org.elasticsearch.search.LeafNestedDocuments
-
An implementation of LeafNestedDocuments for use when there are no nested field mappers
- NO_NODE_FOUND - Static variable in class org.elasticsearch.persistent.PersistentTasksExecutor
- NO_OP - Enum constant in enum class org.elasticsearch.index.engine.Engine.Operation.TYPE
- NO_OP - Enum constant in enum class org.elasticsearch.index.translog.Translog.Operation.Type
- NO_OP - Static variable in class org.elasticsearch.common.bytes.ReleasableBytesReference
- NO_OP_COLLECTOR - Static variable in class org.elasticsearch.search.aggregations.BucketCollector
- NO_OP_COLLECTOR - Static variable in class org.elasticsearch.search.aggregations.LeafBucketCollector
-
A LeafBucketCollector that doesn't collect anything.
- NO_OPS_PERFORMED - Static variable in class org.elasticsearch.index.seqno.SequenceNumbers
-
Represents no operations have been performed on the shard.
- NO_POLICY_PATTERN - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- NO_REPO_INITIALIZE_VERSION - Static variable in class org.elasticsearch.snapshots.SnapshotsService
-
Minimum node version which does not use
Repository.initializeSnapshot(SnapshotId, List, Metadata)
to write snapshot metadata when starting a snapshot. - NO_SCOPE - Static variable in class org.elasticsearch.common.inject.Scopes
-
No scope; the same as not applying any scope at all.
- NO_SHARDS - Static variable in class org.elasticsearch.index.shard.IndexLongFieldRange
-
Sentinel value indicating that no information is currently available, for instance because the index has just been created.
- NO_TIMEOUT - Static variable in class org.elasticsearch.search.SearchService
- NO_UPGRADE_REQUIRED_VERSION - Static variable in class org.elasticsearch.action.admin.cluster.migration.TransportGetFeatureUpgradeStatusAction
- NO_VALID_SHARD_COPY - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
The shard was denied allocation because there were no valid shard copies found for it amongst the nodes in the cluster.
- NO_VALID_SHARD_COPY - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
-
The shard was denied allocation to a node because there were no valid shard copies found for it; this can happen on node restart with gateway allocation
- NO_VALUES - Static variable in class org.elasticsearch.index.fielddata.ordinals.Ordinals
- NO_WAIT - Static variable in interface org.elasticsearch.index.IndexWarmer.TerminationHandle
- noBackoff() - Static method in class org.elasticsearch.action.bulk.BackoffPolicy
-
Creates a backoff policy that will not allow any backoff, i.e.
- NoClassSettingsException - Exception in org.elasticsearch.common.settings
-
A specific type of
SettingsException
indicating failure to load a class based on a settings value. - NoClassSettingsException(String, Throwable) - Constructor for exception org.elasticsearch.common.settings.NoClassSettingsException
- NoClassSettingsException(StreamInput) - Constructor for exception org.elasticsearch.common.settings.NoClassSettingsException
- noCloseStream(InputStream) - Static method in class org.elasticsearch.common.io.Streams
-
Wraps an
InputStream
such that it'sclose
method becomes a noop - noCloseStream(OutputStream) - Static method in class org.elasticsearch.common.io.Streams
-
Wraps an
OutputStream
such that it'sclose
method becomes a noop - node - Variable in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- node - Variable in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- node() - Method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor.Task
- node() - Method in class org.elasticsearch.cluster.coordination.NodeRemovalClusterStateTaskExecutor.Task
- node() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Get the id of the node
- node() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
-
Get the id of the node that manages the shard which allocation should be canceled
- node() - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
Returns the nodes
DiscoveryNode
. - node() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingResponse
-
the node which this ping describes
- node() - Method in exception org.elasticsearch.transport.ConnectTransportException
- node(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- Node - Class in org.elasticsearch.node
-
A node represent a node within a cluster (
cluster.name
). - Node(double[], double[], int, int, boolean) - Constructor for class org.apache.lucene.geo.XTessellator.Node
- Node(XTessellator.Node) - Constructor for class org.apache.lucene.geo.XTessellator.Node
-
simple deep copy constructor
- Node(Environment) - Constructor for class org.elasticsearch.node.Node
- Node(Environment, Collection<Class<? extends Plugin>>, boolean) - Constructor for class org.elasticsearch.node.Node
-
Constructs a node
- NODE_ALLOCATION_DECISION_KEY - Static variable in class org.elasticsearch.cluster.metadata.ShutdownShardMigrationStatus
- NODE_ATTRIBUTES - Static variable in class org.elasticsearch.node.Node
- NODE_BANDWIDTH_RECOVERY_DISK_READ_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
Disk's read bandwidth allocated for this node.
- NODE_BANDWIDTH_RECOVERY_DISK_WRITE_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
Disk's write bandwidth allocated for this node.
- NODE_BANDWIDTH_RECOVERY_NETWORK_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
Network's read bandwidth allocated for this node.
- NODE_BANDWIDTH_RECOVERY_OPERATOR_FACTOR_MAX_OVERCOMMIT_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
- NODE_BANDWIDTH_RECOVERY_OPERATOR_FACTOR_READ_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
- NODE_BANDWIDTH_RECOVERY_OPERATOR_FACTOR_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
-
Default factor as defined by the operator.
- NODE_BANDWIDTH_RECOVERY_OPERATOR_FACTOR_WRITE_SETTING - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
- NODE_FAILURES - Static variable in class org.elasticsearch.action.support.tasks.BaseTasksResponse
- NODE_FIELD - Static variable in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- NODE_ID_FIELD - Static variable in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- NODE_ID_SEED_SETTING - Static variable in class org.elasticsearch.env.NodeEnvironment
-
Seed for determining a persisted unique uuid of this node.
- NODE_LEFT - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of the node hosting it leaving the cluster.
- NODE_LOCAL_STORAGE_SETTING - Static variable in class org.elasticsearch.node.Node
-
controls whether the node is allowed to persist things like metadata to disk Note that this does not control whether the node stores actual indices (see
Node.NODE_DATA_SETTING
). - NODE_LOCK_FILENAME - Static variable in class org.elasticsearch.env.NodeEnvironment
- NODE_NAME_SETTING - Static variable in class org.elasticsearch.node.Node
- NODE_PIDFILE_SETTING - Static variable in class org.elasticsearch.env.Environment
- NODE_PROCESSORS_SETTING - Static variable in class org.elasticsearch.common.util.concurrent.EsExecutors
-
Setting to manually control the number of allocated processors.
- NODE_RESTARTING - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Similar to NODE_LEFT, but at the time the node left, it had been registered for a restart via the Node Shutdown API.
- NODE_ROLES_SETTING - Static variable in class org.elasticsearch.node.NodeRoleSettings
- NODE_SEEN_FIELD - Static variable in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- NODE_SHUTDOWN_VERSION - Static variable in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- NODE_STORE_ALLOW_MMAP - Static variable in class org.elasticsearch.index.IndexModule
- NodeAllocationResult - Class in org.elasticsearch.cluster.routing.allocation
-
This class represents the shard allocation decision and its explanation for a single node.
- NodeAllocationResult(DiscoveryNode, AllocationDecision, Decision, int) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- NodeAllocationResult(DiscoveryNode, Decision, int) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- NodeAllocationResult(DiscoveryNode, NodeAllocationResult.ShardStoreInfo, Decision) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- NodeAllocationResult(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- NodeAllocationResult.ShardStoreInfo - Class in org.elasticsearch.cluster.routing.allocation
-
A class that captures metadata about a shard store on a node.
- NodeAndClusterIdConverter - Class in org.elasticsearch.common.logging
-
Pattern converter to format the node_and_cluster_id variable into JSON fields
node.id
andcluster.uuid
. - NodeAndClusterIdConverter() - Constructor for class org.elasticsearch.common.logging.NodeAndClusterIdConverter
- NodeAndClusterIdStateListener - Class in org.elasticsearch.common.logging
-
The
NodeAndClusterIdStateListener
listens to cluster state changes and ONLY when receives the first update it sets the clusterUUID and nodeID in log4j pattern converterNodeAndClusterIdConverter
. - NodeAndPath(String, String) - Constructor for class org.elasticsearch.cluster.ClusterInfo.NodeAndPath
- NodeAndPath(StreamInput) - Constructor for class org.elasticsearch.cluster.ClusterInfo.NodeAndPath
- nodeBooleanValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeBooleanValue(Object, boolean) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeBooleanValue(Object, String) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeBooleanValue(Object, String, boolean) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeByteValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeByteValue(Object, byte) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- NodeClient - Class in org.elasticsearch.client.node
-
Client that executes actions on the local node.
- NodeClient(Settings, ThreadPool) - Constructor for class org.elasticsearch.client.node.NodeClient
- NodeClosedException - Exception in org.elasticsearch.node
-
An exception indicating that node is closed.
- NodeClosedException(DiscoveryNode) - Constructor for exception org.elasticsearch.node.NodeClosedException
- NodeClosedException(StreamInput) - Constructor for exception org.elasticsearch.node.NodeClosedException
- nodeConnected(DiscoveryNode) - Method in class org.elasticsearch.transport.ClusterConnectionManager
-
Returns
true
if the node is connected. - nodeConnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.ConnectionManager
- nodeConnected(DiscoveryNode) - Method in class org.elasticsearch.transport.RemoteConnectionManager
- nodeConnected(DiscoveryNode) - Method in class org.elasticsearch.transport.TransportService
-
Returns
true
iff the given node is already connected. - NodeConnectionsService - Class in org.elasticsearch.cluster
-
This component is responsible for maintaining connections from this node to all the nodes listed in the cluster state, and for disconnecting from nodes once they are removed from the cluster state.
- NodeConnectionsService(Settings, ThreadPool, TransportService) - Constructor for class org.elasticsearch.cluster.NodeConnectionsService
- nodeDataPaths() - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns an array of all of the nodes data locations.
- nodeDecisions - Variable in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- nodeDecisionsToXContent(List<NodeAllocationResult>, XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Generates X-Content for the node-level decisions, creating the outer "node_decisions" object in which they are serialized.
- NodeDisconnectedException - Exception in org.elasticsearch.transport
- NodeDisconnectedException(DiscoveryNode, String) - Constructor for exception org.elasticsearch.transport.NodeDisconnectedException
- NodeDisconnectedException(StreamInput) - Constructor for exception org.elasticsearch.transport.NodeDisconnectedException
- nodeDoubleValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeDoubleValue(Object, double) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- NodeEnvironment - Class in org.elasticsearch.env
-
A component that holds all data paths for a single node.
- NodeEnvironment(Settings, Environment) - Constructor for class org.elasticsearch.env.NodeEnvironment
-
Setup the environment.
- NodeEnvironment.DataPath - Class in org.elasticsearch.env
- NodeEnvironment.NodeLock - Class in org.elasticsearch.env
- NodeEnvironment.ShardLocker - Interface in org.elasticsearch.env
-
A functional interface that people can use to reference
NodeEnvironment.shardLock(ShardId, String, long)
- nodeExists(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Determine if a given node id exists
- nodeExists(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Determine if a given node exists
- nodeExistsWithSameRoles(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Determine if the given node exists and has the right roles.
- NodeFindDanglingIndexRequest - Class in org.elasticsearch.action.admin.indices.dangling.find
-
Used when querying every node in the cluster for a specific dangling index.
- NodeFindDanglingIndexRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.dangling.find.NodeFindDanglingIndexRequest
- NodeFindDanglingIndexRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.dangling.find.NodeFindDanglingIndexRequest
- NodeFindDanglingIndexResponse - Class in org.elasticsearch.action.admin.indices.dangling.find
-
Used when querying every node in the cluster for a specific dangling index.
- NodeFindDanglingIndexResponse(DiscoveryNode, List<IndexMetadata>) - Constructor for class org.elasticsearch.action.admin.indices.dangling.find.NodeFindDanglingIndexResponse
- NodeFindDanglingIndexResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.dangling.find.NodeFindDanglingIndexResponse
- nodeFloatValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeFloatValue(Object, float) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- NodeGatewayMetaState(DiscoveryNode, Metadata) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodeGatewayMetaState
- NodeGatewayMetaState(StreamInput) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodeGatewayMetaState
- NodeGatewayStartedShards(DiscoveryNode, String, boolean) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- NodeGatewayStartedShards(DiscoveryNode, String, boolean, Exception) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- NodeGatewayStartedShards(StreamInput) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- NodeGatewayStartedShards(StreamInput, DiscoveryNode) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- NodeHealthCheckFailureException - Exception in org.elasticsearch.cluster.coordination
-
This exception is thrown if the File system is reported unhealthy by @
FsHealthService
and this nodes needs to be removed from the cluster - NodeHealthCheckFailureException(String, Object...) - Constructor for exception org.elasticsearch.cluster.coordination.NodeHealthCheckFailureException
- NodeHealthCheckFailureException(StreamInput) - Constructor for exception org.elasticsearch.cluster.coordination.NodeHealthCheckFailureException
- NodeHealthService - Interface in org.elasticsearch.monitor
- NodeHotThreads - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- NodeHotThreads(DiscoveryNode, String) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodeHotThreads
- nodeId - Variable in class org.elasticsearch.cluster.ClusterInfo.NodeAndPath
- nodeId - Variable in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- nodeId() - Method in exception org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.Failure
- nodeId() - Method in exception org.elasticsearch.action.FailedNodeException
- nodeId() - Method in exception org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- nodeId() - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Returns node id of the node where shared is getting restored
- nodeId() - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
Get the id of this node
- nodeId() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- nodeId() - Method in class org.elasticsearch.env.NodeEnvironment
-
returns the unique uuid describing this node.
- nodeId() - Method in class org.elasticsearch.env.NodeMetadata
- nodeId() - Method in class org.elasticsearch.repositories.VerificationFailure
- nodeId() - Method in exception org.elasticsearch.snapshots.SnapshotShardFailure
-
Returns node id where failure occurred
- NodeIdConverter - Class in org.elasticsearch.common.logging
-
Pattern converter to format the node_id variable into JSON fields
node.id
. - NodeIdConverter() - Constructor for class org.elasticsearch.common.logging.NodeIdConverter
- NodeIndicesStats - Class in org.elasticsearch.indices
-
Global information on indices stats running on a specific node.
- NodeIndicesStats(CommonStats, Map<Index, List<IndexShardStats>>) - Constructor for class org.elasticsearch.indices.NodeIndicesStats
- NodeIndicesStats(StreamInput) - Constructor for class org.elasticsearch.indices.NodeIndicesStats
- nodeInfo() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
- NodeInfo - Class in org.elasticsearch.action.admin.cluster.node.info
-
Node information (static, does not change over time).
- NodeInfo(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- NodeInfo(Version, Build, DiscoveryNode, Settings, OsInfo, ProcessInfo, JvmInfo, ThreadPoolInfo, TransportInfo, HttpInfo, PluginsAndModules, IngestInfo, AggregationInfo, ByteSizeValue) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- NodeInfoRequest(NodesInfoRequest) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction.NodeInfoRequest
- NodeInfoRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction.NodeInfoRequest
- nodeIntegerValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeIntegerValue(Object, int) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeInterleavedShardIterator() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Creates an iterator over shards interleaving between nodes: The iterator returns the first shard from the first node, then the first shard of the second node, etc.
- NodeJoinController - Class in org.elasticsearch.discovery.zen
-
This class processes incoming join request (passed zia
ZenDiscovery
). - NodeJoinController(Settings, MasterService, AllocationService, ElectMasterService, RerouteService) - Constructor for class org.elasticsearch.discovery.zen.NodeJoinController
- NodeJoinController.ElectionCallback - Interface in org.elasticsearch.discovery.zen
- NodeListDanglingIndicesRequest - Class in org.elasticsearch.action.admin.indices.dangling.list
-
Used when querying every node in the cluster for dangling indices, in response to a list request.
- NodeListDanglingIndicesRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.dangling.list.NodeListDanglingIndicesRequest
- NodeListDanglingIndicesRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.dangling.list.NodeListDanglingIndicesRequest
- NodeListDanglingIndicesResponse - Class in org.elasticsearch.action.admin.indices.dangling.list
-
Used when querying every node in the cluster for dangling indices, in response to a list request.
- NodeListDanglingIndicesResponse(DiscoveryNode, List<DanglingIndexInfo>) - Constructor for class org.elasticsearch.action.admin.indices.dangling.list.NodeListDanglingIndicesResponse
- NodeListDanglingIndicesResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.dangling.list.NodeListDanglingIndicesResponse
- NodeLock(int, Logger, Environment, CheckedFunction<Path, Boolean, IOException>) - Constructor for class org.elasticsearch.env.NodeEnvironment.NodeLock
-
Tries to acquire a node lock for a node id, throws
IOException
if it is unable to acquire it - nodeLongValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeLongValue(Object, long) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeMapValue(Object, String) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeMetadata(Path...) - Static method in class org.elasticsearch.gateway.PersistedClusterStateService
-
Returns the node metadata for the given data paths, and checks if the node ids are unique
- NodeMetadata - Class in org.elasticsearch.env
-
Metadata associated with this node: its persistent node ID and its version.
- NodeMetadata(String, Version, Version) - Constructor for class org.elasticsearch.env.NodeMetadata
- NodeNamePatternConverter - Class in org.elasticsearch.common.logging
-
Converts
%node_name
in log4j patterns into the current node name. - NodeNotConnectedException - Exception in org.elasticsearch.transport
-
An exception indicating that a message is sent to a node that is not connected.
- NodeNotConnectedException(DiscoveryNode, String) - Constructor for exception org.elasticsearch.transport.NodeNotConnectedException
- NodeNotConnectedException(StreamInput) - Constructor for exception org.elasticsearch.transport.NodeNotConnectedException
- nodeOperation(NodeRequest) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
- nodeOperation(NodeRequest, Task) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
- nodeOperation(TransportNodesHotThreadsAction.NodeRequest) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
- nodeOperation(TransportNodesInfoAction.NodeInfoRequest) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
- nodeOperation(TransportNodesReloadSecureSettingsAction.NodeRequest) - Method in class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction
- nodeOperation(TransportNodesStatsAction.NodeStatsRequest) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
- nodeOperation(TransportNodesStatsAction.NodeStatsRequest, Task) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
- nodeOperation(TransportNodesUsageAction.NodeUsageRequest) - Method in class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction
- nodeOperation(TransportNodesSnapshotsStatus.NodeRequest) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- nodeOperation(TransportClusterStatsAction.ClusterStatsNodeRequest) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
- nodeOperation(TransportClusterStatsAction.ClusterStatsNodeRequest, Task) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
- nodeOperation(NodeFindDanglingIndexRequest) - Method in class org.elasticsearch.action.admin.indices.dangling.find.TransportFindDanglingIndexAction
- nodeOperation(NodeListDanglingIndicesRequest) - Method in class org.elasticsearch.action.admin.indices.dangling.list.TransportListDanglingIndicesAction
- nodeOperation(TransportNodesListGatewayMetaState.NodeRequest) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- nodeOperation(TransportNodesListGatewayStartedShards.NodeRequest) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- nodeOperation(TransportNodesListShardStoreMetadata.NodeRequest) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata
- nodeOperation(AllocatedPersistentTask, SystemIndexMigrationTaskParams, PersistentTaskState) - Method in class org.elasticsearch.upgrades.SystemIndexMigrationExecutor
- nodeOperation(AllocatedPersistentTask, Params, PersistentTaskState) - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
-
This operation will be executed on the executor node.
- NodePersistentTasksExecutor - Class in org.elasticsearch.persistent
-
This component is responsible for execution of persistent tasks.
- nodeQueueSize() - Method in class org.elasticsearch.search.query.QuerySearchResult
- nodeQueueSize(int) - Method in class org.elasticsearch.search.query.QuerySearchResult
- NodeRemovalClusterStateTaskExecutor - Class in org.elasticsearch.cluster.coordination
- NodeRemovalClusterStateTaskExecutor(AllocationService, Logger) - Constructor for class org.elasticsearch.cluster.coordination.NodeRemovalClusterStateTaskExecutor
- NodeRemovalClusterStateTaskExecutor.Task - Class in org.elasticsearch.cluster.coordination
- NodeReplacementAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
- NodeReplacementAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.NodeReplacementAllocationDecider
- NodeRepurposeCommand - Class in org.elasticsearch.env
- NodeRepurposeCommand() - Constructor for class org.elasticsearch.env.NodeRepurposeCommand
- NodeRequest(String, Request, List<ShardRouting>) - Constructor for class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- NodeRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction.NodeRequest
- NodeRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction.NodeRequest
- NodeRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeRequest
- NodeRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- NodeRequest(StreamInput) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeRequest
- NodeRequest(StreamInput) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodeRequest
- NodeRequest(TransportNodesListGatewayStartedShards.Request) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeRequest
- NodeRequest(TransportNodesListShardStoreMetadata.Request) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodeRequest
- nodeRequiresLocalStorage(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
- NodeResponse(DiscoveryNode, Exception) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse.NodeResponse
- NodeResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse.NodeResponse
- nodeResponseClass - Variable in class org.elasticsearch.action.support.nodes.TransportNodesAction
- NodeResponseTracker - Class in org.elasticsearch.action.support
-
This class tracks the intermediate responses that will be used to create aggregated cluster response to a request.
- NodeResponseTracker(int) - Constructor for class org.elasticsearch.action.support.NodeResponseTracker
- NodeResponseTracker(Collection<Object>) - Constructor for class org.elasticsearch.action.support.NodeResponseTracker
- NodeResponseTracker.DiscardedResponsesException - Exception in org.elasticsearch.action.support
-
This exception is thrown when the
NodeResponseTracker
is asked to give information about the responses after they have been discarded. - NodeRoleSettings - Class in org.elasticsearch.node
- NodeRoleSettings() - Constructor for class org.elasticsearch.node.NodeRoleSettings
- nodes() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- nodes() - Method in class org.elasticsearch.cluster.ClusterState.Builder
- nodes() - Method in class org.elasticsearch.cluster.ClusterState
- nodes() - Method in class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- nodes() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Get discovery nodes in current routing
- nodes(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- nodes(DiscoveryNodes) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- nodes(DiscoveryNodes.Builder) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- NODES - Enum constant in enum class org.elasticsearch.cluster.ClusterState.Metric
- NODES_FOLDER - Static variable in class org.elasticsearch.env.NodeEnvironment
- nodesAdded() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff nodes have been added from the cluster since the last cluster state. - nodesChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff nodes have been changed (added or removed) from the cluster since the last cluster state. - NodeScope - Enum constant in enum class org.elasticsearch.common.settings.Setting.Property
-
Node scope
- nodesDelta() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns the
DiscoveryNodes.Delta
between the previous cluster state and the new cluster state. - NodeService - Class in org.elasticsearch.node
- NodesFaultDetection - Class in org.elasticsearch.discovery.zen
-
A fault detection of multiple nodes.
- NodesFaultDetection(Settings, ThreadPool, TransportService, Supplier<ClusterState>, ClusterName) - Constructor for class org.elasticsearch.discovery.zen.NodesFaultDetection
- NodesFaultDetection.Listener - Class in org.elasticsearch.discovery.zen
- NodesFaultDetection.PingRequest - Class in org.elasticsearch.discovery.zen
- NodesFaultDetection.PingResponse - Class in org.elasticsearch.discovery.zen
- NodesGatewayMetaState(ClusterName, List<TransportNodesListGatewayMetaState.NodeGatewayMetaState>, List<FailedNodeException>) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodesGatewayMetaState
- NodesGatewayMetaState(StreamInput) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodesGatewayMetaState
- NodesGatewayStartedShards(ClusterName, List<TransportNodesListGatewayStartedShards.NodeGatewayStartedShards>, List<FailedNodeException>) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodesGatewayStartedShards
- NodesGatewayStartedShards(StreamInput) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodesGatewayStartedShards
- nodeShortValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeShortValue(Object, short) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodesHotThreads(NodesHotThreadsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns top N hot-threads samples per node.
- nodesHotThreads(NodesHotThreadsRequest, ActionListener<NodesHotThreadsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns top N hot-threads samples per node.
- NodesHotThreadsAction - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- NodesHotThreadsRequest - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- NodesHotThreadsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
-
Get hot threads from nodes based on the nodes ids specified.
- NodesHotThreadsRequest(DiscoveryNode) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
-
Get hot threads from the given node, for use if the node isn't a stable member of the cluster.
- NodesHotThreadsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- NodesHotThreadsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- NodesHotThreadsRequestBuilder(ElasticsearchClient, NodesHotThreadsAction) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
- NodesHotThreadsResponse - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- NodesHotThreadsResponse(ClusterName, List<NodeHotThreads>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsResponse
- NodesHotThreadsResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsResponse
- NodeShutdownAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
An allocation decider that prevents shards from being allocated to a node that is in the process of shutting down.
- NodeShutdownAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.NodeShutdownAllocationDecider
- NodeShutdownMetadataDiff(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.NodesShutdownMetadata.NodeShutdownMetadataDiff
- nodeShutdowns() - Method in class org.elasticsearch.cluster.metadata.Metadata
- nodeShutdowns() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Returns the map of node id to shutdown metadata currently in the cluster
- nodesIds() - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- nodesIds(String...) - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- nodesInfo(NodesInfoRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes info of the cluster.
- nodesInfo(NodesInfoRequest, ActionListener<NodesInfoResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes info of the cluster.
- NodesInfoAction - Class in org.elasticsearch.action.admin.cluster.node.info
- nodesInfoRequest() - Static method in class org.elasticsearch.client.Requests
-
Creates a nodes info request against all the nodes.
- nodesInfoRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a nodes info request against one or more nodes.
- NodesInfoRequest - Class in org.elasticsearch.action.admin.cluster.node.info
-
A request to get node (cluster) level information.
- NodesInfoRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Get information from nodes based on the nodes ids specified.
- NodesInfoRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Create a new NodeInfoRequest from a
StreamInput
object. - NodesInfoRequest.Metric - Enum Class in org.elasticsearch.action.admin.cluster.node.info
-
An enumeration of the "core" sections of metrics that may be requested from the nodes information endpoint.
- NodesInfoRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.info
- NodesInfoRequestBuilder(ElasticsearchClient, NodesInfoAction) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder
- NodesInfoResponse - Class in org.elasticsearch.action.admin.cluster.node.info
- NodesInfoResponse(ClusterName, List<NodeInfo>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
- NodesInfoResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
- NodeSnapshotStatus(DiscoveryNode, Map<Snapshot, Map<ShardId, SnapshotIndexShardStatus>>) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeSnapshotStatus
- NodeSnapshotStatus(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeSnapshotStatus
- NodesOperationRequestBuilder<Request extends BaseNodesRequest<Request>,
Response extends BaseNodesResponse<?>, RequestBuilder extends NodesOperationRequestBuilder<Request, Response, RequestBuilder>> - Class in org.elasticsearch.action.support.nodes - NodesOperationRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.support.nodes.NodesOperationRequestBuilder
- NodesReloadSecureSettingsAction - Class in org.elasticsearch.action.admin.cluster.node.reload
- NodesReloadSecureSettingsRequest - Class in org.elasticsearch.action.admin.cluster.node.reload
-
Request for a reload secure settings action
- NodesReloadSecureSettingsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequest
- NodesReloadSecureSettingsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequest
-
Reload secure settings only on certain nodes, based on the nodes ids specified.
- NodesReloadSecureSettingsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequest
- NodesReloadSecureSettingsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.reload
-
Builder for the reload secure settings nodes request
- NodesReloadSecureSettingsRequestBuilder(ElasticsearchClient, NodesReloadSecureSettingsAction) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequestBuilder
- NodesReloadSecureSettingsResponse - Class in org.elasticsearch.action.admin.cluster.node.reload
-
The response for the reload secure settings action
- NodesReloadSecureSettingsResponse(ClusterName, List<NodesReloadSecureSettingsResponse.NodeResponse>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse
- NodesReloadSecureSettingsResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse
- NodesReloadSecureSettingsResponse.NodeResponse - Class in org.elasticsearch.action.admin.cluster.node.reload
- nodesRemoved() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
iff nodes have been removed from the cluster since the last cluster state. - nodesResponse(XContentBuilder, ToXContent.Params, NodesResponse) - Static method in class org.elasticsearch.rest.action.RestActions
- NodesResponseRestListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.RestActions.NodesResponseRestListener
- NodesShutdownMetadata - Class in org.elasticsearch.cluster.metadata
-
Contains the data about nodes which are currently configured to shut down, either permanently or temporarily.
- NodesShutdownMetadata(Map<String, SingleNodeShutdownMetadata>) - Constructor for class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- NodesShutdownMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- NodesShutdownMetadata.NodeShutdownMetadataDiff - Class in org.elasticsearch.cluster.metadata
-
Handles diffing and appling diffs for
NodesShutdownMetadata
as necessary for the cluster state infrastructure. - NodesSnapshotStatus(ClusterName, List<TransportNodesSnapshotsStatus.NodeSnapshotStatus>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodesSnapshotStatus
- NodesSnapshotStatus(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodesSnapshotStatus
- nodesStats(NodesStatsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes stats of the cluster.
- nodesStats(NodesStatsRequest, ActionListener<NodesStatsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes stats of the cluster.
- NodesStatsAction - Class in org.elasticsearch.action.admin.cluster.node.stats
- nodesStatsRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a nodes stats request against one or more nodes.
- NodesStatsRequest - Class in org.elasticsearch.action.admin.cluster.node.stats
-
A request to get node (cluster) level stats.
- NodesStatsRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- NodesStatsRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Get stats from nodes based on the nodes ids specified.
- NodesStatsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- NodesStatsRequest.Metric - Enum Class in org.elasticsearch.action.admin.cluster.node.stats
-
An enumeration of the "core" sections of metrics that may be requested from the nodes stats endpoint.
- NodesStatsRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.stats
- NodesStatsRequestBuilder(ElasticsearchClient, NodesStatsAction) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
- NodesStatsResponse - Class in org.elasticsearch.action.admin.cluster.node.stats
- NodesStatsResponse(ClusterName, List<NodeStats>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
- NodesStatsResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
- NodesStoreFilesMetadata(ClusterName, List<TransportNodesListShardStoreMetadata.NodeStoreFilesMetadata>, List<FailedNodeException>) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodesStoreFilesMetadata
- NodesStoreFilesMetadata(StreamInput) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodesStoreFilesMetadata
- nodeStats() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
- NodeStats - Class in org.elasticsearch.action.admin.cluster.node.stats
-
Node statistics (dynamic, changes depending on when created).
- NodeStats(DiscoveryNode, long, NodeIndicesStats, OsStats, ProcessStats, JvmStats, ThreadPoolStats, FsInfo, TransportStats, HttpStats, AllCircuitBreakerStats, ScriptStats, DiscoveryStats, IngestStats, AdaptiveSelectionStats, ScriptCacheStats, IndexingPressureStats) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- NodeStats(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- NodeStatsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction.NodeStatsRequest
- NodeStoreFilesMetadata(DiscoveryNode, TransportNodesListShardStoreMetadata.StoreFilesMetadata) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodeStoreFilesMetadata
- NodeStoreFilesMetadata(StreamInput, DiscoveryNode) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodeStoreFilesMetadata
- nodeStringArrayValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
-
Returns an array of string value from a node value.
- nodeStringValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
-
Returns the
Object.toString()
value of its input, ornull
if the input is null - nodeStringValue(Object, String) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodesUsage(NodesUsageRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns top N hot-threads samples per node.
- nodesUsage(NodesUsageRequest, ActionListener<NodesUsageResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes usage of the cluster.
- NodesUsageAction - Class in org.elasticsearch.action.admin.cluster.node.usage
- NodesUsageAction() - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageAction
- nodesUsageRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a nodes usage request against one or more nodes.
- NodesUsageRequest - Class in org.elasticsearch.action.admin.cluster.node.usage
- NodesUsageRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
-
Get usage from nodes based on the nodes ids specified.
- NodesUsageRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
- NodesUsageRequestBuilder - Class in org.elasticsearch.action.admin.cluster.node.usage
- NodesUsageRequestBuilder(ElasticsearchClient, ActionType<NodesUsageResponse>) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequestBuilder
- NodesUsageResponse - Class in org.elasticsearch.action.admin.cluster.node.usage
-
The response for the nodes usage api which contains the individual usage statistics for all nodes queried.
- NodesUsageResponse(ClusterName, List<NodeUsage>, List<FailedNodeException>) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageResponse
- NodesUsageResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageResponse
- nodeTimeValue(Object) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- nodeTimeValue(Object, TimeValue) - Static method in class org.elasticsearch.common.xcontent.support.XContentMapValues
- NodeToolCli - Class in org.elasticsearch.cluster.coordination
- NodeToolCli() - Constructor for class org.elasticsearch.cluster.coordination.NodeToolCli
- NodeUsage - Class in org.elasticsearch.action.admin.cluster.node.usage
- NodeUsage(DiscoveryNode, long, long, Map<String, Long>, Map<String, Object>) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- NodeUsage(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- NodeUsageRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction.NodeUsageRequest
- NodeValidationException - Exception in org.elasticsearch.node
-
An exception thrown during node validation.
- NodeValidationException(String) - Constructor for exception org.elasticsearch.node.NodeValidationException
-
Creates a node validation exception with the specified validation message to be displayed to the user.
- nodeVersion() - Method in class org.elasticsearch.env.NodeMetadata
- NodeVersionAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
An allocation decider that prevents relocation or allocation from nodes that might not be version compatible.
- NodeVersionAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.NodeVersionAllocationDecider
- NodeView(String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- NodeView(String, String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- NodeView(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- NoLongerPrimaryShardException(StreamInput) - Constructor for exception org.elasticsearch.cluster.action.shard.ShardStateAction.NoLongerPrimaryShardException
- NoLongerPrimaryShardException(ShardId, String) - Constructor for exception org.elasticsearch.cluster.action.shard.ShardStateAction.NoLongerPrimaryShardException
- NoMasterBlockService - Class in org.elasticsearch.cluster.coordination
- NoMasterBlockService(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.coordination.NoMasterBlockService
- noMatchSize - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- noMatchSize() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- noMatchSize() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- noMatchSize(Integer) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Sets the size of the fragment to return from the beginning of the field if there are no matches to highlight and the field doesn't also define noMatchSize.
- NON_AUTHORITATIVE_INFORMATION - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The returned meta information in the entity-header is not the definitive set as available from the origin server, but is gathered from a local or a third-party copy.
- NON_RECYCLING_INSTANCE - Static variable in class org.elasticsearch.common.util.BigArrays
- NON_RECYCLING_INSTANCE - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- nonAggregatableIndices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
The list of indices where this field is not aggregatable, or null if the field is aggregatable in all indices.
- NonCollectingAggregator - Class in org.elasticsearch.search.aggregations
-
An aggregator that is not collected, this can typically be used when running an aggregation over a field that doesn't have a mapping.
- NonCollectingAggregator(String, AggregationContext, Aggregator, AggregatorFactories, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.NonCollectingAggregator
-
Build a NonCollectingAggregator for any aggregator.
- nonCompetitive - Variable in class org.elasticsearch.search.aggregations.TopBucketBuilder
- NonDiffableValueSerializer() - Constructor for class org.elasticsearch.cluster.DiffableUtils.NonDiffableValueSerializer
- none(Recycler.C<T>) - Static method in enum class org.elasticsearch.common.recycler.Recyclers
-
Return a
Recycler
that never recycles entries. - None() - Constructor for class org.elasticsearch.index.fielddata.IndexFieldDataCache.None
- NONE - Enum constant in enum class org.elasticsearch.action.support.WriteRequest.RefreshPolicy
-
Don't refresh after this request.
- NONE - Enum constant in enum class org.elasticsearch.action.ThreadingModel
- NONE - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
- NONE - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
- NONE - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- NONE - Enum constant in enum class org.elasticsearch.common.util.PageCacheRecycler.Type
- NONE - Enum constant in enum class org.elasticsearch.index.mapper.MappedFieldType.CollapseType
- NONE - Enum constant in enum class org.elasticsearch.index.mapper.TextSearchInfo.TermVector
- NONE - Enum constant in enum class org.elasticsearch.index.query.RegexpFlag
-
Disables all available option flags
- NONE - Enum constant in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- NONE - Enum constant in enum class org.elasticsearch.index.query.ZeroTermsQueryOption
- NONE - Enum constant in enum class org.elasticsearch.indices.SystemIndices.SystemIndexAccessLevel
- NONE - Enum constant in enum class org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
- NONE - Enum constant in enum class org.elasticsearch.search.aggregations.AggregationBuilder.BucketCardinality
- NONE - Enum constant in enum class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
- NONE - Enum constant in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
- NONE - Static variable in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- NONE - Static variable in class org.elasticsearch.action.OriginalIndices
- NONE - Static variable in class org.elasticsearch.action.support.ActiveShardCount
- NONE - Static variable in enum class org.elasticsearch.action.support.IndicesOptions.Option
- NONE - Static variable in enum class org.elasticsearch.action.support.IndicesOptions.WildcardStates
- NONE - Static variable in class org.elasticsearch.index.mapper.TextSearchInfo
-
Specifies that this field does not support text searching of any kind
- NONE - Static variable in interface org.elasticsearch.script.ScriptCompiler
- NONE - Static variable in class org.elasticsearch.search.aggregations.CardinalityUpperBound
-
Aggregator
s with this cardinality won't collect any data at all. - NoneCircuitBreakerService - Class in org.elasticsearch.indices.breaker
-
Class that returns a breaker that never breaks
- NoneCircuitBreakerService() - Constructor for class org.elasticsearch.indices.breaker.NoneCircuitBreakerService
- NoneRecycler<T> - Class in org.elasticsearch.common.recycler
- NoneRecycler(Recycler.C<T>) - Constructor for class org.elasticsearch.common.recycler.NoneRecycler
- NoneRecycler.NV<T> - Class in org.elasticsearch.common.recycler
- NonNegativeScoresSimilarity - Class in org.elasticsearch.index.similarity
-
A
Similarity
that rejects negative scores. - NonNegativeScoresSimilarity(Similarity) - Constructor for class org.elasticsearch.index.similarity.NonNegativeScoresSimilarity
- nonNullLength() - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
Returns the size of the expected results, excluding potential null values.
- NoNodeAvailableException - Exception in org.elasticsearch.client.transport
-
An exception indicating no node is available to perform the operation.
- NoNodeAvailableException(String) - Constructor for exception org.elasticsearch.client.transport.NoNodeAvailableException
- NoNodeAvailableException(String, Throwable) - Constructor for exception org.elasticsearch.client.transport.NoNodeAvailableException
- NoNodeAvailableException(StreamInput) - Constructor for exception org.elasticsearch.client.transport.NoNodeAvailableException
- nonRootDocuments() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Returns an Iterable over all non-root documents.
- nonSearchableIndices() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
-
The list of indices where this field is not searchable, or null if the field is searchable in all indices.
- noOp(Engine.NoOp) - Method in class org.elasticsearch.index.engine.Engine
- noOp(Engine.NoOp) - Method in class org.elasticsearch.index.engine.InternalEngine
- noOp(Engine.NoOp) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- NoOp(long, long, String) - Constructor for class org.elasticsearch.index.translog.Translog.NoOp
- NoOp(long, long, Engine.Operation.Origin, long, String) - Constructor for class org.elasticsearch.index.engine.Engine.NoOp
- NOOP - Enum constant in enum class org.elasticsearch.action.DocWriteResponse.Result
- NOOP - Enum constant in enum class org.elasticsearch.common.breaker.CircuitBreaker.Type
- NOOP - Static variable in class org.elasticsearch.action.search.SearchProgressListener
- NOOP - Static variable in class org.elasticsearch.search.fetch.FetchProfiler
- NOOP_EXTRA_DATA - Static variable in class org.elasticsearch.search.sort.BucketedSort
-
An implementation of BucketedSort.ExtraData that does nothing.
- NOOP_FIELD_FILTER - Static variable in interface org.elasticsearch.plugins.MapperPlugin
-
The default field filter applied, which doesn't filter anything.
- NOOP_FIELD_PREDICATE - Static variable in interface org.elasticsearch.plugins.MapperPlugin
-
The default field predicate applied, which doesn't filter anything.
- NOOP_LISTENER - Static variable in interface org.elasticsearch.transport.TransportMessageListener
- NOOP_PIPELINE_NAME - Static variable in class org.elasticsearch.ingest.IngestService
- NOOP_STARVATION_WATCHER - Static variable in interface org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.StarvationWatcher
- NOOP_TRANSPORT_INTERCEPTOR - Static variable in class org.elasticsearch.transport.TransportService
- NoopCircuitBreaker - Class in org.elasticsearch.common.breaker
-
A CircuitBreaker that doesn't increment or adjust, and all operations are basically noops
- NoopCircuitBreaker(String) - Constructor for class org.elasticsearch.common.breaker.NoopCircuitBreaker
- NoOpEngine - Class in org.elasticsearch.index.engine
-
NoOpEngine is an engine implementation that does nothing but the bare minimum required in order to have an engine.
- NoOpEngine(EngineConfig) - Constructor for class org.elasticsearch.index.engine.NoOpEngine
- NoOpLock() - Constructor for class org.elasticsearch.index.engine.Engine.NoOpLock
- NOOPS_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- noopTombstone(String) - Static method in class org.elasticsearch.index.mapper.ParsedDocument
-
Create a no-op tombstone document
- noopUpdate(String) - Method in class org.elasticsearch.index.shard.IndexShard
-
Should be called for each no-op update operation to increment relevant statistics.
- NORMAL - Enum constant in enum class org.elasticsearch.common.Priority
- normalize(Reader) - Method in interface org.elasticsearch.index.analysis.CharFilterFactory
- normalize(Reader) - Method in interface org.elasticsearch.index.analysis.NormalizingCharFilterFactory
- normalize(String, TokenStream) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- normalize(String, TokenStream) - Method in class org.elasticsearch.index.analysis.LowercaseNormalizer
- normalize(String, TokenStream) - Method in class org.elasticsearch.index.analysis.ReloadableCustomAnalyzer
- normalize(TokenStream) - Method in interface org.elasticsearch.index.analysis.NormalizingTokenFilterFactory
- normalize(TokenStream) - Method in interface org.elasticsearch.index.analysis.TokenFilterFactory
-
Normalize a tokenStream for use in multi-term queries The default implementation is a no-op
- NORMALIZED_LATITUDE_MASK - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
-
Since shapes are encoded, their boundaries are to be compared to against the encoded/decoded values of
LATITUDE_MASK
- NORMALIZED_NEGATIVE_LATITUDE_MASK - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
- normalizedValue() - Method in interface org.elasticsearch.search.aggregations.pipeline.Derivative
-
Returns the normalized value.
- normalizedValue() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalDerivative
- normalizedValue() - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedDerivative
- normalizedWildcardQuery(String, MultiTermQuery.RewriteMethod, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- normalizedWildcardQuery(String, MultiTermQuery.RewriteMethod, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- normalizedWildcardQuery(String, MultiTermQuery.RewriteMethod, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.StringFieldType
- normalizeLat(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Normalize latitude to lie within the -90 to 90 (both inclusive) range.
- normalizeLon(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Normalize longitude to lie within the -180 (exclusive) to 180 (inclusive) range.
- normalizePoint(double[]) - Static method in class org.elasticsearch.common.geo.GeoUtils
- normalizePoint(double[], boolean, boolean) - Static method in class org.elasticsearch.common.geo.GeoUtils
- normalizePoint(GeoPoint) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Normalize the geo
Point
for its coordinates to lie within their respective normalized ranges. - normalizePoint(GeoPoint, boolean, boolean) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Normalize the geo
Point
for the given coordinates to lie within their respective normalized ranges. - normalizePrefix(String) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Checks that all settings in the builder start with the specified prefix.
- normalizer() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- normalizer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- NORMALIZER - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Fields
- normalizeWildcardPattern(String, String, Analyzer) - Static method in class org.elasticsearch.index.mapper.StringFieldType
- NormalizingCharFilterFactory - Interface in org.elasticsearch.index.analysis
-
A CharFilterFactory that also supports normalization The default implementation of
NormalizingCharFilterFactory.normalize(Reader)
delegates toCharFilterFactory.create(Reader)
- NormalizingTokenFilterFactory - Interface in org.elasticsearch.index.analysis
-
A TokenFilterFactory that may be used for normalization The default implementation delegates
NormalizingTokenFilterFactory.normalize(TokenStream)
toTokenFilterFactory.create(TokenStream)
}. - norms(boolean, Function<FieldMapper, Boolean>) - Static method in class org.elasticsearch.index.mapper.TextParams
- NORMS - Enum constant in enum class org.elasticsearch.index.search.stats.FieldUsageStats.UsageContext
- NORMS - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- NORMS - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- NORMS_IN_BYTES - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- NoSeedNodeLeftException - Exception in org.elasticsearch.transport
-
Thrown after completely failing to connect to any node of the remote cluster.
- NoSeedNodeLeftException(String) - Constructor for exception org.elasticsearch.transport.NoSeedNodeLeftException
- NoSeedNodeLeftException(StreamInput) - Constructor for exception org.elasticsearch.transport.NoSeedNodeLeftException
- NoShardAvailableActionException - Exception in org.elasticsearch.action
- NoShardAvailableActionException(StreamInput) - Constructor for exception org.elasticsearch.action.NoShardAvailableActionException
- NoShardAvailableActionException(ShardId) - Constructor for exception org.elasticsearch.action.NoShardAvailableActionException
- NoShardAvailableActionException(ShardId, String) - Constructor for exception org.elasticsearch.action.NoShardAvailableActionException
- NoShardAvailableActionException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.action.NoShardAvailableActionException
- NoSuchNodeException - Exception in org.elasticsearch.action
- NoSuchNodeException(String) - Constructor for exception org.elasticsearch.action.NoSuchNodeException
- NoSuchNodeException(StreamInput) - Constructor for exception org.elasticsearch.action.NoSuchNodeException
- NoSuchRemoteClusterException - Exception in org.elasticsearch.transport
-
An exception that remote cluster is missing or connectivity to the remote connection is failing
- NoSuchRemoteClusterException(String) - Constructor for exception org.elasticsearch.transport.NoSuchRemoteClusterException
- NoSuchRemoteClusterException(StreamInput) - Constructor for exception org.elasticsearch.transport.NoSuchRemoteClusterException
- not(Query) - Static method in class org.elasticsearch.common.lucene.search.Queries
-
Return a query that matches all documents but those that match the given query.
- not(Matcher<? super T>) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Inverts the given matcher.
- NOT - Enum constant in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- NOT_ACCEPTABLE - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The resource identified by the request is only capable of generating response entities which have content characteristics not acceptable according to the accept headers sent in the request.
- NOT_ACKNOWLEDGED - Static variable in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- NOT_CLOSED - Static variable in class org.elasticsearch.http.HttpStats.ClientStats
- NOT_EXISTS - Static variable in class org.elasticsearch.index.engine.Engine.GetResult
- NOT_FOUND - Enum constant in enum class org.elasticsearch.action.DocWriteResponse.Result
- NOT_FOUND - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server has not found anything matching the Request-URI.
- NOT_FOUND - Static variable in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- NOT_FOUND - Static variable in class org.elasticsearch.common.lucene.uid.Versions
-
indicates that the current document was not found in lucene and in the version map
- NOT_IMPLEMENTED - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server does not support the functionality required to fulfill the request.
- NOT_MODIFIED - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
If the client has performed a conditional GET request and access is allowed, but the document has not been modified, the server SHOULD respond with this status code.
- NOT_STARTED - Enum constant in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Status
- NOT_TAKEN - Static variable in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
a constant representing a shard decision where no decision was taken
- NOT_TAKEN - Static variable in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
a constant representing no decision taken
- NOT_TAKEN - Static variable in class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
- notASubtype(Class<?>, Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
- NotCompressedException - Exception in org.elasticsearch.common.compress
-
Exception indicating that we were expecting something compressed, which was not compressed or corrupted so that the compression format could not be detected.
- NotCompressedException() - Constructor for exception org.elasticsearch.common.compress.NotCompressedException
- NotCopyableOnResize - Enum constant in enum class org.elasticsearch.common.settings.Setting.Property
-
Mark this setting as not copyable during an index resize (shrink or split).
- notifyFinalReduce(List<SearchShard>, TotalHits, InternalAggregations, int) - Method in class org.elasticsearch.action.search.SearchProgressListener
- notifyIfCancelled(ActionListener<T>) - Method in class org.elasticsearch.tasks.CancellableTask
-
Notifies the listener of failure with a
TaskCancelledException
if this task has been cancelled, otherwise does nothing. - notifyListener(RecoveryFailedException, boolean) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- notifyNow(ResourceWatcherService.Frequency) - Method in class org.elasticsearch.watcher.ResourceWatcherService
- notifyOnce(ActionListener<Response>) - Static method in interface org.elasticsearch.action.ActionListener
-
Wraps a given listener and returns a new listener which makes sure
ActionListener.onResponse(Object)
andActionListener.onFailure(Exception)
of the provided listener will be called at most once. - NotifyOnceListener<Response> - Class in org.elasticsearch.action
-
A listener that ensures that only one of onResponse or onFailure is called.
- NotifyOnceListener() - Constructor for class org.elasticsearch.action.NotifyOnceListener
- notInMultiFields(String) - Static method in class org.elasticsearch.index.mapper.FieldMapper
- NotMasterException - Exception in org.elasticsearch.cluster
-
Thrown when a node join request or a master ping reaches a node which is not currently acting as a master or when a cluster state update task is to be executed on a node that is no longer master.
- NotMasterException(String) - Constructor for exception org.elasticsearch.cluster.NotMasterException
- NotMasterException(StreamInput) - Constructor for exception org.elasticsearch.cluster.NotMasterException
- NotSerializableExceptionWrapper - Exception in org.elasticsearch.common.io.stream
-
This exception can be used to wrap a given, not serializable exception to serialize via
StreamOutput.writeException(Throwable)
. - NotSerializableExceptionWrapper(Throwable) - Constructor for exception org.elasticsearch.common.io.stream.NotSerializableExceptionWrapper
- NotSerializableExceptionWrapper(StreamInput) - Constructor for exception org.elasticsearch.common.io.stream.NotSerializableExceptionWrapper
- NotSerializableTransportException - Exception in org.elasticsearch.transport
- NotSerializableTransportException(Throwable) - Constructor for exception org.elasticsearch.transport.NotSerializableTransportException
- NotSerializableTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.NotSerializableTransportException
- NotXContentException - Exception in org.elasticsearch.common.compress
-
Exception indicating that we were expecting some
XContent
but could not detect its type. - NotXContentException(String) - Constructor for exception org.elasticsearch.common.compress.NotXContentException
- now() - Method in class org.elasticsearch.common.cache.Cache
-
The relative time used to track time-based evictions.
- NOW - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- nowInMillis - Variable in class org.elasticsearch.index.query.QueryRewriteContext
- nowInMillis() - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- nowInMillis() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- nowInMillis() - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
Returns the time in milliseconds that is shared across all resources involved.
- nowInMillis() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- nowInMillis() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
The time in milliseconds that is shared across all resources involved.
- nowInMillis() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- nowInMillis() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- nowWithMillisResolution() - Static method in class org.elasticsearch.common.time.DateUtils
-
Returns the current UTC date-time with milliseconds precision.
- nowWithMillisResolution(Clock) - Static method in class org.elasticsearch.common.time.DateUtils
- NULL - Enum constant in enum class org.elasticsearch.index.query.ZeroTermsQueryOption
- NULL - Static variable in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetadata
- NULL_KEY - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- NULL_OUTPUT_STREAM - Static variable in class org.elasticsearch.common.io.Streams
-
OutputStream that just throws all the bytes away
- NULL_SEPARATOR - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightUtils
- Nullability - Class in org.elasticsearch.common.inject.internal
-
Whether a member supports null values injected.
- nullInstance() - Static method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns an instance that contains no response.
- nullValue - Variable in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper
- nullValue - Variable in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- nullValueParam(Function<FieldMapper, T>, TriFunction<String, MappingParserContext, Object, T>, Supplier<T>) - Static method in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper
- NUM_PARTITIONS_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- NUMBER - Enum constant in enum class org.elasticsearch.search.aggregations.support.ValueType
- NUMBER - Enum constant in enum class org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
-
script sort for a numeric value
- NUMBER_OF_FRAGMENTS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- NUMBER_OF_SEGMENTS - Static variable in class org.elasticsearch.common.cache.Cache
- NUMBER_SIGNIFICANT_DIGITS_FIELD - Static variable in enum class org.elasticsearch.search.aggregations.metrics.PercentilesMethod
- NumberFieldMapper - Class in org.elasticsearch.index.mapper
-
A
FieldMapper
for numeric types: byte, short, int, long, float and double. - NumberFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- NumberFieldMapper.NumberFieldType - Class in org.elasticsearch.index.mapper
- NumberFieldMapper.NumberType - Enum Class in org.elasticsearch.index.mapper
- NumberFieldType(String, NumberFieldMapper.NumberType) - Constructor for class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- NumberFieldType(String, NumberFieldMapper.NumberType, boolean, boolean, boolean, boolean, Number, Map<String, String>, FieldValues<Number>, boolean, TimeSeriesParams.MetricType) - Constructor for class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- numberOfActions() - Method in class org.elasticsearch.action.bulk.BulkRequest
-
The number of actions in the bulk request.
- numberOfActions() - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
The number of actions currently in the bulk.
- numberOfFiles() - Method in exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
- numberOfFragments() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- numberOfNodesShardsAreAllocatedOn(String...) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Calculates the number of nodes that hold one or more shards of this index
IndexRoutingTable
excluding the nodes with the node ids give as theexcludedNodes
parameter. - numberOfOwningShards() - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
The number of shards on this node that will not be eventually relocated.
- numberOfOwningShardsForIndex(Index) - Method in class org.elasticsearch.cluster.routing.RoutingNode
- numberOfParts() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns number of parts
- numberOfPendingTasks() - Method in class org.elasticsearch.cluster.service.MasterService
-
Returns the number of currently pending tasks.
- numberOfReplicas(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- numberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
-
Returns the number of shards.
- numberOfShards() - Method in class org.elasticsearch.index.IndexService
- numberOfShards() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- numberOfShards() - Method in class org.elasticsearch.search.internal.SearchContext
- numberOfShards() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- numberOfShards(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- numberOfShardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
Determine the number of shards with a specific state
- numberOfSignificantValueDigits() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
-
Deprecated.
- numberOfSignificantValueDigits(int) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
-
Deprecated.
- Numbers - Class in org.elasticsearch.common
-
A set of utilities for numbers.
- NumberSortScript - Class in org.elasticsearch.script
- NumberSortScript() - Constructor for class org.elasticsearch.script.NumberSortScript
- NumberSortScript(Map<String, Object>, SearchLookup, DocReader) - Constructor for class org.elasticsearch.script.NumberSortScript
- NumberSortScript.Factory - Interface in org.elasticsearch.script
-
A factory to construct stateful
NumberSortScript
factories for a specific index. - NumberSortScript.LeafFactory - Interface in org.elasticsearch.script
-
A factory to construct
NumberSortScript
instances. - numberValue() - Method in class org.elasticsearch.search.sort.SortValue
- numDocs - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition.Stats
- numDocs() - Method in class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazySoftDeletesFilterCodecReader
- numDocs() - Method in class org.apache.lucene.index.LazySoftDeletesDirectoryReaderWrapper.LazySoftDeletesFilterLeafReader
- Numeric() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
- NUMERIC - Enum constant in enum class org.elasticsearch.index.mapper.MappedFieldType.CollapseType
- NUMERIC - Enum constant in enum class org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- NUMERIC - Enum constant in enum class org.elasticsearch.search.aggregations.support.ValueType
- NUMERIC_DETECTION - Static variable in class org.elasticsearch.index.mapper.RootObjectMapper.Defaults
- NUMERIC_PAGINATION_VERSION - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- NUMERIC_TYPE - Static variable in class org.elasticsearch.search.sort.FieldSortBuilder
- numericDetection - Variable in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- numericDetection() - Method in class org.elasticsearch.index.mapper.RootObjectMapper
-
Public API
- NumericDoubleValues - Class in org.elasticsearch.index.fielddata
-
A per-document numeric value.
- NumericDoubleValues() - Constructor for class org.elasticsearch.index.fielddata.NumericDoubleValues
-
Sole constructor.
- NumericHistogramAggregator - Class in org.elasticsearch.search.aggregations.bucket.histogram
-
An aggregator for numeric values.
- NumericHistogramAggregator(String, AggregatorFactories, double, double, BucketOrder, boolean, long, DoubleBounds, DoubleBounds, ValuesSourceConfig, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.NumericHistogramAggregator
- NumericMetricsAggregation - Interface in org.elasticsearch.search.aggregations.metrics
- NumericMetricsAggregation.MultiValue - Interface in org.elasticsearch.search.aggregations.metrics
- NumericMetricsAggregation.SingleValue - Interface in org.elasticsearch.search.aggregations.metrics
- NumericMetricsAggregator - Class in org.elasticsearch.search.aggregations.metrics
- NumericMetricsAggregator.MultiValue - Class in org.elasticsearch.search.aggregations.metrics
- NumericMetricsAggregator.SingleValue - Class in org.elasticsearch.search.aggregations.metrics
- NumericMultiValuesSource(Map<String, ValuesSourceConfig>) - Constructor for class org.elasticsearch.search.aggregations.support.MultiValuesSource.NumericMultiValuesSource
- NumericTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
- NumericTermsAggregator(String, AggregatorFactories, Function<NumericTermsAggregator, NumericTermsAggregator.ResultStrategy<?, ?>>, ValuesSource.Numeric, DocValueFormat, BucketOrder, TermsAggregator.BucketCountThresholds, AggregationContext, Aggregator, Aggregator.SubAggCollectionMode, IncludeExclude.LongFilter, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.NumericTermsAggregator
- numericType() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- numericType() - Method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
-
Get the associated numeric type
- numericValue() - Method in class org.elasticsearch.index.mapper.CustomDocValuesField
- numOfFragments - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- numOfFragments() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- numOfFragments(Integer) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set the number of fragments, defaults to
HighlightBuilder.DEFAULT_NUMBER_OF_FRAGMENTS
- numPriorUsesInASequence - Variable in class org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- numReducePhases - Variable in class org.elasticsearch.action.search.SearchResponseSections
- numTerms - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- NVD - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- NVM - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- NXYBuilder(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic.NXYBuilder
- NXYSignificanceHeuristic - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- NXYSignificanceHeuristic(boolean, boolean) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
- NXYSignificanceHeuristic(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
-
Read from a stream.
- NXYSignificanceHeuristic.Frequencies - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- NXYSignificanceHeuristic.NXYBuilder - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
O
- Object() - Constructor for class org.elasticsearch.common.collect.HppcMaps.Object
- OBJECT - Enum constant in enum class org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- OBJECT_PAGE_SIZE - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- ObjectArray<T> - Interface in org.elasticsearch.common.util
-
Abstraction of an array of object values.
- objectField(FieldInfo, Object) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- ObjectMapper - Class in org.elasticsearch.index.mapper
- ObjectMapper.Builder - Class in org.elasticsearch.index.mapper
- ObjectMapper.Defaults - Class in org.elasticsearch.index.mapper
- ObjectMapper.Dynamic - Enum Class in org.elasticsearch.index.mapper
- ObjectMapper.TypeParser - Class in org.elasticsearch.index.mapper
- objectMappers() - Method in class org.elasticsearch.index.mapper.MappingLookup
- objectPage() - Method in class org.elasticsearch.common.util.PageCacheRecycler
- ObjectParserHelper<Value,
Context> - Class in org.elasticsearch.common.xcontent -
This class provides helpers for
ObjectParser
that allow dealing with classes outside of the xcontent dependencies. - ObjectParserHelper() - Constructor for class org.elasticsearch.common.xcontent.ObjectParserHelper
- objectToBytes(Object, XContentType, int) - Static method in class org.elasticsearch.search.fetch.subphase.FetchSourcePhase
- objectToDouble(Object) - Static method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
-
Converts an Object to a double by checking it against known types first
- objectToLong(Object, boolean) - Static method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
-
Converts an Object to a
long
by checking it against known types and checking its range. - obsoleteGenerations(String, SnapshotsInProgress) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
-
Computes a map of repository shard id to set of generations, containing all shard generations that became obsolete and may be deleted from the repository as the cluster state moved from the given
old
value ofSnapshotsInProgress
to this instance. - obsoleteShardGenerations() - Method in class org.elasticsearch.repositories.FinalizeSnapshotContext
- obsoleteShardGenerations(ShardGenerations) - Method in class org.elasticsearch.repositories.ShardGenerations
-
Computes the obsolete shard index generations that can be deleted once this instance was written to the repository.
- obtain() - Method in class org.elasticsearch.common.recycler.ConcurrentDequeRecycler
- obtain() - Method in class org.elasticsearch.common.recycler.DequeRecycler
- obtain() - Method in class org.elasticsearch.common.recycler.NoneRecycler
- obtain() - Method in interface org.elasticsearch.common.recycler.Recycler
- occur - Variable in class org.elasticsearch.index.search.MatchQueryParser
- of() - Static method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- of() - Static method in class org.elasticsearch.common.collect.ImmutableOpenMap
- of(boolean) - Static method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- of(boolean, boolean) - Static method in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- of(long, long) - Static method in class org.elasticsearch.index.shard.ShardLongFieldRange
-
Construct a new
ShardLongFieldRange
with the given (inclusive) minimum and maximum. - of(String) - Static method in enum class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.SortBy
- of(String) - Static method in class org.elasticsearch.common.time.DateUtils
- of(String) - Static method in class org.elasticsearch.common.time.WriteableZoneId
- of(String) - Static method in enum class org.elasticsearch.monitor.jvm.HotThreads.ReportType
- of(String) - Static method in enum class org.elasticsearch.monitor.jvm.HotThreads.SortOrder
- of(List<SnapshotDeletionsInProgress.Entry>) - Static method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- of(Metadata, Runnable) - Static method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
-
Create
AnalysisStats
from the given cluster state. - of(Metadata, Runnable) - Static method in class org.elasticsearch.action.admin.cluster.stats.MappingStats
-
Create
MappingStats
from the given cluster state. - of(Metadata, List<ClusterStatsNodeResponse>) - Static method in class org.elasticsearch.action.admin.cluster.stats.VersionStats
- of(DiscoveryNode...) - Static method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfiguration
- of(BytesReference...) - Static method in class org.elasticsearch.common.bytes.CompositeBytesReference
- of(TimeValue, TransportRequestOptions.Type) - Static method in class org.elasticsearch.transport.TransportRequestOptions
- of(T) - Static method in class org.elasticsearch.common.inject.util.Providers
-
Returns a provider which always provides
instance
. - ofBytes(long) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
- OFF - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.DebugMode
-
debug mode is off
- offer(E) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- offer(E, long, TimeUnit) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- offer(T) - Method in class org.elasticsearch.common.collect.EvictingQueue
- offMaster() - Method in interface org.elasticsearch.cluster.LocalNodeMasterListener
-
Called when the local node used to be the master, a new master was elected and it's no longer the local node.
- offset - Variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder.AbstractDistanceScoreFunction
- offset - Variable in class org.elasticsearch.script.ScriptException.Position
- offset - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- offset - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- offset() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- offset() - Method in class org.elasticsearch.common.Rounding
-
Deprecated.We're in the process of abstracting offset *into* Rounding so keep any usage to migratory shims
- offset() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Get the offset to use when rounding, which is a number of milliseconds.
- offset() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Get the offset to use when rounding, which is a number of milliseconds.
- offset() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Get the current offset that is set on this builder.
- offset(double) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Set the offset on this builder, and return the builder so that calls can be chained.
- offset(int) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- offset(long) - Method in class org.elasticsearch.common.Rounding.Builder
-
Sets the offset of this rounding from the normal beginning of the interval.
- offset(long) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Set the offset on this builder, which is a number of milliseconds.
- offset(long) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set the offset on this builder, which is a number of milliseconds, and return the builder so that calls can be chained.
- offset(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set the offset on this builder, as a time value, and return the builder so that calls can be chained.
- OFFSET - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- OFFSET_FIELD - Static variable in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
- OFFSET_TIME_FORMATTER - Static variable in class org.elasticsearch.common.xcontent.XContentElasticsearchExtension
- offsetAttr - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- offsetContaining(long) - Method in class org.elasticsearch.common.LocalTimeOffset
-
Find the offset containing the provided time, first checking this offset, then its previous offset, the than one's previous offset, etc.
- offsetContaining(long) - Method in class org.elasticsearch.common.LocalTimeOffset.Transition
- offsets() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- offsets(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the start and stop offsets for each term if they were stored or skip offsets.
- Offsets - Enum constant in enum class org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
- OFFSETS - Enum constant in enum class org.elasticsearch.index.mapper.TextSearchInfo.TermVector
- OFFSETS - Enum constant in enum class org.elasticsearch.index.search.stats.FieldUsageStats.UsageContext
- OFFSETS - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- ofGb(long) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
- ofKb(long) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
- ofMb(long) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
- ofOrdinal(int) - Static method in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
- ofPb(long) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
- ofTb(long) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
- OK - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The request has succeeded.
- OLD - Static variable in class org.elasticsearch.monitor.jvm.GcNames
- OLD_PORT - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_SETTING_HTTP_TCP_NO_DELAY - Static variable in class org.elasticsearch.http.HttpTransportSettings
- OLD_SNAPSHOT_FORMAT - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- OLD_TCP_KEEP_ALIVE_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_TCP_NO_DELAY - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_TCP_NO_DELAY_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_TCP_RECEIVE_BUFFER_SIZE_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_TCP_REUSE_ADDRESS_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_TCP_SEND_BUFFER_SIZE_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- OLD_TRANSPORT_COMPRESS - Static variable in class org.elasticsearch.transport.TransportSettings
- oldestIndexVersion() - Method in class org.elasticsearch.cluster.metadata.Metadata
- oldestIndexVersion() - Method in class org.elasticsearch.env.NodeMetadata
- ON - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.DebugMode
-
debug mode is on
- ON_FAILURE_KEY - Static variable in class org.elasticsearch.ingest.Pipeline
- ON_FAILURE_MESSAGE_FIELD - Static variable in class org.elasticsearch.ingest.CompoundProcessor
- ON_FAILURE_PIPELINE_FIELD - Static variable in class org.elasticsearch.ingest.CompoundProcessor
- ON_FAILURE_PROCESSOR_TAG_FIELD - Static variable in class org.elasticsearch.ingest.CompoundProcessor
- ON_FAILURE_PROCESSOR_TYPE_FIELD - Static variable in class org.elasticsearch.ingest.CompoundProcessor
- ON_NEXT_INDEX_FIND_MAPPINGS_NOOP - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- onAckTimeout() - Method in interface org.elasticsearch.cluster.AckedClusterStateTaskListener
-
Called once the acknowledgement timeout defined by
AckedClusterStateUpdateTask.ackTimeout()
has expired - onAckTimeout() - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
-
Called once the acknowledgement timeout defined by
AckedClusterStateUpdateTask.ackTimeout()
has expired - onActiveMasterFound(DiscoveryNode, long) - Method in class org.elasticsearch.discovery.PeerFinder
-
Invoked on receipt of a PeersResponse from a node that believes it's an active leader, which this node should therefore try and join.
- onAfter() - Method in class org.elasticsearch.common.util.concurrent.AbstractLifecycleRunnable
-
This method is called in a finally block after successful execution or on a rejection.
- onAfter() - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
-
This method is called in a finally block after successful execution or on a rejection.
- onAfter() - Method in class org.elasticsearch.threadpool.Scheduler.ReschedulingRunnable
- onAfterInLifecycle() - Method in class org.elasticsearch.common.util.concurrent.AbstractLifecycleRunnable
-
This method is invoked in the finally block of the run method, but it is only executed if the
AbstractLifecycleRunnable.lifecycle
is not stopped or closed. - onAllNodesAcked(Exception) - Method in interface org.elasticsearch.cluster.AckedClusterStateTaskListener
-
Called once all the nodes have acknowledged the cluster state update request.
- onAllNodesAcked(Exception) - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
-
Called once all the nodes have acknowledged the cluster state update request.
- onCache(ShardId, String, Accountable) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache.Listener
-
Called after the fielddata is loaded during the cache phase
- onCache(ShardId, String, Accountable) - Method in class org.elasticsearch.index.fielddata.ShardFieldData
- onCache(ShardId, Accountable) - Method in interface org.elasticsearch.index.cache.bitset.BitsetFilterCache.Listener
-
Called for each cached bitset on the cache event.
- onCached(long) - Method in class org.elasticsearch.index.cache.bitset.ShardBitsetFilterCache
- onCached(Accountable, BytesReference) - Method in class org.elasticsearch.index.cache.request.ShardRequestCache
- onCacheEviction() - Method in class org.elasticsearch.script.ScriptMetrics
- onCancel(String, Exception) - Method in interface org.elasticsearch.common.util.CancellableThreads.OnCancel
-
Called when some running operations are cancelled or
CancellableThreads.checkForCancel()
is explicitly called. - onCancelled() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- onCancelled() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
- onCancelled() - Method in interface org.elasticsearch.tasks.CancellableTask.CancellationListener
- onCancelled() - Method in class org.elasticsearch.tasks.CancellableTask
-
Called after the task is cancelled so that it can take any actions that it has to take.
- onClose() - Method in interface org.elasticsearch.cluster.TimeoutClusterStateListener
- onClose(Object) - Method in interface org.elasticsearch.indices.ESCacheHelper.ClosedListener
- onClose(IndexReader.CacheKey) - Method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- onClose(ShardId) - Method in class org.elasticsearch.indices.IndicesQueryCache
- onClusterServiceClose() - Method in interface org.elasticsearch.cluster.ClusterStateObserver.Listener
-
called when the cluster service is closed
- onClusterServiceClose() - Method in class org.elasticsearch.common.logging.NodeAndClusterIdStateListener
- onClusterStateApplied() - Method in class org.elasticsearch.cluster.coordination.JoinHelper
- onClusterStateCommitted(String, ActionListener<Void>) - Method in interface org.elasticsearch.discovery.zen.PublishClusterStateAction.IncomingClusterStateListener
-
called when a cluster state has been committed and is ready to be processed
- onClusterStateCommitted(String, ActionListener<Void>) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- onCommit(List<? extends IndexCommit>) - Method in class org.elasticsearch.index.engine.CombinedDeletionPolicy
- onCommit(TimeValue) - Method in interface org.elasticsearch.cluster.coordination.ClusterStatePublisher.AckListener
-
Should be called when the cluster coordination layer has committed the cluster state (i.e.
- onCompilation() - Method in class org.elasticsearch.script.ScriptMetrics
- onCompilationLimit() - Method in class org.elasticsearch.script.ScriptMetrics
- onCompletion() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- onCompletion() - Method in class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
-
Invoked once all write chunks/parts are ready to be combined into the final blob.
- onCompletion(boolean) - Method in class org.elasticsearch.cluster.coordination.Publication
- onConnectionClosed(Transport.Connection) - Method in class org.elasticsearch.transport.ConnectionManager.DelegatingNodeConnectionListener
- onConnectionClosed(Transport.Connection) - Method in interface org.elasticsearch.transport.TransportConnectionListener
-
Called once a connection ws closed.
- onConnectionClosed(Transport.Connection) - Method in class org.elasticsearch.transport.TransportService
- onConnectionOpened(Transport.Connection) - Method in class org.elasticsearch.transport.ConnectionManager.DelegatingNodeConnectionListener
- onConnectionOpened(Transport.Connection) - Method in interface org.elasticsearch.transport.TransportConnectionListener
-
Called once a connection was opened
- onDirectoryCreated(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every new subdirectory found in the watched directory
- onDirectoryDeleted(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every file that disappeared in the watched directory
- onDirectoryInit(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every subdirectory found in the watched directory during initialization
- onDocValuesUsed(String) - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker.FieldUsageStatsTrackingSession
- onDocValuesUsed(String) - Method in interface org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader.FieldUsageNotifier
- ONE - Enum constant in enum class org.elasticsearch.indices.analysis.PreBuiltCacheFactory.CachingStrategy
- ONE - Enum constant in enum class org.elasticsearch.search.aggregations.AggregationBuilder.BucketCardinality
- ONE - Static variable in class org.elasticsearch.action.support.ActiveShardCount
- ONE - Static variable in class org.elasticsearch.common.unit.ByteSizeValue
- ONE - Static variable in class org.elasticsearch.common.unit.Fuzziness
- ONE - Static variable in class org.elasticsearch.search.aggregations.CardinalityUpperBound
-
Aggregator
s with this cardinality will collect be collected once or zero times. - onElectedAsMaster(ClusterState) - Method in interface org.elasticsearch.discovery.zen.NodeJoinController.ElectionCallback
-
called when the local node is successfully elected as master Guaranteed to be called on the cluster state update thread
- OneMergeHelper - Class in org.apache.lucene.index
-
Allows pkg private access
- onEmptyQueue() - Method in interface org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.StarvationWatcher
-
Called before and after the execution of each task if the queue is empty (excluding the task being executed)
- onError() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- onException(HttpChannel, Exception) - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- onException(TcpChannel, Exception) - Method in class org.elasticsearch.transport.TcpTransport
- onFailedEngine(String, Exception) - Method in interface org.elasticsearch.index.engine.Engine.EventListener
-
Called when a fatal exception occurred
- onFailedFetchPhase(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onFailedFetchPhase(SearchContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onFailedFetchPhase(SearchContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed if a fetch phased failed.
- onFailedQueryPhase(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onFailedQueryPhase(SearchContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onFailedQueryPhase(SearchContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed if a query phased failed.
- onFailure() - Method in class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
-
Invoked in case writing all chunks of data to storage failed.
- onFailure(Exception) - Method in class org.elasticsearch.action.ActionListener.Delegating
- onFailure(Exception) - Method in class org.elasticsearch.action.ActionListener.DelegatingActionListener
- onFailure(Exception) - Method in interface org.elasticsearch.action.ActionListener
-
A failure caused by an exception at some phase of the task.
- onFailure(Exception) - Method in class org.elasticsearch.action.ActionListener.RunAfterActionListener
- onFailure(Exception) - Method in class org.elasticsearch.action.ActionListener.RunBeforeActionListener
- onFailure(Exception) - Method in class org.elasticsearch.action.ActionRunnable
-
Calls the action listeners
ActionListener.onFailure(Exception)
method with the given exception. - onFailure(Exception) - Method in class org.elasticsearch.action.LatchedActionListener
- onFailure(Exception) - Method in class org.elasticsearch.action.NotifyOnceListener
- onFailure(Exception) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- onFailure(Exception) - Method in class org.elasticsearch.action.support.ChannelActionListener
- onFailure(Exception) - Method in class org.elasticsearch.action.support.ContextPreservingActionListener
- onFailure(Exception) - Method in class org.elasticsearch.action.support.GroupedActionListener
- onFailure(Exception) - Method in class org.elasticsearch.action.support.ThreadedActionListener
- onFailure(Exception) - Method in interface org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutListener
- onFailure(Exception) - Method in interface org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.RemoveListener
- onFailure(Exception) - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
-
This method is invoked for all exception thrown by
AbstractRunnable.doRun()
- onFailure(Exception) - Method in class org.elasticsearch.common.util.concurrent.ListenableFuture
- onFailure(Exception) - Method in interface org.elasticsearch.discovery.zen.MembershipAction.JoinCallback
- onFailure(Exception) - Method in class org.elasticsearch.repositories.GetSnapshotInfoContext
- onFailure(Exception) - Method in class org.elasticsearch.rest.action.RestActionListener
- onFailure(Exception) - Method in class org.elasticsearch.threadpool.Scheduler.ReschedulingRunnable
- onFailure(Iterable<ActionListener<Response>>, Exception) - Static method in interface org.elasticsearch.action.ActionListener
-
Notifies every given listener with the failure passed to
ActionListener.onFailure(Exception)
. - onFailure(String) - Method in interface org.elasticsearch.gateway.Gateway.GatewayStateRecoveredListener
- onFailure(String, Exception) - Method in class org.elasticsearch.cluster.AckedClusterStateUpdateTask
- onFailure(String, Exception) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardStartedClusterStateTaskExecutor
- onFailure(String, Exception) - Method in interface org.elasticsearch.cluster.ClusterStateTaskListener
-
A callback for when task execution fails.
- onFailure(String, Exception) - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
-
A callback for when task execution fails.
- onFailure(String, Exception) - Method in class org.elasticsearch.cluster.coordination.NodeRemovalClusterStateTaskExecutor
- onFailure(String, Exception) - Method in class org.elasticsearch.cluster.metadata.SystemIndexMetadataUpgradeService.SystemIndexMetadataUpdateTask
- onFailure(String, Exception) - Method in class org.elasticsearch.upgrades.MigrationResultsUpdateTask
- onFailure(Throwable) - Method in interface org.elasticsearch.discovery.zen.NodeJoinController.ElectionCallback
-
called when the local node failed to be elected as master Guaranteed to be called on the cluster state update thread
- onFailure(DiscoveryNode, Exception) - Method in class org.elasticsearch.discovery.AckClusterStatePublishResponseHandler
- onFailure(DiscoveryNode, Exception) - Method in class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
Called for each failure obtained from non master nodes
- onFailure(Task, Exception) - Method in class org.elasticsearch.tasks.LoggingTaskListener
- onFailure(Task, Exception) - Method in interface org.elasticsearch.tasks.TaskListener
-
A failure caused by an exception at some phase of the task.
- onFaultyNode(DiscoveryNode) - Method in class org.elasticsearch.cluster.coordination.Publication
- onFetchFailure(int, SearchShardTarget, Exception) - Method in class org.elasticsearch.action.search.SearchProgressListener
-
Executed when a shard reports a fetch failure.
- onFetchPhase(SearchContext, long) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onFetchPhase(SearchContext, long) - Method in class org.elasticsearch.index.SearchSlowLog
- onFetchPhase(SearchContext, long) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onFetchPhase(SearchContext, long) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed after the fetch phase successfully finished.
- onFetchResult(int) - Method in class org.elasticsearch.action.search.SearchProgressListener
-
Executed when a shard returns a fetch result.
- onFileChanged(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every file that was changed in the watched directory
- onFileCreated(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every new file found in the watched directory
- onFileDeleted(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every file that disappeared in the watched directory
- onFileInit(Path) - Method in interface org.elasticsearch.watcher.FileChangesListener
-
Called for every file found in the watched directory during initialization
- onFinalReduce(List<SearchShard>, TotalHits, InternalAggregations, int) - Method in class org.elasticsearch.action.search.SearchProgressListener
-
Executed once when the final reduce is created.
- onFinished() - Method in class org.elasticsearch.action.support.RetryableAction
- onFoundPeersUpdated() - Method in class org.elasticsearch.discovery.PeerFinder
-
Invoked when the set of found peers changes.
- onFreeReaderContext(ReaderContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onFreeReaderContext(ReaderContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onFreeReaderContext(ReaderContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed when a previously created reader context is freed.
- onFreeScrollContext(ReaderContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onFreeScrollContext(ReaderContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onFreeScrollContext(ReaderContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed when a scroll search
SearchContext
is freed. - OnGoingMerge - Class in org.elasticsearch.index.merge
-
Represents a single on going merge within an index.
- OnGoingMerge(MergePolicy.OneMerge) - Constructor for class org.elasticsearch.index.merge.OnGoingMerge
- onHit() - Method in class org.elasticsearch.index.cache.request.ShardRequestCache
- onIncomingClusterState(ClusterState) - Method in interface org.elasticsearch.discovery.zen.PublishClusterStateAction.IncomingClusterStateListener
-
called when a new incoming cluster state has been received.
- onIncomingClusterState(ClusterState) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- onIndexModule(IndexModule) - Method in class org.elasticsearch.plugins.Plugin
-
Called before a new index is created on a node.
- onIndexModule(IndexModule) - Method in class org.elasticsearch.plugins.PluginsService
- onInit(List<? extends IndexCommit>) - Method in class org.elasticsearch.index.engine.CombinedDeletionPolicy
- onJoin(Join) - Method in class org.elasticsearch.cluster.coordination.Publication
- onJoin(DiscoveryNode, MembershipAction.JoinCallback) - Method in interface org.elasticsearch.discovery.zen.MembershipAction.MembershipListener
- onLagDetected(DiscoveryNode, long, long) - Method in interface org.elasticsearch.cluster.coordination.LagDetector.LagListener
-
Called when a node is detected as lagging and should be removed from the cluster.
- onLeave(DiscoveryNode) - Method in interface org.elasticsearch.discovery.zen.MembershipAction.MembershipListener
- onListShards(List<SearchShard>, List<SearchShard>, SearchResponse.Clusters, boolean) - Method in class org.elasticsearch.action.search.SearchProgressListener
-
Executed when shards are ready to be queried.
- only(Object) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches objects equal to the given object.
- ONLY_EXPUNGE_DELETES - Static variable in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest.Defaults
- ONLY_LOCAL - Enum constant in enum class org.elasticsearch.cluster.routing.Preference
-
Route to the local shard only
- ONLY_NODES - Enum constant in enum class org.elasticsearch.cluster.routing.Preference
-
Route to only node with attribute
- onlyExpungeDeletes() - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Should the merge only expunge deletes from the index, without full merging.
- onlyExpungeDeletes(boolean) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
-
Should the merge only expunge deletes from the index, without full merge.
- onlyNodeActiveInitializingShardsIt(String) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- onlyNodeSelectorActiveInitializingShardsIt(String[], DiscoveryNodes) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns shards based on nodeAttributes given such as node name , node attribute, node IP Supports node specifications in cluster API
- onlyNodeSelectorActiveInitializingShardsIt(String, DiscoveryNodes) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- onMaster() - Method in interface org.elasticsearch.cluster.LocalNodeMasterListener
-
Called when local node is elected to be the master
- onMasterFailure(DiscoveryNode, Throwable, String) - Method in interface org.elasticsearch.discovery.zen.MasterFaultDetection.Listener
-
called when pinging the master failed, like a timeout, transport disconnects etc
- onMiss() - Method in class org.elasticsearch.index.cache.request.ShardRequestCache
- onMissingJoin(DiscoveryNode) - Method in class org.elasticsearch.cluster.coordination.Publication
- onNewClusterState(String, Supplier<ClusterState>, ActionListener<Void>) - Method in interface org.elasticsearch.cluster.service.ClusterApplier
-
Method to invoke when a new cluster state is available to be applied
- onNewClusterState(String, Supplier<ClusterState>, ActionListener<Void>) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- onNewClusterState(ClusterState) - Method in interface org.elasticsearch.cluster.ClusterStateObserver.Listener
-
called when a new state is observed
- onNewClusterState(ClusterState) - Method in class org.elasticsearch.common.logging.NodeAndClusterIdStateListener
- onNewInfo(ClusterInfo) - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdMonitor
- onNewReaderContext(ReaderContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onNewReaderContext(ReaderContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onNewReaderContext(ReaderContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed when a new reader context was created
- onNewResource(Source) - Method in class org.elasticsearch.indices.recovery.MultiChunkTransfer
-
This method is called when starting sending/requesting a new source.
- onNewScrollContext(ReaderContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onNewScrollContext(ReaderContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onNewScrollContext(ReaderContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed when a new scroll search
ReaderContext
was created - onNodeAck(DiscoveryNode, Exception) - Method in interface org.elasticsearch.cluster.coordination.ClusterStatePublisher.AckListener
-
Should be called whenever the cluster coordination layer receives confirmation from a node that it has successfully applied the cluster state.
- onNodeConnected(DiscoveryNode, Transport.Connection) - Method in class org.elasticsearch.transport.ConnectionManager.DelegatingNodeConnectionListener
- onNodeConnected(DiscoveryNode, Transport.Connection) - Method in interface org.elasticsearch.transport.TransportConnectionListener
-
Called once a node connection is opened and registered.
- onNodeDisconnected(DiscoveryNode, Exception) - Method in interface org.elasticsearch.client.transport.TransportClient.HostFailureListener
-
Deprecated.Called once a node disconnect is detected.
- onNodeDisconnected(DiscoveryNode, Transport.Connection) - Method in class org.elasticsearch.transport.ConnectionManager.DelegatingNodeConnectionListener
- onNodeDisconnected(DiscoveryNode, Transport.Connection) - Method in class org.elasticsearch.transport.RemoteConnectionStrategy
- onNodeDisconnected(DiscoveryNode, Transport.Connection) - Method in interface org.elasticsearch.transport.TransportConnectionListener
-
Called once a node connection is closed and unregistered.
- onNodeFailure(DiscoveryNode, int, Throwable) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- onNodeFailure(DiscoveryNode, String) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection.Listener
- onNodeResponse(DiscoveryNode, int, TransportBroadcastByNodeAction.NodeResponse) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- onNodeStarted() - Method in interface org.elasticsearch.plugins.ClusterPlugin
-
Called when the node is started
- onNoLongerMaster(String) - Method in interface org.elasticsearch.cluster.ClusterStateTaskListener
-
A callback for when the task was rejected because the processing node is no longer the elected master.
- onNoLongerMaster(String) - Method in class org.elasticsearch.cluster.coordination.NodeRemovalClusterStateTaskExecutor
- onNonemptyQueue() - Method in interface org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.StarvationWatcher
-
Called after the execution of each task if the queue is nonempty (excluding the task being executed)
- onNormsUsed(String) - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker.FieldUsageStatsTrackingSession
- onNormsUsed(String) - Method in interface org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader.FieldUsageNotifier
- onOffsetsUsed(String) - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker.FieldUsageStatsTrackingSession
- onOffsetsUsed(String) - Method in interface org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader.FieldUsageNotifier
- onOperation(ShardRouting, int, ShardResponse) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- onOrAfter(Version) - Method in class org.elasticsearch.Version
- onOrBefore(Version) - Method in class org.elasticsearch.Version
- onOutOfMemoryError() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- onPartialReduce(List<SearchShard>, TotalHits, InternalAggregations, int) - Method in class org.elasticsearch.action.search.SearchProgressListener
-
Executed when a partial reduce is created.
- onPause(long) - Method in interface org.elasticsearch.index.snapshots.blobstore.RateLimitingInputStream.Listener
- onPayloadsUsed(String) - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker.FieldUsageStatsTrackingSession
- onPayloadsUsed(String) - Method in interface org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader.FieldUsageNotifier
- onPingReceived(NodesFaultDetection.PingRequest) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection.Listener
- onPointsUsed(String) - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker.FieldUsageStatsTrackingSession
- onPointsUsed(String) - Method in interface org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader.FieldUsageNotifier
- onPortNumber(int) - Method in interface org.elasticsearch.common.transport.PortsRange.PortCallback
- onPositionsUsed(String) - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker.FieldUsageStatsTrackingSession
- onPositionsUsed(String) - Method in interface org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader.FieldUsageNotifier
- onPostingsUsed(String) - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker.FieldUsageStatsTrackingSession
- onPostingsUsed(String) - Method in interface org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader.FieldUsageNotifier
- onPostWarm(long) - Method in class org.elasticsearch.index.warmer.ShardIndexWarmerService
- onPreFetchPhase(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onPreFetchPhase(SearchContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onPreFetchPhase(SearchContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed before the fetch phase is executed
- onPreQueryPhase(SearchContext) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onPreQueryPhase(SearchContext) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onPreQueryPhase(SearchContext) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed before the query phase is executed
- onPreWarm() - Method in class org.elasticsearch.index.warmer.ShardIndexWarmerService
- onQueryFailure(int, SearchShardTarget, Exception) - Method in class org.elasticsearch.action.search.SearchProgressListener
-
Executed when a shard reports a query failure.
- onQueryPhase(SearchContext, long) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
- onQueryPhase(SearchContext, long) - Method in class org.elasticsearch.index.SearchSlowLog
- onQueryPhase(SearchContext, long) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- onQueryPhase(SearchContext, long) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed after the query phase successfully finished.
- onQueryResult(int) - Method in class org.elasticsearch.action.search.SearchProgressListener
-
Executed when a shard returns a query result.
- onRecoveryDone(RecoveryState, ShardLongFieldRange) - Method in interface org.elasticsearch.indices.recovery.PeerRecoveryTargetService.RecoveryListener
- onRecoveryFailure(RecoveryState, RecoveryFailedException, boolean) - Method in interface org.elasticsearch.indices.recovery.PeerRecoveryTargetService.RecoveryListener
- onRejection(Exception) - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
-
This should be executed if the thread-pool executing this action rejected the execution.
- onRejection(Exception) - Method in interface org.elasticsearch.index.reindex.RejectAwareActionListener
- onRejection(Exception) - Method in class org.elasticsearch.threadpool.Scheduler.ReschedulingRunnable
- onRemoval(long) - Method in class org.elasticsearch.index.cache.bitset.ShardBitsetFilterCache
- onRemoval(Accountable, BytesReference, boolean) - Method in class org.elasticsearch.index.cache.request.ShardRequestCache
- onRemoval(RemovalNotification<K, V>) - Method in interface org.elasticsearch.common.cache.RemovalListener
- onRemoval(RemovalNotification<IndexReader.CacheKey, Cache<Query, BitsetFilterCache.Value>>) - Method in class org.elasticsearch.index.cache.bitset.BitsetFilterCache
- onRemoval(RemovalNotification<IndicesFieldDataCache.Key, Accountable>) - Method in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache
- onRemoval(RemovalNotification<IndicesRequestCache.Key, BytesReference>) - Method in class org.elasticsearch.indices.IndicesRequestCache
- onRemoval(ShardId, String, boolean, long) - Method in interface org.elasticsearch.index.fielddata.IndexFieldDataCache.Listener
-
Called after the fielddata is unloaded
- onRemoval(ShardId, String, boolean, long) - Method in class org.elasticsearch.index.fielddata.ShardFieldData
- onRemoval(ShardId, Accountable) - Method in interface org.elasticsearch.index.cache.bitset.BitsetFilterCache.Listener
-
Called for each cached bitset on the removal event.
- onRemoved() - Method in class org.elasticsearch.transport.CloseableConnection
- onRemoved() - Method in interface org.elasticsearch.transport.Transport.Connection
-
Called after this connection is removed from the transport service.
- onRequestReceived(long, String) - Method in interface org.elasticsearch.transport.TransportMessageListener
-
Called once a request is received
- onRequestReceived(long, String) - Method in class org.elasticsearch.transport.TransportService
-
called by the
Transport
implementation when an incoming request arrives but before any parsing of it has happened (with the exception of the requestId and action) - onRequestSent(DiscoveryNode, long, String, TransportRequest, TransportRequestOptions) - Method in interface org.elasticsearch.transport.TransportMessageListener
-
Called for every request sent to a server after the request has been passed to the underlying network implementation
- onRequestSent(DiscoveryNode, long, String, TransportRequest, TransportRequestOptions) - Method in class org.elasticsearch.transport.TransportService
-
called by the
Transport
implementation once a request has been sent - onResponse(Iterable<ActionListener<Response>>, Response) - Static method in interface org.elasticsearch.action.ActionListener
-
Notifies every given listener with the response passed to
ActionListener.onResponse(Object)
. - onResponse(L) - Method in class org.elasticsearch.action.support.AdapterActionFuture
- onResponse(AcknowledgedResponse) - Method in interface org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.RemoveListener
- onResponse(MetadataIndexTemplateService.PutResponse) - Method in interface org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutListener
- onResponse(DiscoveryNode) - Method in class org.elasticsearch.discovery.AckClusterStatePublishResponseHandler
- onResponse(DiscoveryNode) - Method in class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
Called for each response obtained from non master nodes
- onResponse(Tuple<RepositoryData, SnapshotInfo>) - Method in class org.elasticsearch.repositories.FinalizeSnapshotContext
- onResponse(ShardSnapshotResult) - Method in class org.elasticsearch.repositories.SnapshotShardContext
- onResponse(SearchPhaseResult) - Method in class org.elasticsearch.action.search.SearchExecutionStatsCollector
- onResponse(SnapshotInfo) - Method in class org.elasticsearch.repositories.GetSnapshotInfoContext
- onResponse(Task, Response) - Method in class org.elasticsearch.tasks.LoggingTaskListener
- onResponse(Task, Response) - Method in interface org.elasticsearch.tasks.TaskListener
-
Handle task response.
- onResponse(R) - Method in class org.elasticsearch.action.support.ContextPreservingActionListener
- onResponse(Response) - Method in class org.elasticsearch.action.ActionListener.MappedActionListener
- onResponse(Response) - Method in interface org.elasticsearch.action.ActionListener
-
Handle action response.
- onResponse(Response) - Method in class org.elasticsearch.action.NotifyOnceListener
- onResponse(Response) - Method in class org.elasticsearch.action.support.ChannelActionListener
- onResponse(Response) - Method in class org.elasticsearch.action.support.ThreadedActionListener
- onResponse(Response) - Method in class org.elasticsearch.rest.action.RestActionListener
- onResponse(T) - Method in class org.elasticsearch.action.ActionListener.DelegatingActionListener
- onResponse(T) - Method in class org.elasticsearch.action.ActionListener.DelegatingFailureActionListener
- onResponse(T) - Method in class org.elasticsearch.action.ActionListener.RunAfterActionListener
- onResponse(T) - Method in class org.elasticsearch.action.ActionListener.RunBeforeActionListener
- onResponse(T) - Method in class org.elasticsearch.action.LatchedActionListener
- onResponse(T) - Method in class org.elasticsearch.action.support.GroupedActionListener
- onResponse(V) - Method in class org.elasticsearch.common.util.concurrent.ListenableFuture
- onResponseReceived(long, Transport.ResponseContext) - Method in interface org.elasticsearch.transport.TransportMessageListener
-
Called for every response received
- onResponseReceived(long, Transport.ResponseContext) - Method in class org.elasticsearch.transport.TransportService
- onResponseReceived(long, TransportMessageListener) - Method in class org.elasticsearch.transport.Transport.ResponseHandlers
-
called by the
Transport
implementation when a response or an exception has been received for a previously sent request (before any processing or deserialization was done). - onResponseSent(long, String, Exception) - Method in interface org.elasticsearch.transport.TransportMessageListener
-
Called for every failed action response after the response has been passed to the underlying network implementation.
- onResponseSent(long, String, Exception) - Method in class org.elasticsearch.transport.TransportService
-
called by the
Transport
implementation after an exception was sent as a response to an incoming request - onResponseSent(long, String, TransportResponse) - Method in interface org.elasticsearch.transport.TransportMessageListener
-
Called for every action response sent after the response has been passed to the underlying network implementation.
- onResponseSent(long, String, TransportResponse) - Method in class org.elasticsearch.transport.TransportService
-
called by the
Transport
implementation once a response was sent to calling node - onRetry() - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- onRetry() - Method in class org.elasticsearch.action.index.IndexRequest
- onRetry() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
This method is called before this replication request is retried the first time.
- onScriptError - Variable in class org.elasticsearch.index.mapper.FieldMapper
- onScriptErrorParam(Function<FieldMapper, String>, FieldMapper.Parameter<Script>) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Defines an on_script_error parameter
- onServerException(HttpServerChannel, Exception) - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- onServerException(TcpServerChannel, Exception) - Method in class org.elasticsearch.transport.TcpTransport
- onSettingsChanged() - Method in class org.elasticsearch.index.shard.IndexShard
- onSettingsChanged(TimeValue, ByteSizeValue, long) - Method in class org.elasticsearch.index.engine.Engine
- onSettingsChanged(TimeValue, ByteSizeValue, long) - Method in class org.elasticsearch.index.engine.InternalEngine
- onShardInactive(IndexShard) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called when a shard is marked as inactive
- onShardInactive(IndexShard) - Method in class org.elasticsearch.indices.flush.SyncedFlushService
- onSliceFailure(ActionListener<BulkByScrollResponse>, int, Exception) - Method in class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
-
Record a failure from a slice and respond to the listener if the request is finished.
- onSliceResponse(ActionListener<BulkByScrollResponse>, int, BulkByScrollResponse) - Method in class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
-
Record a response from a slice and respond to the listener if the request is finished.
- onStoreClosed(ShardId) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called when the given shards store is closed.
- onStoreCreated(ShardId) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called when the given shards store is created.
- onStoredFieldsUsed(String) - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker.FieldUsageStatsTrackingSession
- onStoredFieldsUsed(String) - Method in interface org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader.FieldUsageNotifier
- onSuccess() - Method in interface org.elasticsearch.discovery.zen.MembershipAction.JoinCallback
- onSuccess(ClusterState) - Method in interface org.elasticsearch.gateway.Gateway.GatewayStateRecoveredListener
- onTermFrequenciesUsed(String) - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker.FieldUsageStatsTrackingSession
- onTermFrequenciesUsed(String) - Method in interface org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader.FieldUsageNotifier
- onTerminated() - Method in interface org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor.ShutdownListener
- onTermsUsed(String) - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker.FieldUsageStatsTrackingSession
- onTermsUsed(String) - Method in interface org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader.FieldUsageNotifier
- onTermVectorsUsed(String) - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker.FieldUsageStatsTrackingSession
- onTermVectorsUsed(String) - Method in interface org.elasticsearch.search.internal.FieldUsageTrackingDirectoryReader.FieldUsageNotifier
- onTimeout(List<? extends TaskBatcher.BatchedTask>, TimeValue) - Method in class org.elasticsearch.cluster.service.TaskBatcher
-
Action to be implemented by the specific batching implementation.
- onTimeout(TimeValue) - Method in interface org.elasticsearch.cluster.ClusterStateObserver.Listener
- onTimeout(TimeValue) - Method in interface org.elasticsearch.cluster.TimeoutClusterStateListener
- onTimeout(TimeValue) - Method in class org.elasticsearch.common.logging.NodeAndClusterIdStateListener
- onTimeout(TimeValue) - Method in interface org.elasticsearch.persistent.PersistentTasksService.WaitForPersistentTaskListener
- OP - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- open(FileChannel, Path, Checkpoint, String) - Static method in class org.elasticsearch.index.translog.TranslogReader
-
Given a file channel, opens a
TranslogReader
, taking care of checking and validating the file header. - open(Path) - Method in interface org.elasticsearch.index.translog.ChannelFactory
- open(Path, OpenOption...) - Method in interface org.elasticsearch.index.translog.ChannelFactory
- open(IndexCommit) - Method in class org.elasticsearch.index.engine.NoOpEngine
- open(IndexCommit) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- open(OpenIndexRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Open an index based on the index name.
- open(OpenIndexRequest, ActionListener<OpenIndexResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Open an index based on the index name.
- OPEN - Enum constant in enum class org.elasticsearch.action.support.IndicesOptions.WildcardStates
- OPEN - Enum constant in enum class org.elasticsearch.cluster.metadata.IndexMetadata.State
- OPEN_SHARD_READER_CONTEXT_NAME - Static variable in class org.elasticsearch.action.search.TransportOpenPointInTimeAction
- openAndPutIndexOutput(String, StoreFileMetadata, Store) - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
-
Creates an
IndexOutput
for the given file name. - openConnection(DiscoveryNode, ConnectionProfile) - Method in class org.elasticsearch.transport.TransportService
-
Establishes and returns a new connection to the given node.
- openConnection(DiscoveryNode, ConnectionProfile, ActionListener<Transport.Connection>) - Method in class org.elasticsearch.transport.ClusterConnectionManager
- openConnection(DiscoveryNode, ConnectionProfile, ActionListener<Transport.Connection>) - Method in interface org.elasticsearch.transport.ConnectionManager
- openConnection(DiscoveryNode, ConnectionProfile, ActionListener<Transport.Connection>) - Method in class org.elasticsearch.transport.RemoteConnectionManager
- openConnection(DiscoveryNode, ConnectionProfile, ActionListener<Transport.Connection>) - Method in class org.elasticsearch.transport.TcpTransport
- openConnection(DiscoveryNode, ConnectionProfile, ActionListener<Transport.Connection>) - Method in interface org.elasticsearch.transport.Transport
-
Opens a new connection to the given node.
- openConnection(DiscoveryNode, ConnectionProfile, ActionListener<Transport.Connection>) - Method in class org.elasticsearch.transport.TransportService
-
Establishes a new connection to the given node.
- openDirectory(Directory, boolean) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- openEngineAndRecoverFromTranslog() - Method in class org.elasticsearch.index.shard.IndexShard
-
opens the engine on top of the existing lucene engine and translog.
- openEngineAndSkipTranslogRecovery() - Method in class org.elasticsearch.index.shard.IndexShard
-
Opens the engine on top of the existing lucene engine and translog.
- openFileURLStream(URL) - Static method in class org.elasticsearch.common.io.FileSystemUtils
-
Returns an InputStream the given url if the url has a protocol of 'file' or 'jar', no host, and no port.
- openIndex(OpenIndexClusterStateUpdateRequest, ActionListener<ShardsAcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexStateService
- OpenIndexAction - Class in org.elasticsearch.action.admin.indices.open
- OpenIndexClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.open
-
Cluster state update request that allows to open one or more indices
- OpenIndexClusterStateUpdateRequest() - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexClusterStateUpdateRequest
- openIndexRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Creates an open index request.
- OpenIndexRequest - Class in org.elasticsearch.action.admin.indices.open
-
A request to open an index.
- OpenIndexRequest() - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
- OpenIndexRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
Constructs a new open index request for the specified index.
- OpenIndexRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
- OpenIndexRequestBuilder - Class in org.elasticsearch.action.admin.indices.open
-
Builder for for open index request
- OpenIndexRequestBuilder(ElasticsearchClient, OpenIndexAction) - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
- OpenIndexRequestBuilder(ElasticsearchClient, OpenIndexAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
- OpenIndexResponse - Class in org.elasticsearch.action.admin.indices.open
-
A response for a open index action.
- OpenIndexResponse(boolean, boolean) - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexResponse
- OpenIndexResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.open.OpenIndexResponse
- openOrGetStreamInput() - Method in class org.elasticsearch.transport.InboundMessage
- OpenPointInTimeAction - Class in org.elasticsearch.action.search
- OpenPointInTimeRequest - Class in org.elasticsearch.action.search
- OpenPointInTimeRequest(String...) - Constructor for class org.elasticsearch.action.search.OpenPointInTimeRequest
- OpenPointInTimeRequest(StreamInput) - Constructor for class org.elasticsearch.action.search.OpenPointInTimeRequest
- OpenPointInTimeResponse - Class in org.elasticsearch.action.search
- OpenPointInTimeResponse(String) - Constructor for class org.elasticsearch.action.search.OpenPointInTimeResponse
- OpenPointInTimeResponse(StreamInput) - Constructor for class org.elasticsearch.action.search.OpenPointInTimeResponse
- openReaderContext(ShardId, TimeValue, ActionListener<ShardSearchContextId>) - Method in class org.elasticsearch.search.SearchService
-
Opens the reader context for given shardId.
- openSlice(int) - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
-
Called for each logical slice given a zero based slice ordinal.
- openVerifyingInput(String, IOContext, StoreFileMetadata) - Method in class org.elasticsearch.index.store.Store
- Operation(Term, long, long, long, VersionType, Engine.Operation.Origin, long) - Constructor for class org.elasticsearch.index.engine.Engine.Operation
- OPERATION - Enum constant in enum class org.elasticsearch.action.ThreadingModel
- OPERATION_LISTENER - Enum constant in enum class org.elasticsearch.action.ThreadingModel
- operationRouting() - Method in class org.elasticsearch.cluster.service.ClusterService
- OperationRouting - Class in org.elasticsearch.cluster.routing
- OperationRouting(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.OperationRouting
- operations() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- operations() - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- OPERATIONS_BLOCKED - Static variable in class org.elasticsearch.index.shard.IndexShard
- operationType() - Method in class org.elasticsearch.index.engine.Engine.Delete
- operationType() - Method in class org.elasticsearch.index.engine.Engine.Index
- operationType() - Method in class org.elasticsearch.index.engine.Engine.NoOp
- operationType() - Method in class org.elasticsearch.index.engine.Engine.Operation
- operator() - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- operator() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Returns the operator to use in a boolean query.
- operator() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Returns the operator to use in a boolean query.
- operator() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- operator(Operator) - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
-
Sets the operator to use for the top-level boolean query.
- operator(Operator) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Sets the operator to use when using a boolean query.
- operator(Operator) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets the operator to use when using a boolean query.
- operator(Operator) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Sets the operator to use when using a boolean query.
- Operator - Enum Class in org.elasticsearch.index.query
- OPERATOR_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- OperatorDynamic - Enum constant in enum class org.elasticsearch.common.settings.Setting.Property
-
Operator only Dynamic setting
- Option(int, Text, float, Map<String, Set<String>>) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- Option(StreamInput) - Constructor for class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- Option(StreamInput) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry.Option
- Option(StreamInput) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- Option(StreamInput) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- Option(Text, float) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- Option(Text, int, float) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- Option(Text, Text, float) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry.Option
- Option(Text, Text, float) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- Option(Text, Text, float, Boolean) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry.Option
- Option(Text, Text, float, Boolean) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- optional() - Element in annotation interface org.elasticsearch.common.inject.Inject
-
If true, and the appropriate binding is not found, the Injector will skip injection of this method or field rather than produce an error.
- optionalConstructor(Constructor) - Method in class org.elasticsearch.common.inject.internal.Errors
- options - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- options - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- options() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- options() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- options(Map<String, Object>) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Allows to set custom options for custom highlighters.
- OPTIONS - Enum constant in enum class org.elasticsearch.rest.RestRequest.Method
- OPTIONS - Static variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- OPTIONS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- OPTIONS_PARSE_FIELD - Static variable in class org.elasticsearch.script.Script
-
Standard
ParseField
for options on the inner level. - OPTIONS_PARSE_FIELD - Static variable in class org.elasticsearch.script.StoredScriptSource
-
Standard
ParseField
for options on the inner level. - opType() - Method in class org.elasticsearch.action.delete.DeleteRequest
- opType() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the requested document operation type of the request
- opType() - Method in class org.elasticsearch.action.index.IndexRequest
- opType() - Method in class org.elasticsearch.action.update.UpdateRequest
- opType() - Method in class org.elasticsearch.index.translog.Translog.Delete
- opType() - Method in class org.elasticsearch.index.translog.Translog.Index
- opType() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- opType() - Method in interface org.elasticsearch.index.translog.Translog.Operation
- opType(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets a string representation of the
IndexRequest.opType(OpType)
. - opType(DocWriteRequest.OpType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the type of operation to perform.
- or(Matcher<? super T>) - Method in class org.elasticsearch.common.inject.matcher.AbstractMatcher
- or(Matcher<? super T>) - Method in interface org.elasticsearch.common.inject.matcher.Matcher
-
Returns a new matcher which returns
true
if either this or the given matcher returntrue
. - or(BitArray) - Method in class org.elasticsearch.common.util.BitArray
-
this = this OR other
- OR - Enum constant in enum class org.elasticsearch.cluster.node.DiscoveryNodeFilters.OpType
- OR - Enum constant in enum class org.elasticsearch.index.query.Operator
- OR - Enum constant in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- ord() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- ord() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.BytesKeyedBucketOrds.BucketOrdsEnum
-
The ordinal of the current value.
- ord() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.BucketOrdsEnum
-
The ordinal of the current value.
- order - Variable in class org.elasticsearch.search.aggregations.bucket.histogram.AbstractHistogramAggregator
- order - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
- order - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- order - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- order - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- order - Variable in class org.elasticsearch.search.sort.SortBuilder
- order() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- order() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- order() - Method in interface org.elasticsearch.action.support.ActionFilter
-
The position of the filter in the chain.
- order() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- order() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Gets the
SortOrder
to use to sort values produced this source - order() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Return the order to use to sort buckets of this histogram.
- order() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Return the order to use to sort buckets of this histogram.
- order() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Gets the order in which the buckets will be returned.
- order() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- order() - Method in class org.elasticsearch.search.sort.SortBuilder
-
Return the
SortOrder
used for thisSortBuilder
. - order(int) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- order(int) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- order(int) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutRequest
- order(String) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Sets the
SortOrder
to use to sort values produced this source - order(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
The order of fragments per field.
- order(List<BucketOrder>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Sets the order in which the buckets will be returned.
- order(List<BucketOrder>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Sets the order in which the buckets will be returned.
- order(List<BucketOrder>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Sets the order in which the buckets will be returned.
- order(BucketOrder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Set a new order on this builder and return the builder so that calls can be chained.
- order(BucketOrder) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
-
Set a new order on this builder and return the builder so that calls can be chained.
- order(BucketOrder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Set a new order on this builder and return the builder so that calls can be chained.
- order(HighlightBuilder.Order) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
By default, fragments of a field are ordered by the order in the highlighted text.
- order(SortOrder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- order(SortOrder) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Sets the
SortOrder
to use to sort values produced this source - order(SortOrder) - Method in class org.elasticsearch.search.sort.SortBuilder
-
Set the order of sorting.
- ORDER_FIELD - Static variable in interface org.elasticsearch.search.aggregations.bucket.histogram.Histogram
- ORDER_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- ORDER_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- ORDER_FIELD - Static variable in class org.elasticsearch.search.sort.SortBuilder
- orderElements() - Method in class org.elasticsearch.search.aggregations.InternalOrder.CompoundOrder
- ORDINAL_DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- ORDINAL_DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- ORDINAL_DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- ordinalDate() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date, using a four digit year and three digit dayOfYear (yyyy-DDD).
- ordinalDateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date and time, using a four digit year and three digit dayOfYear (yyyy-DDD'T'HH:mm:ss.SSSZZ).
- ordinalDateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full ordinal date and time without millis, using a four digit year and three digit dayOfYear (yyyy-DDD'T'HH:mm:ssZZ).
- ordinals - Variable in class org.elasticsearch.index.fielddata.plain.PagedBytesLeafFieldData
- ordinals() - Method in class org.elasticsearch.index.fielddata.ordinals.Ordinals
- ordinals(Ordinals.ValuesHolder) - Method in class org.elasticsearch.index.fielddata.ordinals.MultiOrdinals
- ordinals(Ordinals.ValuesHolder) - Method in class org.elasticsearch.index.fielddata.ordinals.Ordinals
- ordinals(Ordinals.ValuesHolder) - Method in class org.elasticsearch.index.fielddata.ordinals.SinglePackedOrdinals
- Ordinals - Class in org.elasticsearch.index.fielddata.ordinals
-
A thread safe ordinals abstraction.
- Ordinals() - Constructor for class org.elasticsearch.index.fielddata.ordinals.Ordinals
- Ordinals.ValuesHolder - Interface in org.elasticsearch.index.fielddata.ordinals
- OrdinalsBuilder - Class in org.elasticsearch.index.fielddata.ordinals
-
Simple class to build document ID <-> ordinal mapping.
- OrdinalsBuilder(int) - Constructor for class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
- OrdinalsBuilder(int, float) - Constructor for class org.elasticsearch.index.fielddata.ordinals.OrdinalsBuilder
- OrdinalsFilter() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.OrdinalsFilter
- ordinalsValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
- ordinalsValues(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
-
Get a view into the leaf's ordinals and their
BytesRef
values. - ordsEnum(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.BytesKeyedBucketOrds
-
Build an iterator for buckets inside
owningBucketOrd
in order of increasing ord. - ordsEnum(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromMany
- ordsEnum(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromManySmall
- ordsEnum(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromSingle
- ordsEnum(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds
-
Build an iterator for buckets inside
owningBucketOrd
in order of increasing ord. - org.apache.lucene.analysis.miscellaneous - package org.apache.lucene.analysis.miscellaneous
- org.apache.lucene.document - package org.apache.lucene.document
- org.apache.lucene.geo - package org.apache.lucene.geo
- org.apache.lucene.index - package org.apache.lucene.index
- org.apache.lucene.queries - package org.apache.lucene.queries
- org.apache.lucene.queryparser.classic - package org.apache.lucene.queryparser.classic
- org.apache.lucene.search.grouping - package org.apache.lucene.search.grouping
- org.apache.lucene.search.uhighlight - package org.apache.lucene.search.uhighlight
- org.apache.lucene.search.vectorhighlight - package org.apache.lucene.search.vectorhighlight
- org.apache.lucene.util - package org.apache.lucene.util
- org.elasticsearch - package org.elasticsearch
-
A distributed RESTful search engine.
- org.elasticsearch.action - package org.elasticsearch.action
-
Actions that Elasticsearch can take either on the data stored on disk or on other nodes.
- org.elasticsearch.action.admin.cluster.allocation - package org.elasticsearch.action.admin.cluster.allocation
- org.elasticsearch.action.admin.cluster.configuration - package org.elasticsearch.action.admin.cluster.configuration
- org.elasticsearch.action.admin.cluster.health - package org.elasticsearch.action.admin.cluster.health
- org.elasticsearch.action.admin.cluster.migration - package org.elasticsearch.action.admin.cluster.migration
- org.elasticsearch.action.admin.cluster.node.hotthreads - package org.elasticsearch.action.admin.cluster.node.hotthreads
- org.elasticsearch.action.admin.cluster.node.info - package org.elasticsearch.action.admin.cluster.node.info
- org.elasticsearch.action.admin.cluster.node.liveness - package org.elasticsearch.action.admin.cluster.node.liveness
- org.elasticsearch.action.admin.cluster.node.reload - package org.elasticsearch.action.admin.cluster.node.reload
- org.elasticsearch.action.admin.cluster.node.stats - package org.elasticsearch.action.admin.cluster.node.stats
- org.elasticsearch.action.admin.cluster.node.tasks.cancel - package org.elasticsearch.action.admin.cluster.node.tasks.cancel
- org.elasticsearch.action.admin.cluster.node.tasks.get - package org.elasticsearch.action.admin.cluster.node.tasks.get
- org.elasticsearch.action.admin.cluster.node.tasks.list - package org.elasticsearch.action.admin.cluster.node.tasks.list
- org.elasticsearch.action.admin.cluster.node.usage - package org.elasticsearch.action.admin.cluster.node.usage
- org.elasticsearch.action.admin.cluster.remote - package org.elasticsearch.action.admin.cluster.remote
- org.elasticsearch.action.admin.cluster.repositories.cleanup - package org.elasticsearch.action.admin.cluster.repositories.cleanup
- org.elasticsearch.action.admin.cluster.repositories.delete - package org.elasticsearch.action.admin.cluster.repositories.delete
- org.elasticsearch.action.admin.cluster.repositories.get - package org.elasticsearch.action.admin.cluster.repositories.get
- org.elasticsearch.action.admin.cluster.repositories.put - package org.elasticsearch.action.admin.cluster.repositories.put
- org.elasticsearch.action.admin.cluster.repositories.verify - package org.elasticsearch.action.admin.cluster.repositories.verify
- org.elasticsearch.action.admin.cluster.reroute - package org.elasticsearch.action.admin.cluster.reroute
- org.elasticsearch.action.admin.cluster.settings - package org.elasticsearch.action.admin.cluster.settings
- org.elasticsearch.action.admin.cluster.shards - package org.elasticsearch.action.admin.cluster.shards
- org.elasticsearch.action.admin.cluster.snapshots.clone - package org.elasticsearch.action.admin.cluster.snapshots.clone
- org.elasticsearch.action.admin.cluster.snapshots.create - package org.elasticsearch.action.admin.cluster.snapshots.create
- org.elasticsearch.action.admin.cluster.snapshots.delete - package org.elasticsearch.action.admin.cluster.snapshots.delete
- org.elasticsearch.action.admin.cluster.snapshots.features - package org.elasticsearch.action.admin.cluster.snapshots.features
- org.elasticsearch.action.admin.cluster.snapshots.get - package org.elasticsearch.action.admin.cluster.snapshots.get
- org.elasticsearch.action.admin.cluster.snapshots.get.shard - package org.elasticsearch.action.admin.cluster.snapshots.get.shard
- org.elasticsearch.action.admin.cluster.snapshots.restore - package org.elasticsearch.action.admin.cluster.snapshots.restore
- org.elasticsearch.action.admin.cluster.snapshots.status - package org.elasticsearch.action.admin.cluster.snapshots.status
- org.elasticsearch.action.admin.cluster.state - package org.elasticsearch.action.admin.cluster.state
- org.elasticsearch.action.admin.cluster.stats - package org.elasticsearch.action.admin.cluster.stats
- org.elasticsearch.action.admin.cluster.storedscripts - package org.elasticsearch.action.admin.cluster.storedscripts
- org.elasticsearch.action.admin.cluster.tasks - package org.elasticsearch.action.admin.cluster.tasks
- org.elasticsearch.action.admin.indices.alias - package org.elasticsearch.action.admin.indices.alias
- org.elasticsearch.action.admin.indices.alias.exists - package org.elasticsearch.action.admin.indices.alias.exists
- org.elasticsearch.action.admin.indices.alias.get - package org.elasticsearch.action.admin.indices.alias.get
- org.elasticsearch.action.admin.indices.analyze - package org.elasticsearch.action.admin.indices.analyze
- org.elasticsearch.action.admin.indices.cache.clear - package org.elasticsearch.action.admin.indices.cache.clear
- org.elasticsearch.action.admin.indices.close - package org.elasticsearch.action.admin.indices.close
- org.elasticsearch.action.admin.indices.create - package org.elasticsearch.action.admin.indices.create
-
Create index action.
- org.elasticsearch.action.admin.indices.dangling - package org.elasticsearch.action.admin.indices.dangling
-
Dangling indices are indices that exist on disk on one or more nodes but which do not currently exist in the cluster state.
- org.elasticsearch.action.admin.indices.dangling.delete - package org.elasticsearch.action.admin.indices.dangling.delete
- org.elasticsearch.action.admin.indices.dangling.find - package org.elasticsearch.action.admin.indices.dangling.find
- org.elasticsearch.action.admin.indices.dangling.import_index - package org.elasticsearch.action.admin.indices.dangling.import_index
- org.elasticsearch.action.admin.indices.dangling.list - package org.elasticsearch.action.admin.indices.dangling.list
- org.elasticsearch.action.admin.indices.delete - package org.elasticsearch.action.admin.indices.delete
-
Delete index action.
- org.elasticsearch.action.admin.indices.diskusage - package org.elasticsearch.action.admin.indices.diskusage
- org.elasticsearch.action.admin.indices.exists.indices - package org.elasticsearch.action.admin.indices.exists.indices
- org.elasticsearch.action.admin.indices.exists.types - package org.elasticsearch.action.admin.indices.exists.types
- org.elasticsearch.action.admin.indices.flush - package org.elasticsearch.action.admin.indices.flush
-
Flush index/indices action.
- org.elasticsearch.action.admin.indices.forcemerge - package org.elasticsearch.action.admin.indices.forcemerge
-
Force merge index/indices action.
- org.elasticsearch.action.admin.indices.get - package org.elasticsearch.action.admin.indices.get
- org.elasticsearch.action.admin.indices.mapping.get - package org.elasticsearch.action.admin.indices.mapping.get
- org.elasticsearch.action.admin.indices.mapping.put - package org.elasticsearch.action.admin.indices.mapping.put
-
Put Mapping Action.
- org.elasticsearch.action.admin.indices.open - package org.elasticsearch.action.admin.indices.open
- org.elasticsearch.action.admin.indices.readonly - package org.elasticsearch.action.admin.indices.readonly
- org.elasticsearch.action.admin.indices.recovery - package org.elasticsearch.action.admin.indices.recovery
- org.elasticsearch.action.admin.indices.refresh - package org.elasticsearch.action.admin.indices.refresh
-
Refresh index/indices action.
- org.elasticsearch.action.admin.indices.resolve - package org.elasticsearch.action.admin.indices.resolve
- org.elasticsearch.action.admin.indices.rollover - package org.elasticsearch.action.admin.indices.rollover
- org.elasticsearch.action.admin.indices.segments - package org.elasticsearch.action.admin.indices.segments
- org.elasticsearch.action.admin.indices.settings.get - package org.elasticsearch.action.admin.indices.settings.get
- org.elasticsearch.action.admin.indices.settings.put - package org.elasticsearch.action.admin.indices.settings.put
- org.elasticsearch.action.admin.indices.shards - package org.elasticsearch.action.admin.indices.shards
- org.elasticsearch.action.admin.indices.shrink - package org.elasticsearch.action.admin.indices.shrink
- org.elasticsearch.action.admin.indices.stats - package org.elasticsearch.action.admin.indices.stats
- org.elasticsearch.action.admin.indices.template.delete - package org.elasticsearch.action.admin.indices.template.delete
- org.elasticsearch.action.admin.indices.template.get - package org.elasticsearch.action.admin.indices.template.get
- org.elasticsearch.action.admin.indices.template.post - package org.elasticsearch.action.admin.indices.template.post
- org.elasticsearch.action.admin.indices.template.put - package org.elasticsearch.action.admin.indices.template.put
- org.elasticsearch.action.admin.indices.upgrade.get - package org.elasticsearch.action.admin.indices.upgrade.get
- org.elasticsearch.action.admin.indices.upgrade.post - package org.elasticsearch.action.admin.indices.upgrade.post
- org.elasticsearch.action.admin.indices.validate.query - package org.elasticsearch.action.admin.indices.validate.query
-
Validate action.
- org.elasticsearch.action.bulk - package org.elasticsearch.action.bulk
- org.elasticsearch.action.datastreams - package org.elasticsearch.action.datastreams
- org.elasticsearch.action.delete - package org.elasticsearch.action.delete
-
Delete action.
- org.elasticsearch.action.explain - package org.elasticsearch.action.explain
-
Explain action.
- org.elasticsearch.action.fieldcaps - package org.elasticsearch.action.fieldcaps
- org.elasticsearch.action.get - package org.elasticsearch.action.get
-
Get action.
- org.elasticsearch.action.index - package org.elasticsearch.action.index
-
Index action.
- org.elasticsearch.action.ingest - package org.elasticsearch.action.ingest
- org.elasticsearch.action.main - package org.elasticsearch.action.main
- org.elasticsearch.action.resync - package org.elasticsearch.action.resync
- org.elasticsearch.action.search - package org.elasticsearch.action.search
-
Search action.
- org.elasticsearch.action.support - package org.elasticsearch.action.support
- org.elasticsearch.action.support.broadcast - package org.elasticsearch.action.support.broadcast
- org.elasticsearch.action.support.broadcast.node - package org.elasticsearch.action.support.broadcast.node
- org.elasticsearch.action.support.master - package org.elasticsearch.action.support.master
- org.elasticsearch.action.support.master.info - package org.elasticsearch.action.support.master.info
- org.elasticsearch.action.support.nodes - package org.elasticsearch.action.support.nodes
- org.elasticsearch.action.support.replication - package org.elasticsearch.action.support.replication
- org.elasticsearch.action.support.single.instance - package org.elasticsearch.action.support.single.instance
- org.elasticsearch.action.support.single.shard - package org.elasticsearch.action.support.single.shard
- org.elasticsearch.action.support.tasks - package org.elasticsearch.action.support.tasks
- org.elasticsearch.action.termvectors - package org.elasticsearch.action.termvectors
-
Get the term vector for a specific document.
- org.elasticsearch.action.update - package org.elasticsearch.action.update
- org.elasticsearch.bootstrap - package org.elasticsearch.bootstrap
- org.elasticsearch.bootstrap.plugins - package org.elasticsearch.bootstrap.plugins
- org.elasticsearch.cli - package org.elasticsearch.cli
- org.elasticsearch.client - package org.elasticsearch.client
-
The client module allowing to easily perform actions/operations.
- org.elasticsearch.client.node - package org.elasticsearch.client.node
- org.elasticsearch.client.support - package org.elasticsearch.client.support
- org.elasticsearch.client.transport - package org.elasticsearch.client.transport
- org.elasticsearch.cluster - package org.elasticsearch.cluster
- org.elasticsearch.cluster.ack - package org.elasticsearch.cluster.ack
- org.elasticsearch.cluster.action.index - package org.elasticsearch.cluster.action.index
- org.elasticsearch.cluster.action.shard - package org.elasticsearch.cluster.action.shard
- org.elasticsearch.cluster.block - package org.elasticsearch.cluster.block
- org.elasticsearch.cluster.coordination - package org.elasticsearch.cluster.coordination
- org.elasticsearch.cluster.health - package org.elasticsearch.cluster.health
- org.elasticsearch.cluster.metadata - package org.elasticsearch.cluster.metadata
- org.elasticsearch.cluster.node - package org.elasticsearch.cluster.node
- org.elasticsearch.cluster.routing - package org.elasticsearch.cluster.routing
- org.elasticsearch.cluster.routing.allocation - package org.elasticsearch.cluster.routing.allocation
- org.elasticsearch.cluster.routing.allocation.allocator - package org.elasticsearch.cluster.routing.allocation.allocator
- org.elasticsearch.cluster.routing.allocation.command - package org.elasticsearch.cluster.routing.allocation.command
- org.elasticsearch.cluster.routing.allocation.decider - package org.elasticsearch.cluster.routing.allocation.decider
- org.elasticsearch.cluster.service - package org.elasticsearch.cluster.service
- org.elasticsearch.common - package org.elasticsearch.common
- org.elasticsearch.common.blobstore - package org.elasticsearch.common.blobstore
- org.elasticsearch.common.blobstore.fs - package org.elasticsearch.common.blobstore.fs
- org.elasticsearch.common.blobstore.support - package org.elasticsearch.common.blobstore.support
- org.elasticsearch.common.breaker - package org.elasticsearch.common.breaker
- org.elasticsearch.common.bytes - package org.elasticsearch.common.bytes
- org.elasticsearch.common.cache - package org.elasticsearch.common.cache
- org.elasticsearch.common.collect - package org.elasticsearch.common.collect
- org.elasticsearch.common.component - package org.elasticsearch.common.component
- org.elasticsearch.common.compress - package org.elasticsearch.common.compress
- org.elasticsearch.common.document - package org.elasticsearch.common.document
- org.elasticsearch.common.filesystem - package org.elasticsearch.common.filesystem
- org.elasticsearch.common.geo - package org.elasticsearch.common.geo
- org.elasticsearch.common.hash - package org.elasticsearch.common.hash
- org.elasticsearch.common.inject - package org.elasticsearch.common.inject
-
Google Guice (pronounced "juice") is an ultra-lightweight dependency injection framework.
- org.elasticsearch.common.inject.assistedinject - package org.elasticsearch.common.inject.assistedinject
-
Extension for combining factory interfaces with injection; this extension requires
guice-jndi-2.0.jar
. - org.elasticsearch.common.inject.binder - package org.elasticsearch.common.inject.binder
-
Interfaces which make up
Binder
's expression language. - org.elasticsearch.common.inject.internal - package org.elasticsearch.common.inject.internal
-
Guice (sounds like like "juice")
- org.elasticsearch.common.inject.matcher - package org.elasticsearch.common.inject.matcher
-
Used for matching things.
- org.elasticsearch.common.inject.multibindings - package org.elasticsearch.common.inject.multibindings
-
Extension for binding multiple instances in a collection; this extension requires
guice-multibindings-2.0.jar
. - org.elasticsearch.common.inject.name - package org.elasticsearch.common.inject.name
-
Support for binding to string-based names.
- org.elasticsearch.common.inject.spi - package org.elasticsearch.common.inject.spi
-
Guice service provider interface
- org.elasticsearch.common.inject.util - package org.elasticsearch.common.inject.util
-
Helper methods for working with Guice.
- org.elasticsearch.common.io - package org.elasticsearch.common.io
- org.elasticsearch.common.io.stream - package org.elasticsearch.common.io.stream
-
Classes for streaming objects from one Elasticsearch node to another over its binary internode protocol.
- org.elasticsearch.common.joda - package org.elasticsearch.common.joda
- org.elasticsearch.common.logging - package org.elasticsearch.common.logging
- org.elasticsearch.common.lucene - package org.elasticsearch.common.lucene
- org.elasticsearch.common.lucene.index - package org.elasticsearch.common.lucene.index
- org.elasticsearch.common.lucene.search - package org.elasticsearch.common.lucene.search
- org.elasticsearch.common.lucene.search.function - package org.elasticsearch.common.lucene.search.function
- org.elasticsearch.common.lucene.store - package org.elasticsearch.common.lucene.store
- org.elasticsearch.common.lucene.uid - package org.elasticsearch.common.lucene.uid
- org.elasticsearch.common.metrics - package org.elasticsearch.common.metrics
- org.elasticsearch.common.network - package org.elasticsearch.common.network
- org.elasticsearch.common.path - package org.elasticsearch.common.path
- org.elasticsearch.common.recycler - package org.elasticsearch.common.recycler
- org.elasticsearch.common.regex - package org.elasticsearch.common.regex
- org.elasticsearch.common.rounding - package org.elasticsearch.common.rounding
- org.elasticsearch.common.settings - package org.elasticsearch.common.settings
-
Settings based utility.
- org.elasticsearch.common.text - package org.elasticsearch.common.text
- org.elasticsearch.common.time - package org.elasticsearch.common.time
- org.elasticsearch.common.transport - package org.elasticsearch.common.transport
- org.elasticsearch.common.unit - package org.elasticsearch.common.unit
- org.elasticsearch.common.util - package org.elasticsearch.common.util
- org.elasticsearch.common.util.concurrent - package org.elasticsearch.common.util.concurrent
- org.elasticsearch.common.util.iterable - package org.elasticsearch.common.util.iterable
- org.elasticsearch.common.util.set - package org.elasticsearch.common.util.set
- org.elasticsearch.common.xcontent - package org.elasticsearch.common.xcontent
- org.elasticsearch.common.xcontent.support - package org.elasticsearch.common.xcontent.support
- org.elasticsearch.discovery - package org.elasticsearch.discovery
- org.elasticsearch.discovery.zen - package org.elasticsearch.discovery.zen
- org.elasticsearch.env - package org.elasticsearch.env
- org.elasticsearch.gateway - package org.elasticsearch.gateway
- org.elasticsearch.http - package org.elasticsearch.http
- org.elasticsearch.index - package org.elasticsearch.index
- org.elasticsearch.index.analysis - package org.elasticsearch.index.analysis
- org.elasticsearch.index.cache - package org.elasticsearch.index.cache
- org.elasticsearch.index.cache.bitset - package org.elasticsearch.index.cache.bitset
- org.elasticsearch.index.cache.query - package org.elasticsearch.index.cache.query
- org.elasticsearch.index.cache.request - package org.elasticsearch.index.cache.request
- org.elasticsearch.index.codec - package org.elasticsearch.index.codec
- org.elasticsearch.index.engine - package org.elasticsearch.index.engine
- org.elasticsearch.index.fielddata - package org.elasticsearch.index.fielddata
- org.elasticsearch.index.fielddata.fieldcomparator - package org.elasticsearch.index.fielddata.fieldcomparator
- org.elasticsearch.index.fielddata.ordinals - package org.elasticsearch.index.fielddata.ordinals
- org.elasticsearch.index.fielddata.plain - package org.elasticsearch.index.fielddata.plain
- org.elasticsearch.index.fieldvisitor - package org.elasticsearch.index.fieldvisitor
- org.elasticsearch.index.flush - package org.elasticsearch.index.flush
- org.elasticsearch.index.get - package org.elasticsearch.index.get
- org.elasticsearch.index.mapper - package org.elasticsearch.index.mapper
- org.elasticsearch.index.mapper.flattened - package org.elasticsearch.index.mapper.flattened
- org.elasticsearch.index.merge - package org.elasticsearch.index.merge
- org.elasticsearch.index.query - package org.elasticsearch.index.query
- org.elasticsearch.index.query.functionscore - package org.elasticsearch.index.query.functionscore
- org.elasticsearch.index.query.support - package org.elasticsearch.index.query.support
- org.elasticsearch.index.recovery - package org.elasticsearch.index.recovery
- org.elasticsearch.index.refresh - package org.elasticsearch.index.refresh
- org.elasticsearch.index.reindex - package org.elasticsearch.index.reindex
- org.elasticsearch.index.search - package org.elasticsearch.index.search
- org.elasticsearch.index.search.stats - package org.elasticsearch.index.search.stats
- org.elasticsearch.index.seqno - package org.elasticsearch.index.seqno
- org.elasticsearch.index.shard - package org.elasticsearch.index.shard
- org.elasticsearch.index.similarity - package org.elasticsearch.index.similarity
- org.elasticsearch.index.snapshots - package org.elasticsearch.index.snapshots
- org.elasticsearch.index.snapshots.blobstore - package org.elasticsearch.index.snapshots.blobstore
- org.elasticsearch.index.stats - package org.elasticsearch.index.stats
- org.elasticsearch.index.store - package org.elasticsearch.index.store
- org.elasticsearch.index.termvectors - package org.elasticsearch.index.termvectors
- org.elasticsearch.index.translog - package org.elasticsearch.index.translog
- org.elasticsearch.index.warmer - package org.elasticsearch.index.warmer
- org.elasticsearch.indices - package org.elasticsearch.indices
- org.elasticsearch.indices.analysis - package org.elasticsearch.indices.analysis
- org.elasticsearch.indices.breaker - package org.elasticsearch.indices.breaker
- org.elasticsearch.indices.cluster - package org.elasticsearch.indices.cluster
- org.elasticsearch.indices.fielddata.cache - package org.elasticsearch.indices.fielddata.cache
- org.elasticsearch.indices.flush - package org.elasticsearch.indices.flush
- org.elasticsearch.indices.recovery - package org.elasticsearch.indices.recovery
-
This package contains the logic for the recovery functionality.
- org.elasticsearch.indices.recovery.plan - package org.elasticsearch.indices.recovery.plan
- org.elasticsearch.indices.store - package org.elasticsearch.indices.store
- org.elasticsearch.ingest - package org.elasticsearch.ingest
- org.elasticsearch.monitor - package org.elasticsearch.monitor
-
Monitors the Elasticsearch process and the system on which it is running so that metrics can be exposed via an HTTP or transport APIs to be logged and graphed.
- org.elasticsearch.monitor.fs - package org.elasticsearch.monitor.fs
- org.elasticsearch.monitor.jvm - package org.elasticsearch.monitor.jvm
- org.elasticsearch.monitor.os - package org.elasticsearch.monitor.os
- org.elasticsearch.monitor.process - package org.elasticsearch.monitor.process
- org.elasticsearch.node - package org.elasticsearch.node
-
Allow to build a
Node
which is a node within the cluster. - org.elasticsearch.persistent - package org.elasticsearch.persistent
-
The Persistent Tasks Executors are responsible for executing restartable tasks that can survive disappearance of a coordinating and executor nodes.
- org.elasticsearch.persistent.decider - package org.elasticsearch.persistent.decider
- org.elasticsearch.plugins - package org.elasticsearch.plugins
-
Support for extending Elasticsearch by providing java code that is loaded by a child classloader.
- org.elasticsearch.plugins.spi - package org.elasticsearch.plugins.spi
-
This package contains interfaces for services provided by Elasticsearch plugins to external applications like the Java High Level Rest Client.
- org.elasticsearch.repositories - package org.elasticsearch.repositories
-
Repositories of snapshot/restore information.
- org.elasticsearch.repositories.blobstore - package org.elasticsearch.repositories.blobstore
-
This package exposes the blobstore repository used by Elasticsearch Snapshots.
- org.elasticsearch.repositories.fs - package org.elasticsearch.repositories.fs
- org.elasticsearch.rest - package org.elasticsearch.rest
-
Exposes Elasticsearch functionality over RESTful HTTP.
- org.elasticsearch.rest.action - package org.elasticsearch.rest.action
-
RestHandler
s that translate requests from REST into internal requests and start them then wait for them to complete and then translate them back into REST. - org.elasticsearch.rest.action.admin.cluster - package org.elasticsearch.rest.action.admin.cluster
-
RestHandler
s for administrative actions that can be taken on the cluster as a whole like getting the listing tasks, adding repositories, and getting stats. - org.elasticsearch.rest.action.admin.cluster.dangling - package org.elasticsearch.rest.action.admin.cluster.dangling
-
RestHandler
s for managing dangling indices. - org.elasticsearch.rest.action.admin.indices - package org.elasticsearch.rest.action.admin.indices
-
RestHandler
s for administrative actions that can be taken on indexes like creation, deletion, setting up aliases, and changing mapping. - org.elasticsearch.rest.action.cat - package org.elasticsearch.rest.action.cat
-
RestHandler
s for actions that spit out tables of results. - org.elasticsearch.rest.action.datastreams - package org.elasticsearch.rest.action.datastreams
- org.elasticsearch.rest.action.document - package org.elasticsearch.rest.action.document
-
RestHandler
s for actions that can be taken on documents like index, update, get, and delete. - org.elasticsearch.rest.action.ingest - package org.elasticsearch.rest.action.ingest
-
RestHandler
s that manage ingest pipelines. - org.elasticsearch.rest.action.search - package org.elasticsearch.rest.action.search
-
RestHandler
s for search actions like search, scroll, and suggest. - org.elasticsearch.rollup - package org.elasticsearch.rollup
- org.elasticsearch.script - package org.elasticsearch.script
-
Support for running user provided scripts (in the request, in cluster state, etc) in portions of various requests (
FunctionScoreQuery
,Aggregation
,UpdateAction
, etc). - org.elasticsearch.script.field - package org.elasticsearch.script.field
- org.elasticsearch.search - package org.elasticsearch.search
- org.elasticsearch.search.aggregations - package org.elasticsearch.search.aggregations
-
Aggregations
- org.elasticsearch.search.aggregations.bucket - package org.elasticsearch.search.aggregations.bucket
- org.elasticsearch.search.aggregations.bucket.adjacency - package org.elasticsearch.search.aggregations.bucket.adjacency
- org.elasticsearch.search.aggregations.bucket.composite - package org.elasticsearch.search.aggregations.bucket.composite
- org.elasticsearch.search.aggregations.bucket.filter - package org.elasticsearch.search.aggregations.bucket.filter
- org.elasticsearch.search.aggregations.bucket.geogrid - package org.elasticsearch.search.aggregations.bucket.geogrid
- org.elasticsearch.search.aggregations.bucket.global - package org.elasticsearch.search.aggregations.bucket.global
- org.elasticsearch.search.aggregations.bucket.histogram - package org.elasticsearch.search.aggregations.bucket.histogram
-
Histogram module for different bucket specifications used in aggregation.
- org.elasticsearch.search.aggregations.bucket.missing - package org.elasticsearch.search.aggregations.bucket.missing
- org.elasticsearch.search.aggregations.bucket.nested - package org.elasticsearch.search.aggregations.bucket.nested
- org.elasticsearch.search.aggregations.bucket.range - package org.elasticsearch.search.aggregations.bucket.range
- org.elasticsearch.search.aggregations.bucket.sampler - package org.elasticsearch.search.aggregations.bucket.sampler
- org.elasticsearch.search.aggregations.bucket.terms - package org.elasticsearch.search.aggregations.bucket.terms
- org.elasticsearch.search.aggregations.bucket.terms.heuristic - package org.elasticsearch.search.aggregations.bucket.terms.heuristic
- org.elasticsearch.search.aggregations.metrics - package org.elasticsearch.search.aggregations.metrics
-
Aggregations module
- org.elasticsearch.search.aggregations.pipeline - package org.elasticsearch.search.aggregations.pipeline
- org.elasticsearch.search.aggregations.support - package org.elasticsearch.search.aggregations.support
- org.elasticsearch.search.aggregations.support.values - package org.elasticsearch.search.aggregations.support.values
- org.elasticsearch.search.builder - package org.elasticsearch.search.builder
- org.elasticsearch.search.collapse - package org.elasticsearch.search.collapse
- org.elasticsearch.search.dfs - package org.elasticsearch.search.dfs
- org.elasticsearch.search.fetch - package org.elasticsearch.search.fetch
-
Search phase that fetches the top hits from the shards after the results of the query phase have been merged.
- org.elasticsearch.search.fetch.subphase - package org.elasticsearch.search.fetch.subphase
-
Built in
FetchSubPhase
s like matched queries and fetching_source
. - org.elasticsearch.search.fetch.subphase.highlight - package org.elasticsearch.search.fetch.subphase.highlight
-
Fetch sub phase that extracts significant portions of string fields, marking the matches.
- org.elasticsearch.search.internal - package org.elasticsearch.search.internal
- org.elasticsearch.search.lookup - package org.elasticsearch.search.lookup
- org.elasticsearch.search.profile - package org.elasticsearch.search.profile
-
Profiling for portions of the search request.
- org.elasticsearch.search.profile.aggregation - package org.elasticsearch.search.profile.aggregation
-
Profiles the aggregation portion of a search request.
- org.elasticsearch.search.profile.query - package org.elasticsearch.search.profile.query
-
Profiles the query portion of a search request.
- org.elasticsearch.search.query - package org.elasticsearch.search.query
- org.elasticsearch.search.rescore - package org.elasticsearch.search.rescore
- org.elasticsearch.search.runtime - package org.elasticsearch.search.runtime
- org.elasticsearch.search.searchafter - package org.elasticsearch.search.searchafter
- org.elasticsearch.search.slice - package org.elasticsearch.search.slice
- org.elasticsearch.search.sort - package org.elasticsearch.search.sort
- org.elasticsearch.search.suggest - package org.elasticsearch.search.suggest
-
Support for suggesting alternate queries.
- org.elasticsearch.search.suggest.completion - package org.elasticsearch.search.suggest.completion
-
Suggests alternate queries by fancy prefix matching.
- org.elasticsearch.search.suggest.completion.context - package org.elasticsearch.search.suggest.completion.context
-
Support for limiting the completion suggesters results to within a "context" like a geographic location or a category.
- org.elasticsearch.search.suggest.phrase - package org.elasticsearch.search.suggest.phrase
-
Suggests alternate queries by breaking the query into terms and suggesting terms that are frequently found together.
- org.elasticsearch.search.suggest.term - package org.elasticsearch.search.suggest.term
-
Suggests alternate queries by breaking the query into terms and suggesting more popular terms.
- org.elasticsearch.shutdown - package org.elasticsearch.shutdown
- org.elasticsearch.snapshots - package org.elasticsearch.snapshots
-
This package exposes the Elasticsearch Snapshot functionality.
- org.elasticsearch.tasks - package org.elasticsearch.tasks
-
Support for viewing and modifying in flight actions (
Task
s) and saving their results to an index. - org.elasticsearch.threadpool - package org.elasticsearch.threadpool
- org.elasticsearch.transport - package org.elasticsearch.transport
- org.elasticsearch.upgrades - package org.elasticsearch.upgrades
- org.elasticsearch.usage - package org.elasticsearch.usage
- org.elasticsearch.watcher - package org.elasticsearch.watcher
- org.joda.time.format - package org.joda.time.format
- orientation - Variable in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper
- orientation() - Method in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper.AbstractShapeGeometryFieldType
- orientation() - Method in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper
- Orientation - Enum Class in org.elasticsearch.common.geo
- orientationParam(Function<FieldMapper, Explicit<Orientation>>) - Static method in class org.elasticsearch.index.mapper.AbstractShapeGeometryFieldMapper
- origin() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- origin() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- origin() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- origin() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- origin() - Method in class org.elasticsearch.index.engine.Engine.Operation
- origin() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
-
Return the
GeoPoint
that is used for distance computations. - origin(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- origin(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- origin(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- origin(String) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- origin(String) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Sets the origin to use, only set this when the settings update is requested by ES internal processes.
- Origin(Long) - Constructor for class org.elasticsearch.index.query.DistanceFeatureQueryBuilder.Origin
- Origin(String) - Constructor for class org.elasticsearch.index.query.DistanceFeatureQueryBuilder.Origin
- Origin(GeoPoint) - Constructor for class org.elasticsearch.index.query.DistanceFeatureQueryBuilder.Origin
- ORIGIN - Static variable in class org.elasticsearch.http.CorsHandler
- ORIGIN - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- originalFrom - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- originalIndices - Variable in class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- OriginalIndices - Class in org.elasticsearch.action
-
Used to keep track of original indices within internal (e.g.
- OriginalIndices(String[], IndicesOptions) - Constructor for class org.elasticsearch.action.OriginalIndices
- OriginalIndices(IndicesRequest) - Constructor for class org.elasticsearch.action.OriginalIndices
- originalTerm - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.CandidateSet
- originalTo - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- origins() - Method in class org.elasticsearch.http.CorsHandler.Config
- OriginSettingClient - Class in org.elasticsearch.client
-
A Client that sends requests with the
origin
set to a particular value and calls its ActionListener in its originalThreadContext
. - OriginSettingClient(Client, String) - Constructor for class org.elasticsearch.client.OriginSettingClient
- OriginSettingClient(Client, String, boolean) - Constructor for class org.elasticsearch.client.OriginSettingClient
- OS - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
- OS - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- OsInfo - Class in org.elasticsearch.monitor.os
- OsInfo(long, int, int, String, String, String, String) - Constructor for class org.elasticsearch.monitor.os.OsInfo
- OsInfo(StreamInput) - Constructor for class org.elasticsearch.monitor.os.OsInfo
- OsProbe - Class in org.elasticsearch.monitor.os
-
The
OsProbe
class retrieves information about the physical and swap size of the machine memory, as well as the system load average and cpu load. - OSS - Enum constant in enum class org.elasticsearch.Build.Flavor
- osService() - Method in class org.elasticsearch.monitor.MonitorService
- OsService - Class in org.elasticsearch.monitor.os
- OsService(Settings) - Constructor for class org.elasticsearch.monitor.os.OsService
- osStats() - Method in class org.elasticsearch.monitor.os.OsProbe
- OsStats - Class in org.elasticsearch.monitor.os
- OsStats(long, OsStats.Cpu, OsStats.Mem, OsStats.Swap, OsStats.Cgroup) - Constructor for class org.elasticsearch.monitor.os.OsStats
- OsStats(StreamInput) - Constructor for class org.elasticsearch.monitor.os.OsStats
- OsStats.Cgroup - Class in org.elasticsearch.monitor.os
-
Encapsulates basic cgroup statistics.
- OsStats.Cgroup.CpuStat - Class in org.elasticsearch.monitor.os
-
Encapsulates CPU time statistics.
- OsStats.Cpu - Class in org.elasticsearch.monitor.os
- OsStats.Mem - Class in org.elasticsearch.monitor.os
- OsStats.Swap - Class in org.elasticsearch.monitor.os
- OTHER - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- OTHER_BUCKET_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
- OTHER_BUCKET_KEY_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
- OTHER_SUBTYPE - Static variable in class org.elasticsearch.search.aggregations.support.AggregationUsageService
- otherBucket() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
-
Get whether to include a bucket for documents not matching any filter
- otherBucket(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
-
Set whether to include a bucket for documents not matching any filter
- otherBucketKey - Variable in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator
- otherBucketKey() - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
-
Get the key to use for the bucket for documents not matching any filter.
- otherBucketKey(String) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
-
Set the key to use for the bucket for documents not matching any filter.
- otherDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- otherStatsToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- otherStatsToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- otherStatsToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- otherStatsToXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- out - Variable in class org.elasticsearch.common.lucene.store.FilterIndexOutput
- OutOfScopeException - Exception in org.elasticsearch.common.inject
-
Thrown from
Provider.get()
when an attempt is made to access a scoped object while the scope in question is not currently active. - OutOfScopeException(String) - Constructor for exception org.elasticsearch.common.inject.OutOfScopeException
- OutOfScopeException(String, Throwable) - Constructor for exception org.elasticsearch.common.inject.OutOfScopeException
- OutOfScopeException(Throwable) - Constructor for exception org.elasticsearch.common.inject.OutOfScopeException
- OutputStreamStreamOutput - Class in org.elasticsearch.common.io.stream
- OutputStreamStreamOutput(OutputStream) - Constructor for class org.elasticsearch.common.io.stream.OutputStreamStreamOutput
- outstandingCleanFilesConditions() - Method in class org.elasticsearch.index.shard.IndexShard
- OVERRIDDEN - Enum constant in enum class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
- override(Iterable<? extends Module>) - Static method in class org.elasticsearch.common.inject.util.Modules
-
Returns a builder that creates a module that overlays override modules over the given modules.
- override(Module...) - Static method in class org.elasticsearch.common.inject.util.Modules
-
Returns a builder that creates a module that overlays override modules over the given modules.
- overrideBucketsPath() - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- overrideBucketsPath() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- overrideBucketsPath() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- overrideBucketsPath() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- overrideBucketsPath() - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- OverrideNodeVersionCommand - Class in org.elasticsearch.env
- OverrideNodeVersionCommand() - Constructor for class org.elasticsearch.env.OverrideNodeVersionCommand
- overridePath(ContentPath) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Return a new context that will have the provided path.
- overrideVersion(Version, Path...) - Static method in class org.elasticsearch.gateway.PersistedClusterStateService
-
Overrides the version field for the metadata in the given data path
- overSize(long) - Static method in class org.elasticsearch.common.util.BigArrays
-
Returns the next size to grow when working with parallel arrays that may have different page sizes or number of bytes per element.
- overSize(long, int, int) - Static method in class org.elasticsearch.common.util.BigArrays
-
Return the next size to grow to that is >=
minTargetSize
.
P
- p - Variable in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
- pad(boolean) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
- pad(Table.Cell, int, RestRequest, UTF8StreamWriter) - Static method in class org.elasticsearch.rest.action.cat.RestTable
- pad(Table.Cell, int, RestRequest, UTF8StreamWriter, boolean) - Static method in class org.elasticsearch.rest.action.cat.RestTable
- padStart(String, int, char) - Static method in class org.elasticsearch.common.Strings
- PAGE_SIZE_IN_BYTES - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
-
Page size in bytes: 16KB
- pageCacheRecycler - Variable in class org.elasticsearch.transport.TcpTransport
- PageCacheRecycler - Class in org.elasticsearch.common.util
-
A recycler of fixed-size pages.
- PageCacheRecycler(Settings) - Constructor for class org.elasticsearch.common.util.PageCacheRecycler
- PageCacheRecycler.Type - Enum Class in org.elasticsearch.common.util
- PagedBytesIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- PagedBytesIndexFieldData(String, ValuesSourceType, IndexFieldDataCache, CircuitBreakerService, double, double, int) - Constructor for class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData
- PagedBytesIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
- PagedBytesIndexFieldData.PagedBytesEstimator - Class in org.elasticsearch.index.fielddata.plain
-
Estimator that wraps string field data by either using BlockTreeTermsReader, or wrapping the data in a RamAccountingTermsEnum if the BlockTreeTermsReader cannot be used.
- PagedBytesLeafFieldData - Class in org.elasticsearch.index.fielddata.plain
- PagedBytesLeafFieldData(PagedBytes.Reader, PackedLongValues, Ordinals) - Constructor for class org.elasticsearch.index.fielddata.plain.PagedBytesLeafFieldData
- PagedBytesReference - Class in org.elasticsearch.common.bytes
-
A page based bytes reference, internally holding the bytes in a paged data structure.
- PAGINATED_GET_SNAPSHOTS_VERSION - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- PARAGRAPH_SEPARATOR - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.HighlightUtils
- param(String) - Method in class org.elasticsearch.rest.RestRequest
- param(String, String) - Method in class org.elasticsearch.rest.RestRequest
- paramAsBoolean(String, boolean) - Method in class org.elasticsearch.rest.RestRequest
- paramAsBoolean(String, Boolean) - Method in class org.elasticsearch.rest.RestRequest
- paramAsDouble(String, double) - Method in class org.elasticsearch.rest.RestRequest
- paramAsFloat(String, float) - Method in class org.elasticsearch.rest.RestRequest
- paramAsInt(String, int) - Method in class org.elasticsearch.rest.RestRequest
- paramAsLong(String, long) - Method in class org.elasticsearch.rest.RestRequest
- paramAsSize(String, ByteSizeValue) - Method in class org.elasticsearch.rest.RestRequest
- paramAsStringArray(String, String[]) - Method in class org.elasticsearch.rest.RestRequest
- paramAsStringArrayOrEmptyIfAll(String) - Method in class org.elasticsearch.rest.RestRequest
- paramAsTime(String, TimeValue) - Method in class org.elasticsearch.rest.RestRequest
- Parameter(String, boolean, Supplier<T>, TriFunction<String, MappingParserContext, Object, T>, Function<FieldMapper, T>) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Creates a new Parameter
- ParameterInfo(String, String) - Constructor for class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo.ParameterInfo
- ParameterInfo(StreamInput) - Constructor for class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo.ParameterInfo
- ParameterizedTypeImpl(Type, Type, Type...) - Constructor for class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- parameters - Variable in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo
- Parameters(Environment, ScriptService, AnalysisRegistry, ThreadContext, LongSupplier, BiFunction<Long, Runnable, Scheduler.ScheduledCancellable>, IngestService, Client, Consumer<Runnable>) - Constructor for class org.elasticsearch.ingest.Processor.Parameters
- PARAMETERS - Static variable in class org.elasticsearch.index.query.IntervalFilterScript
- PARAMETERS - Static variable in class org.elasticsearch.script.AggregationScript
- PARAMETERS - Static variable in class org.elasticsearch.script.BooleanFieldScript
- PARAMETERS - Static variable in class org.elasticsearch.script.BucketAggregationScript
- PARAMETERS - Static variable in class org.elasticsearch.script.BucketAggregationSelectorScript
- PARAMETERS - Static variable in class org.elasticsearch.script.CompositeFieldScript
- PARAMETERS - Static variable in class org.elasticsearch.script.DateFieldScript
- PARAMETERS - Static variable in class org.elasticsearch.script.DoubleFieldScript
- PARAMETERS - Static variable in class org.elasticsearch.script.FieldScript
- PARAMETERS - Static variable in class org.elasticsearch.script.FilterScript
- PARAMETERS - Static variable in class org.elasticsearch.script.GeoPointFieldScript
- PARAMETERS - Static variable in class org.elasticsearch.script.IngestConditionalScript
- PARAMETERS - Static variable in class org.elasticsearch.script.IngestScript
- PARAMETERS - Static variable in class org.elasticsearch.script.IpFieldScript
- PARAMETERS - Static variable in class org.elasticsearch.script.LongFieldScript
- PARAMETERS - Static variable in class org.elasticsearch.script.NumberSortScript
- PARAMETERS - Static variable in class org.elasticsearch.script.ScoreScript
- PARAMETERS - Static variable in class org.elasticsearch.script.ScriptedMetricAggContexts.CombineScript
- PARAMETERS - Static variable in class org.elasticsearch.script.ScriptedMetricAggContexts.InitScript
- PARAMETERS - Static variable in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- PARAMETERS - Static variable in class org.elasticsearch.script.ScriptedMetricAggContexts.ReduceScript
- PARAMETERS - Static variable in class org.elasticsearch.script.SignificantTermsHeuristicScoreScript
- PARAMETERS - Static variable in class org.elasticsearch.script.SimilarityScript
- PARAMETERS - Static variable in class org.elasticsearch.script.SimilarityWeightScript
- PARAMETERS - Static variable in class org.elasticsearch.script.StringFieldScript
- PARAMETERS - Static variable in class org.elasticsearch.script.StringSortScript
- PARAMETERS - Static variable in class org.elasticsearch.script.TemplateScript
- PARAMETERS - Static variable in class org.elasticsearch.script.TermsSetQueryScript
- PARAMETERS - Static variable in class org.elasticsearch.script.UpdateScript
- PARAMETERS - Static variable in class org.elasticsearch.search.aggregations.pipeline.MovingFunctionScript
- params() - Method in class org.elasticsearch.rest.RestRequest
- params() - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
-
Get parameters that will be available in the
init
,map
andcombine
phases. - params(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
-
Set parameters that will be available in the
init
,map
andcombine
phases. - PARAMS_PARSE_FIELD - Static variable in class org.elasticsearch.script.Script
-
Standard
ParseField
for params on the inner level. - parent - Variable in class org.elasticsearch.search.aggregations.AggregatorBase
- parent - Variable in class org.elasticsearch.search.aggregations.AggregatorFactory
- parent() - Method in class org.elasticsearch.common.blobstore.BlobPath
-
Returns this path's parent path.
- parent() - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- parent() - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Return the parent aggregator.
- parent() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- parent() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- parent() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- parent(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
-
Simple sets the routing.
- PARENT - Enum constant in enum class org.elasticsearch.common.breaker.CircuitBreaker.Type
- PARENT - Static variable in interface org.elasticsearch.common.breaker.CircuitBreaker
-
The parent breaker is a sum of all the following breakers combined.
- parentPath(String) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Builder
- parentSearchContext() - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- ParentTaskAssigningClient - Class in org.elasticsearch.client
-
A Client that sets the parent task on all requests that it makes.
- ParentTaskAssigningClient(Client, DiscoveryNode, Task) - Constructor for class org.elasticsearch.client.ParentTaskAssigningClient
-
Convenience constructor for building the TaskId out of what is usually at hand.
- ParentTaskAssigningClient(Client, TaskId) - Constructor for class org.elasticsearch.client.ParentTaskAssigningClient
-
Standard constructor.
- parse(Object) - Method in class org.elasticsearch.script.DateFieldScript.Parse
- parse(Object) - Static method in class org.elasticsearch.script.Script
- parse(Object, boolean) - Method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- parse(String) - Static method in enum class org.elasticsearch.action.support.WriteRequest.RefreshPolicy
-
Parse the string representation of a refresh policy, usually from a request parameter.
- parse(String) - Static method in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Type
- parse(String) - Static method in enum class org.elasticsearch.cluster.routing.Preference
-
Parses the Preference Type given a string
- parse(String) - Static method in class org.elasticsearch.common.geo.SimpleVectorTileFormatter
-
Parses string in the format we expect either z/x/y or z/x/y@extent to an array of integer parameters
- parse(String) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- parse(String) - Method in interface org.elasticsearch.common.time.DateFormatter
-
Try to parse input to a java time TemporalAccessor
- parse(String) - Static method in class org.elasticsearch.common.util.LocaleUtils
-
Parse the given locale as
language
,language-country
orlanguage-country-variant
. - parse(String) - Static method in enum class org.elasticsearch.common.util.PageCacheRecycler.Type
- parse(String) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- parse(String) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- parse(String) - Static method in enum class org.elasticsearch.index.SlowLogLevel
- parse(String) - Static method in enum class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.SeasonalityType
-
Parse a string SeasonalityType into the byte enum
- parse(String) - Static method in class org.elasticsearch.search.aggregations.support.AggregationPath
- parse(String, LongSupplier) - Method in interface org.elasticsearch.common.time.DateMathParser
-
Parse a date math expression without timezone info and rounding down.
- parse(String, LongSupplier, boolean, ZoneId) - Method in class org.elasticsearch.common.joda.JodaDateMathParser
- parse(String, LongSupplier, boolean, ZoneId) - Method in interface org.elasticsearch.common.time.DateMathParser
-
Parse text, that potentially contains date math into the milliseconds since the epoch Examples are
2014-11-18||-2y
subtracts two years from the input datenow/m
rounds the current time to minute granularity Supported rounding units are y year M month w week (beginning on a monday) d day h/H hour m minute s second - parse(String, LongSupplier, boolean, ZoneId) - Method in class org.elasticsearch.common.time.JavaDateMathParser
- parse(String, LongSupplier, boolean, DateTimeZone) - Method in interface org.elasticsearch.common.time.DateMathParser
-
Deprecated.
- parse(String, Map<String, Object>, MappingParserContext) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper.TypeParser
- parse(String, Map<String, Object>, MappingParserContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.TypeParser
- parse(String, Map<String, Object>, MappingParserContext) - Method in interface org.elasticsearch.index.mapper.Mapper.TypeParser
- parse(String, Map<String, Object>, MappingParserContext) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper.ConfigurableTypeParser
- parse(String, Map<String, Object>, MappingParserContext) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper.FixedTypeParser
- parse(String, Map<String, Object>, MappingParserContext) - Method in interface org.elasticsearch.index.mapper.MetadataFieldMapper.TypeParser
- parse(String, Map<String, Object>, MappingParserContext) - Method in class org.elasticsearch.index.mapper.NestedObjectMapper.TypeParser
- parse(String, Map<String, Object>, MappingParserContext) - Method in class org.elasticsearch.index.mapper.ObjectMapper.TypeParser
- parse(String, CompressedXContent) - Method in class org.elasticsearch.index.mapper.MappingParser
- parse(String, CompressedXContent, String) - Method in class org.elasticsearch.index.mapper.MappingParser
- parse(String, DistanceUnit) - Method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Parses a given distance and converts it to this unit.
- parse(String, DistanceUnit, DistanceUnit) - Static method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Parses a given distance and converts it to the specified unit.
- parse(String, MappingParserContext, Object) - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Parse the field value from an Object
- parse(String, MappingParserContext, Map<String, Object>) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
Parse mapping parameters from a map of mappings
- parse(String, MappingParserContext, Map<String, Object>) - Method in class org.elasticsearch.index.mapper.RuntimeField.Builder
- parse(String, DeprecationHandler) - Static method in enum class org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
- parse(String, DeprecationHandler) - Static method in enum class org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
- parse(String, XContentLocation) - Static method in enum class org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Parse a string GapPolicy into the byte enum
- parse(String, XContentParser) - Method in interface org.elasticsearch.search.aggregations.Aggregator.Parser
-
Returns the aggregator factory with which this parser is associated, may return
null
indicating the aggregation should be skipped (e.g. - parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.PercentileRanksAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- parse(String, XContentParser) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsParser
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- parse(String, XContentParser) - Method in interface org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.Parser
-
Returns the pipeline aggregator factory with which this parser is associated.
- parse(String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
- parse(Map<String, Object>, String, int) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel.AbstractModelParser
-
Parse a settings hash that is specific to this model
- parse(BytesReference, String, String, String, FetchSourceContext, String, Boolean, boolean, XContentType, Consumer<IndexRequest>, Consumer<UpdateRequest>, Consumer<DeleteRequest>) - Method in class org.elasticsearch.action.bulk.BulkRequestParser
- parse(BytesReference, String, String, FetchSourceContext, String, Boolean, boolean, XContentType, Consumer<IndexRequest>, Consumer<UpdateRequest>, Consumer<DeleteRequest>) - Method in class org.elasticsearch.action.bulk.BulkRequestParser
-
Parse the provided
data
assuming the provided default values. - parse(BytesReference, XContentType) - Static method in class org.elasticsearch.script.StoredScriptSource
-
This will parse XContent into a
StoredScriptSource
. - parse(Settings) - Static method in class org.elasticsearch.script.Script
-
Parse the script configured in the given settings.
- parse(ParseFieldRegistry<MovAvgModel.AbstractModelParser>, String, XContentParser) - Static method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
- parse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- parse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper
-
Parses and indexes inputs Parsing: Acceptable format: "STRING" - interpreted as field value (input) "ARRAY" - each element can be one of "OBJECT" (see below) "OBJECT" - { "input": STRING|ARRAY, "weight": STRING|INT, "contexts": ARRAY|OBJECT } Indexing: if context mappings are defined, delegates to
ContextMappings.addField(LuceneDocument, String, String, int, Map)
else adds inputs as aSuggestField
- parse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.FieldMapper
-
Parse the field value using the provided
DocumentParserContext
. - parse(FieldMapper, DocumentParserContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields
- parse(SourceToParse) - Method in class org.elasticsearch.index.mapper.DocumentMapper
- parse(MultiMatchQueryBuilder.Type, Map<String, Float>, Object, String) - Method in class org.elasticsearch.index.search.MultiMatchQueryParser
- parse(MatchQueryParser.Type, String, Object) - Method in class org.elasticsearch.index.search.MatchQueryParser
- parse(XContentParser) - Static method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
- parse(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.ComponentTemplate
- parse(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- parse(XContentParser) - Static method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- parse(XContentParser) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- parse(XContentParser) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateEmptyPrimaryAllocationCommand.Builder
- parse(XContentParser) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateReplicaAllocationCommand.Builder
- parse(XContentParser) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocateStalePrimaryAllocationCommand.Builder
- parse(XContentParser) - Method in class org.elasticsearch.common.geo.GeometryParser
-
Parses supplied XContent into Geometry
- parse(XContentParser) - Static method in class org.elasticsearch.common.unit.Fuzziness
- parse(XContentParser) - Static method in class org.elasticsearch.script.Script
-
Convenience method to call
Script.parse(XContentParser, String)
using the default scripting language. - parse(XContentParser) - Method in interface org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder.PrecisionParser
- parse(XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.PercentageScore
- parse(XContentParser, boolean) - Method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- parse(XContentParser, String) - Static method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- parse(XContentParser, String) - Static method in class org.elasticsearch.script.Script
-
This will parse XContent into a
Script
. - parse(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- parse(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- parse(XContentParser, String) - Static method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- parse(XContentParser, CheckedConsumer<Geometry, IOException>, Consumer<Exception>) - Method in class org.elasticsearch.index.mapper.GeoShapeParser
- parse(XContentParser, CheckedConsumer<T, IOException>, Consumer<Exception>) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.Parser
-
Parse the given xContent value to one or more objects of type
AbstractGeometryFieldMapper.Parser
. - parse(XContentParser, CheckedConsumer<T, IOException>, Consumer<Exception>) - Method in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.PointParser
- parse(XContentParser, MoreLikeThisQueryBuilder.Item) - Static method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
Parses and returns the given item.
- Parse(DateFieldScript) - Constructor for class org.elasticsearch.script.DateFieldScript.Parse
- PARSE_FROM_SOURCE - Static variable in class org.elasticsearch.script.BooleanFieldScript
- PARSE_FROM_SOURCE - Static variable in class org.elasticsearch.script.DateFieldScript
- PARSE_FROM_SOURCE - Static variable in class org.elasticsearch.script.DoubleFieldScript
- PARSE_FROM_SOURCE - Static variable in class org.elasticsearch.script.GeoPointFieldScript
- PARSE_FROM_SOURCE - Static variable in class org.elasticsearch.script.IpFieldScript
- PARSE_FROM_SOURCE - Static variable in class org.elasticsearch.script.LongFieldScript
- PARSE_FROM_SOURCE - Static variable in class org.elasticsearch.script.StringFieldScript
- parseAggregators(XContentParser) - Static method in class org.elasticsearch.search.aggregations.AggregatorFactories
-
Parses the aggregation request recursively generating aggregator factories in turn.
- parseAliasFilter(CheckedFunction<BytesReference, QueryBuilder, IOException>, IndexMetadata, String...) - Static method in class org.elasticsearch.search.internal.ShardSearchRequest
-
Returns the filter associated with listed filtering aliases.
- parseArticles(Environment, Settings) - Static method in class org.elasticsearch.index.analysis.Analysis
- parseBoolParam(Map<String, Object>, String, boolean) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel.AbstractModelParser
-
Extracts a boolean from the settings map, otherwise throws an exception
- parseBoundingBox(XContentParser) - Static method in class org.elasticsearch.common.geo.GeoBoundingBox
-
Parses the bounding box and returns bottom, top, left, right coordinates
- parseByteSize(String, ByteSizeValue, ByteSizeValue, String) - Static method in class org.elasticsearch.common.settings.Setting
- parseBytesRef(String) - Method in class org.elasticsearch.search.DocValueFormat.BinaryDocValueFormat
- parseBytesRef(String) - Method in class org.elasticsearch.search.DocValueFormat.IpDocValueFormat
- parseBytesRef(String) - Method in interface org.elasticsearch.search.DocValueFormat
-
Parse a value that was formatted with
DocValueFormat.format(BytesRef)
back to the original BytesRef. - parseBytesRef(String) - Method in class org.elasticsearch.search.DocValueFormat.RawDocValueFormat
- parseBytesSizeValue(String, String) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
- parseBytesSizeValue(String, ByteSizeValue, String) - Static method in class org.elasticsearch.common.unit.ByteSizeValue
- parseBytesSizeValueOrHeapRatio(String, String) - Static method in enum class org.elasticsearch.common.unit.MemorySizeValue
-
Parse the provided string as a memory size.
- parseCidr(String) - Static method in class org.elasticsearch.common.network.InetAddresses
-
Parse an IP address and its prefix length using the CIDR notation.
- parseCommonWords(Environment, Settings, CharArraySet, boolean) - Static method in class org.elasticsearch.index.analysis.Analysis
- parseContentType(List<String>) - Static method in class org.elasticsearch.rest.RestRequest
-
Parses the given content type string for the media type.
- parseContext(DocumentParserContext, XContentParser) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
-
Parse a set of
CharSequence
contexts at index-time. - parseContext(DocumentParserContext, XContentParser) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Parses a set of index-time contexts.
- parseContext(DocumentParserContext, XContentParser) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
-
Parse a set of
CharSequence
contexts at index-time. - parseContext(LuceneDocument) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
- parseContext(LuceneDocument) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Retrieves a set of context from a
document
at index-time. - parseContext(LuceneDocument) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- parseCopyFields(Object) - Static method in class org.elasticsearch.index.mapper.TypeParsers
- parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper
- parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper
- parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper
- parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper
- parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.DocCountFieldMapper
- parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.FieldMapper
-
Parse the field value and populate the fields on
DocumentParserContext.doc()
. - parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper
- parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper
- parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper
- parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper
- parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper
- parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper
- parseCreateField(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper
- ParsedAdjacencyMatrix - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- ParsedAdjacencyMatrix() - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.ParsedAdjacencyMatrix
- ParsedAdjacencyMatrix.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.adjacency
- ParsedAggregation - Class in org.elasticsearch.search.aggregations
-
An implementation of
Aggregation
that is parsed from a REST response. - ParsedAggregation() - Constructor for class org.elasticsearch.search.aggregations.ParsedAggregation
- parseDateTimeFormatter(Object) - Static method in class org.elasticsearch.index.mapper.TypeParsers
- ParsedAutoDateHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
- ParsedAutoDateHistogram() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram
- ParsedAutoDateHistogram.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
- ParsedAvg - Class in org.elasticsearch.search.aggregations.metrics
- ParsedAvg() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedAvg
- ParsedBinaryRange - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedBinaryRange() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange
- ParsedBinaryRange.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.adjacency.ParsedAdjacencyMatrix.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedDateRange.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedGeoDistance.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongRareTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedRareTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantLongTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantStringTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringRareTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms.ParsedBucket
- ParsedBucket() - Constructor for class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- ParsedBucketMetricValue - Class in org.elasticsearch.search.aggregations.pipeline
- ParsedBucketMetricValue() - Constructor for class org.elasticsearch.search.aggregations.pipeline.ParsedBucketMetricValue
- ParsedCardinality - Class in org.elasticsearch.search.aggregations.metrics
- ParsedCardinality() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedCardinality
- ParsedComposite - Class in org.elasticsearch.search.aggregations.bucket.composite
- ParsedComposite() - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite
- ParsedComposite.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.composite
- ParsedDateHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
- ParsedDateHistogram() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ParsedDateHistogram
- ParsedDateHistogram.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
- ParsedDateRange - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedDateRange() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedDateRange
- ParsedDateRange.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedDerivative - Class in org.elasticsearch.search.aggregations.pipeline
- ParsedDerivative() - Constructor for class org.elasticsearch.search.aggregations.pipeline.ParsedDerivative
- parsedDoc() - Method in class org.elasticsearch.index.engine.Engine.Index
- ParsedDocument - Class in org.elasticsearch.index.mapper
-
The result of parsing a document.
- ParsedDocument(Field, SeqNoFieldMapper.SequenceIDFields, String, String, String, List<LuceneDocument>, BytesReference, XContentType, Mapping) - Constructor for class org.elasticsearch.index.mapper.ParsedDocument
- ParsedDoubleTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedDoubleTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedDoubleTerms
- ParsedDoubleTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedExtendedStats - Class in org.elasticsearch.search.aggregations.metrics
- ParsedExtendedStats() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- ParsedExtendedStatsBucket - Class in org.elasticsearch.search.aggregations.pipeline
- ParsedExtendedStatsBucket() - Constructor for class org.elasticsearch.search.aggregations.pipeline.ParsedExtendedStatsBucket
- ParsedFilter - Class in org.elasticsearch.search.aggregations.bucket.filter
- ParsedFilter() - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilter
- ParsedFilters - Class in org.elasticsearch.search.aggregations.bucket.filter
- ParsedFilters() - Constructor for class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters
- ParsedFilters.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.filter
- ParsedGeoBounds - Class in org.elasticsearch.search.aggregations.metrics
- ParsedGeoBounds() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedGeoBounds
- ParsedGeoCentroid - Class in org.elasticsearch.search.aggregations.metrics
-
Serialization and merge logic for
GeoCentroidAggregator
. - ParsedGeoCentroid() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedGeoCentroid
- ParsedGeoDistance - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedGeoDistance() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedGeoDistance
- ParsedGeoDistance.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedGeoGrid - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- ParsedGeoGrid() - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoGrid
- ParsedGeoGridBucket - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- ParsedGeoGridBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoGridBucket
- ParsedGeoHashGrid - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- ParsedGeoHashGrid() - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoHashGrid
- ParsedGeoHashGridBucket - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- ParsedGeoHashGridBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoHashGridBucket
- ParsedGeometryQueryParams() - Constructor for class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- ParsedGeoTileGrid - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- ParsedGeoTileGrid() - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoTileGrid
- ParsedGeoTileGridBucket - Class in org.elasticsearch.search.aggregations.bucket.geogrid
- ParsedGeoTileGridBucket() - Constructor for class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoTileGridBucket
- ParsedGlobal - Class in org.elasticsearch.search.aggregations.bucket.global
- ParsedGlobal() - Constructor for class org.elasticsearch.search.aggregations.bucket.global.ParsedGlobal
- ParsedHDRPercentileRanks - Class in org.elasticsearch.search.aggregations.metrics
- ParsedHDRPercentileRanks() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedHDRPercentileRanks
- ParsedHDRPercentiles - Class in org.elasticsearch.search.aggregations.metrics
- ParsedHDRPercentiles() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedHDRPercentiles
- ParsedHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
- ParsedHistogram() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ParsedHistogram
- parseDistance(String) - Static method in class org.elasticsearch.common.unit.DistanceUnit.Distance
-
Parse a
DistanceUnit.Distance
from a given String. - ParsedLongRareTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedLongRareTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongRareTerms
- ParsedLongRareTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedLongTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedLongTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedLongTerms
- ParsedLongTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- parsedMatchAllQuery() - Static method in class org.elasticsearch.index.query.ParsedQuery
- ParsedMax - Class in org.elasticsearch.search.aggregations.metrics
- ParsedMax() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedMax
- ParsedMedianAbsoluteDeviation - Class in org.elasticsearch.search.aggregations.metrics
- ParsedMedianAbsoluteDeviation() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedMedianAbsoluteDeviation
- ParsedMin - Class in org.elasticsearch.search.aggregations.metrics
- ParsedMin() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedMin
- ParsedMissing - Class in org.elasticsearch.search.aggregations.bucket.missing
- ParsedMissing() - Constructor for class org.elasticsearch.search.aggregations.bucket.missing.ParsedMissing
- ParsedMultiBucketAggregation<B extends MultiBucketsAggregation.Bucket> - Class in org.elasticsearch.search.aggregations
- ParsedMultiBucketAggregation() - Constructor for class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation
- ParsedMultiBucketAggregation.ParsedBucket - Class in org.elasticsearch.search.aggregations
- ParsedNested - Class in org.elasticsearch.search.aggregations.bucket.nested
- ParsedNested() - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ParsedNested
- parseDocument(SourceToParse) - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Parse a document with current mapping.
- parseDocument(SourceToParse, MappingLookup) - Method in class org.elasticsearch.index.mapper.DocumentParser
-
Parse a document
- parseDouble(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.BooleanDocValueFormat
- parseDouble(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- parseDouble(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- parseDouble(String, boolean, LongSupplier) - Method in interface org.elasticsearch.search.DocValueFormat
-
Parse a value that was formatted with
DocValueFormat.format(double)
back to the original double value. - parseDouble(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.RawDocValueFormat
- parseDouble(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.UnsignedLongShiftedDocValueFormat
- parseDouble(String, double, double, String, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- parseDouble(XContentParser, double) - Static method in class org.elasticsearch.search.aggregations.ParsedAggregation
-
Parse a token of type XContentParser.Token.VALUE_NUMBER or XContentParser.Token.STRING to a double.
- parseDoubleParam(Map<String, Object>, String, double) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel.AbstractModelParser
-
Extracts a 0-1 inclusive double from the settings map, otherwise throws an exception
- parsedParamsFromXContent(XContentParser, AbstractGeometryQueryBuilder.ParsedGeometryQueryParams) - Static method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- ParsedPercentiles - Class in org.elasticsearch.search.aggregations.metrics
- ParsedPercentiles() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedPercentiles
- ParsedPercentilesBucket - Class in org.elasticsearch.search.aggregations.pipeline
- ParsedPercentilesBucket() - Constructor for class org.elasticsearch.search.aggregations.pipeline.ParsedPercentilesBucket
- parsedPostFilter() - Method in class org.elasticsearch.search.fetch.FetchContext
-
Any post-filters run as part of the search
- parsedPostFilter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- parsedPostFilter() - Method in class org.elasticsearch.search.internal.SearchContext
- parsedPostFilter(ParsedQuery) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- parsedPostFilter(ParsedQuery) - Method in class org.elasticsearch.search.internal.SearchContext
- parsedPostFilter(ParsedQuery) - Method in class org.elasticsearch.search.internal.SubSearchContext
- parsedQuery() - Method in class org.elasticsearch.search.fetch.FetchContext
-
The original query with additional filters and named queries
- parsedQuery() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- parsedQuery() - Method in class org.elasticsearch.search.internal.SearchContext
- parsedQuery() - Method in class org.elasticsearch.search.internal.SubSearchContext
- parsedQuery(ParsedQuery) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- parsedQuery(ParsedQuery) - Method in class org.elasticsearch.search.internal.SearchContext
- parsedQuery(ParsedQuery) - Method in class org.elasticsearch.search.internal.SubSearchContext
- ParsedQuery - Class in org.elasticsearch.index.query
-
The result of parsing a query.
- ParsedQuery(Query) - Constructor for class org.elasticsearch.index.query.ParsedQuery
- ParsedQuery(Query, Map<String, Query>) - Constructor for class org.elasticsearch.index.query.ParsedQuery
-
Store the query and filters.
- ParsedQuery(Query, ParsedQuery) - Constructor for class org.elasticsearch.index.query.ParsedQuery
- ParsedRange - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedRange() - Constructor for class org.elasticsearch.search.aggregations.bucket.range.ParsedRange
- ParsedRange.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.range
- ParsedRareTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedRareTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedRareTerms
- ParsedRareTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedReverseNested - Class in org.elasticsearch.search.aggregations.bucket.nested
- ParsedReverseNested() - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ParsedReverseNested
- ParsedSampler - Class in org.elasticsearch.search.aggregations.bucket.sampler
- ParsedSampler() - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.ParsedSampler
- ParsedScriptedMetric - Class in org.elasticsearch.search.aggregations.metrics
- ParsedScriptedMetric() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedScriptedMetric
- ParsedScrollId - Class in org.elasticsearch.action.search
- ParsedSignificantLongTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedSignificantLongTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantLongTerms
- ParsedSignificantLongTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedSignificantStringTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedSignificantStringTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantStringTerms
- ParsedSignificantStringTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedSignificantTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedSignificantTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms
- ParsedSignificantTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedSimpleValue - Class in org.elasticsearch.search.aggregations.pipeline
- ParsedSimpleValue() - Constructor for class org.elasticsearch.search.aggregations.pipeline.ParsedSimpleValue
- ParsedSingleBucketAggregation - Class in org.elasticsearch.search.aggregations.bucket
-
A base class for all the single bucket aggregations.
- ParsedSingleBucketAggregation() - Constructor for class org.elasticsearch.search.aggregations.bucket.ParsedSingleBucketAggregation
- ParsedSingleValueNumericMetricsAggregation - Class in org.elasticsearch.search.aggregations.metrics
- ParsedSingleValueNumericMetricsAggregation() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- ParsedStats - Class in org.elasticsearch.search.aggregations.metrics
- ParsedStats() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedStats
- ParsedStatsBucket - Class in org.elasticsearch.search.aggregations.pipeline
- ParsedStatsBucket() - Constructor for class org.elasticsearch.search.aggregations.pipeline.ParsedStatsBucket
- ParsedStringRareTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedStringRareTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringRareTerms
- ParsedStringRareTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedStringTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedStringTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedStringTerms
- ParsedStringTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedSum - Class in org.elasticsearch.search.aggregations.metrics
- ParsedSum() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedSum
- ParsedTDigestPercentileRanks - Class in org.elasticsearch.search.aggregations.metrics
- ParsedTDigestPercentileRanks() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentileRanks
- ParsedTDigestPercentiles - Class in org.elasticsearch.search.aggregations.metrics
- ParsedTDigestPercentiles() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentiles
- ParsedTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedTerms() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- ParsedTerms.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- ParsedTopHits - Class in org.elasticsearch.search.aggregations.metrics
- ParsedTopHits() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedTopHits
- ParsedValueCount - Class in org.elasticsearch.search.aggregations.metrics
- ParsedValueCount() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedValueCount
- ParsedVariableWidthHistogram - Class in org.elasticsearch.search.aggregations.bucket.histogram
- ParsedVariableWidthHistogram() - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram
- ParsedVariableWidthHistogram.ParsedBucket - Class in org.elasticsearch.search.aggregations.bucket.histogram
- ParsedWeightedAvg - Class in org.elasticsearch.search.aggregations.metrics
- ParsedWeightedAvg() - Constructor for class org.elasticsearch.search.aggregations.metrics.ParsedWeightedAvg
- parseEntries(XContentParser, Suggest.Suggestion<E>, CheckedFunction<XContentParser, E, IOException>) - Static method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- parseExclude(XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- parseField() - Method in enum class org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
- parseField() - Method in enum class org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
- ParseFieldRegistry<T> - Class in org.elasticsearch.common.xcontent
-
Registry for looking things up using ParseField semantics.
- ParseFieldRegistry(String) - Constructor for class org.elasticsearch.common.xcontent.ParseFieldRegistry
-
Build the registry.
- parseFieldsAndWeights(List<String>) - Static method in class org.elasticsearch.index.search.QueryParserHelper
-
Convert a list of field names encoded with optional boosts to a map that associates the field name and its boost.
- parseFieldsValue(XContentParser) - Static method in class org.elasticsearch.common.xcontent.XContentParserUtils
-
Parse the current token depending on its token type.
- parseFrom(RangeFieldMapper.RangeFieldType, XContentParser, boolean, boolean) - Method in enum class org.elasticsearch.index.mapper.RangeType
-
parses from value.
- parseFromRestRequest(RestRequest) - Static method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- parseFromString(String) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Parse a
GeoPoint
from a string. - parseFromXContent(XContentParser) - Static method in class org.elasticsearch.search.rescore.RescorerBuilder
- parseGeometry(Object) - Method in class org.elasticsearch.common.geo.GeometryParser
-
Parses the value as a
Geometry
. - parseGeoPoint(Object, boolean) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Parses the value as a geopoint.
- parseGeoPoint(Object, GeoPoint, boolean) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Parses the value as a geopoint.
- parseGeoPoint(XContentParser) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Parse a
GeoPoint
with aXContentParser
: - parseGeoPoint(XContentParser, GeoPoint) - Static method in class org.elasticsearch.common.geo.GeoUtils
- parseGeoPoint(XContentParser, GeoPoint, boolean) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Parse a geopoint represented as an object, string or an array.
- parseGeoPoint(XContentParser, GeoPoint, boolean, GeoUtils.EffectivePoint) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Parse a
GeoPoint
with aXContentParser
. - parseIdFromFileName(Path) - Static method in class org.elasticsearch.index.translog.Translog
-
Extracts the translog generation from a file name.
- parseIds(XContentParser, List<MultiGetRequest.Item>, String, String, String[], FetchSourceContext, String) - Static method in class org.elasticsearch.action.get.MultiGetRequest
- parseInclude(XContentParser) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- parseIndexNameCounter(String) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Parses the number from the rolled over index name.
- parseInnerQueryBuilder(XContentParser) - Static method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Parses a query excluding the query element that wraps it
- parseInnerQueryBuilder(XContentParser) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- parseInnerQueryBuilder(XContentParser, Integer) - Static method in class org.elasticsearch.index.query.AbstractQueryBuilder
- parseInnerToXContent(XContentParser, DocWriteResponse.Builder) - Static method in class org.elasticsearch.action.DocWriteResponse
-
Parse the output of the
DocWriteResponse.innerToXContent(XContentBuilder, Params)
method. - parseInt(String, int, int, String) - Static method in class org.elasticsearch.common.settings.Setting
- parseInt(String, int, int, String, boolean) - Static method in class org.elasticsearch.common.settings.Setting
- parseInt(String, int, String) - Static method in class org.elasticsearch.common.settings.Setting
- parseInt(String, int, String, boolean) - Static method in class org.elasticsearch.common.settings.Setting
- parseIntegerParam(Map<String, Object>, String, int) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel.AbstractModelParser
-
Extracts an integer from the settings map, otherwise throws an exception
- parseInto(DateTimeParserBucket, String, int) - Method in class org.elasticsearch.common.joda.Joda.EpochTimeParser
-
Deprecated.
- parseJoda(String) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- parseJoda(String) - Method in interface org.elasticsearch.common.time.DateFormatter
-
Parse the given input into a Joda
DateTime
. - parseList(XContentParser, CheckedFunction<XContentParser, T, IOException>) - Static method in class org.elasticsearch.common.xcontent.XContentParserUtils
-
Parses a list of a given type from the given
parser
. - parseLong(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.BooleanDocValueFormat
- parseLong(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- parseLong(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- parseLong(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.GeoTileDocValueFormat
- parseLong(String, boolean, LongSupplier) - Method in interface org.elasticsearch.search.DocValueFormat
-
Parse a value that was formatted with
DocValueFormat.format(long)
back to the original long value. - parseLong(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.RawDocValueFormat
- parseLong(String, boolean, LongSupplier) - Method in class org.elasticsearch.search.DocValueFormat.UnsignedLongShiftedDocValueFormat
-
Formats the unsigned long to the shifted long format
- parseLong(String, long, String) - Static method in class org.elasticsearch.common.settings.Setting
- parseMapping(String, CompressedXContent, boolean) - Method in class org.elasticsearch.index.mapper.MapperService
- parseMapping(NamedXContentRegistry, String) - Static method in class org.elasticsearch.index.mapper.MapperService
-
Parses the mappings (formatted as JSON) into a map
- parseMeta(String, Object) - Static method in class org.elasticsearch.index.mapper.TypeParsers
-
Parse the
meta
key of the mapping. - parseMillis(String) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- parseMillis(String) - Method in interface org.elasticsearch.common.time.DateFormatter
-
Parse the given input into millis-since-epoch.
- parseMultiField(Consumer<FieldMapper.Builder>, String, MappingParserContext, String, Object) - Static method in class org.elasticsearch.index.mapper.TypeParsers
- parseMultiLineRequest(RestRequest, IndicesOptions, boolean, CheckedBiConsumer<SearchRequest, XContentParser, IOException>) - Static method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
-
Parses a multi-line
RestRequest
body, instantiating aSearchRequest
for each line and applying the given consumer. - parseMultiLineRequest(RestRequest, IndicesOptions, boolean, CheckedBiConsumer<SearchRequest, XContentParser, IOException>, TriFunction<String, Object, SearchRequest, Boolean>) - Static method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
-
Parses a multi-line
RestRequest
body, instantiating aSearchRequest
for each line and applying the given consumer. - parseNested(String, Map<String, Object>, NestedObjectMapper.Builder) - Static method in class org.elasticsearch.index.mapper.NestedObjectMapper.TypeParser
- parseNestedFilter(XContentParser) - Static method in class org.elasticsearch.search.sort.SortBuilder
- parseObjectOrDocumentTypeProperties(String, Object, MappingParserContext, ObjectMapper.Builder) - Static method in class org.elasticsearch.index.mapper.ObjectMapper.TypeParser
- parseOrderParam(XContentParser) - Static method in class org.elasticsearch.search.aggregations.InternalOrder.Parser
-
Parse a
BucketOrder
fromXContent
. - parseParameter(Object, EnumSet<IndicesOptions.WildcardStates>) - Static method in enum class org.elasticsearch.action.support.IndicesOptions.WildcardStates
- parsePoint(byte[]) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- parsePoint(byte[]) - Method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- parsePointAsMillis(byte[]) - Method in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
-
Decode the points representation of this field as milliseconds.
- parsePrecision(XContentParser) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Parse a precision that can be expressed as an integer or a distance measure like "1km", "10m".
- parseProperties(ObjectMapper.Builder, Map<String, Object>, MappingParserContext) - Static method in class org.elasticsearch.index.mapper.ObjectMapper.TypeParser
- parseQueryContext(XContentParser) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Parses query contexts for this mapper
- parser() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- parser() - Method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- parser() - Method in enum class org.elasticsearch.index.mapper.RangeType
- parser() - Static method in class org.elasticsearch.tasks.TaskId
- Parser() - Constructor for class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.Parser
- Parser() - Constructor for class org.elasticsearch.search.aggregations.InternalOrder.Parser
- Parser(Function<String, RuntimeField.Builder>) - Constructor for class org.elasticsearch.index.mapper.RuntimeField.Parser
- PARSER - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- PARSER - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptContextResponse
- PARSER - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Parser for any one
AliasAction
. - PARSER - Static variable in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- PARSER - Static variable in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- PARSER - Static variable in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- PARSER - Static variable in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- PARSER - Static variable in class org.elasticsearch.action.datastreams.ModifyDataStreamsAction.Request
- PARSER - Static variable in class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- PARSER - Static variable in class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
- PARSER - Static variable in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- PARSER - Static variable in class org.elasticsearch.action.ingest.SimulateProcessorResult
- PARSER - Static variable in exception org.elasticsearch.action.support.DefaultShardOperationFailedException
- PARSER - Static variable in class org.elasticsearch.cluster.health.ClusterShardHealth
- PARSER - Static variable in class org.elasticsearch.cluster.metadata.ComponentTemplate
- PARSER - Static variable in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- PARSER - Static variable in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- PARSER - Static variable in class org.elasticsearch.cluster.metadata.DataStreamAction
- PARSER - Static variable in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- PARSER - Static variable in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- PARSER - Static variable in class org.elasticsearch.cluster.metadata.Template
- PARSER - Static variable in class org.elasticsearch.index.mapper.AllFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.BinaryFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.BooleanFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.BooleanScriptFieldType
- PARSER - Static variable in class org.elasticsearch.index.mapper.CompletionFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.CompositeRuntimeField
- PARSER - Static variable in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.DateScriptFieldType
- PARSER - Static variable in class org.elasticsearch.index.mapper.DocCountFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.DoubleScriptFieldType
- PARSER - Static variable in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.GeoPointFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.GeoPointScriptFieldType
- PARSER - Static variable in class org.elasticsearch.index.mapper.GeoShapeFieldMapper
-
Deprecated.
- PARSER - Static variable in class org.elasticsearch.index.mapper.IdFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.IgnoredFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.IndexFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.IpFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.IpScriptFieldType
- PARSER - Static variable in class org.elasticsearch.index.mapper.KeywordFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- PARSER - Static variable in class org.elasticsearch.index.mapper.LongScriptFieldType
- PARSER - Static variable in class org.elasticsearch.index.mapper.RoutingFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.SourceFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.TextFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.TypeFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.mapper.VersionFieldMapper
- PARSER - Static variable in class org.elasticsearch.index.query.functionscore.ExponentialDecayFunctionBuilder
- PARSER - Static variable in class org.elasticsearch.index.query.functionscore.GaussDecayFunctionBuilder
- PARSER - Static variable in class org.elasticsearch.index.query.functionscore.LinearDecayFunctionBuilder
- PARSER - Static variable in class org.elasticsearch.repositories.RepositoryCleanupResult
- PARSER - Static variable in class org.elasticsearch.script.ScriptContextInfo
- PARSER - Static variable in class org.elasticsearch.script.ScriptLanguagesInfo
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.LongBounds
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ChiSquare
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.GND
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.JLHScore
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.MutualInformation
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.PercentageScore
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.LinearModel
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.MaxBucketPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.MinBucketPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.SimpleModel
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.StatsBucketPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.pipeline.SumBucketPipelineAggregationBuilder
- PARSER - Static variable in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- PARSER - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- PARSER - Static variable in class org.elasticsearch.snapshots.SnapshotInfo.IndexSnapshotDetails
- PARSER - Static variable in class org.elasticsearch.tasks.TaskInfo
- PARSER - Static variable in class org.elasticsearch.tasks.TaskResult
- PARSER - Static variable in class org.elasticsearch.upgrades.FeatureMigrationResults
- PARSER - Static variable in class org.elasticsearch.upgrades.SystemIndexMigrationTaskParams
- PARSER_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.InternalSampler
- parseRangeBucketXContent(XContentParser, Supplier<B>, boolean) - Static method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- parseRatioValue(String) - Static method in class org.elasticsearch.common.unit.RatioValue
-
Parses the provided string as a
RatioValue
, the string can either be in percentage format (eg. - parserContext() - Method in class org.elasticsearch.index.mapper.MapperService
- parseRelativeByteSizeValue(String, String) - Static method in class org.elasticsearch.common.unit.RelativeByteSizeValue
- parseRequest(TermVectorsRequest, XContentParser) - Static method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
populates a request object (pre-populated with defaults) based on a parser.
- parseRequest(RestRequest, NamedWriteableRegistry, boolean) - Static method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
-
Parses a
RestRequest
body and returns aMultiSearchRequest
- parseRequest(RestRequest, NamedWriteableRegistry, boolean, TriFunction<String, Object, SearchRequest, Boolean>) - Static method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
-
Parses a
RestRequest
body and returns aMultiSearchRequest
. - parseRewriteMethod(String, MultiTermQuery.RewriteMethod, DeprecationHandler) - Static method in class org.elasticsearch.index.query.support.QueryParsers
- parseRewriteMethod(String, DeprecationHandler) - Static method in class org.elasticsearch.index.query.support.QueryParsers
- parseRuntimeFields(Map<String, Object>, MappingParserContext, boolean) - Static method in interface org.elasticsearch.index.mapper.RuntimeField
-
Parse runtime fields from the provided map, using the provided parser context.
- parseRuntimeFields(Map<String, Object>, MappingParserContext, Function<RuntimeField.Builder, RuntimeField>, boolean) - Static method in interface org.elasticsearch.index.mapper.RuntimeField
-
Parse runtime fields from the provided map, using the provided parser context.
- parsesArrayValue() - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper
- parsesArrayValue() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper
- parsesArrayValue() - Method in class org.elasticsearch.index.mapper.FieldMapper
-
Whether this mapper can handle an array value during document parsing.
- parseScoreMode(String) - Static method in class org.elasticsearch.index.query.NestedQueryBuilder
- parseScript(String, MappingParserContext, Object) - Static method in interface org.elasticsearch.index.mapper.RuntimeField
- parseScrollId() - Method in class org.elasticsearch.action.search.SearchScrollRequest
- parseSearchRequest(SearchRequest, RestRequest, XContentParser, NamedWriteableRegistry, IntConsumer) - Static method in class org.elasticsearch.rest.action.search.RestSearchAction
-
Parses the rest request on top of the SearchRequest, preserving values that are not overridden by the rest request.
- parseSearchRequest(SearchRequest, RestRequest, XContentParser, NamedWriteableRegistry, IntConsumer, BiConsumer<RestRequest, SearchRequest>) - Static method in class org.elasticsearch.rest.action.search.RestSearchAction
-
Parses the rest request on top of the SearchRequest, preserving values that are not overridden by the rest request.
- parseSizeValue(String) - Static method in class org.elasticsearch.common.unit.SizeValue
- parseSizeValue(String, SizeValue) - Static method in class org.elasticsearch.common.unit.SizeValue
- parseSourceValue(Object) - Method in class org.elasticsearch.index.mapper.ArraySourceValueFetcher
-
Given a value that has been extracted from a document's source, parse it into a standard format.
- parseSourceValue(Object) - Method in class org.elasticsearch.index.mapper.SourceValueFetcher
-
Given a value that has been extracted from a document's source, parse it into a standard format.
- parseStemExclusion(Settings, CharArraySet) - Static method in class org.elasticsearch.index.analysis.Analysis
- parseStopWords(Environment, Settings, CharArraySet) - Static method in class org.elasticsearch.index.analysis.Analysis
- parseStopWords(Environment, Settings, CharArraySet, boolean) - Static method in class org.elasticsearch.index.analysis.Analysis
- parseString(String) - Static method in class org.elasticsearch.action.support.ActiveShardCount
-
Parses the active shard count from the given string.
- parseString(String) - Static method in enum class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
- parseString(String, boolean) - Static method in enum class org.elasticsearch.cluster.ClusterState.Metric
- parseStringOffset(String) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
-
Parse the string specification of an offset.
- parseTermsLookup(XContentParser) - Static method in class org.elasticsearch.indices.TermsLookup
- parseTierList(String) - Static method in class org.elasticsearch.cluster.routing.allocation.DataTier
- parseTimeValue(String, TimeValue, String) - Static method in class org.elasticsearch.common.settings.Setting
- parseTo(RangeFieldMapper.RangeFieldType, XContentParser, boolean, boolean) - Method in enum class org.elasticsearch.index.mapper.RangeType
-
parses to value.
- parseToLong(Object, boolean, ZoneId, DateMathParser, LongSupplier) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- parseToLong(Object, boolean, ZoneId, DateMathParser, LongSupplier, DateFieldMapper.Resolution) - Static method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- parseTotalHitsFragment(XContentParser) - Static method in class org.elasticsearch.search.SearchHits
- parseTypedKeysObject(XContentParser, String, Class<T>, Consumer<T>) - Static method in class org.elasticsearch.common.xcontent.XContentParserUtils
-
This method expects that the current field name is the concatenation of a type, a delimiter and a name (ex: terms#foo where "terms" refers to the type of a registered
NamedXContentRegistry.Entry
, "#" is the delimiter and "foo" the name of the object to parse). - parseUnit(String, DistanceUnit) - Static method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Parses the suffix of a given distance string and return the corresponding
DistanceUnit
- parseValue(Object, boolean, DateMathParser) - Method in enum class org.elasticsearch.index.mapper.RangeType
- parseValue(String) - Static method in enum class org.elasticsearch.common.breaker.CircuitBreaker.Type
- parseVersion(String, Version, Logger) - Static method in class org.elasticsearch.common.lucene.Lucene
- parseVersion(RestRequest) - Static method in class org.elasticsearch.rest.action.RestActions
- parseVersion(RestRequest, long) - Static method in class org.elasticsearch.rest.action.RestActions
- parseVersionLenient(String, Version) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Parses the version string lenient and returns the default value if the given string is null or empty
- parseWords(Environment, Settings, String, CharArraySet, Map<String, Set<?>>, boolean) - Static method in class org.elasticsearch.index.analysis.Analysis
- parseXContent(XContentParser) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- parseXContent(XContentParser, boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Parse some xContent into this SearchSourceBuilder, overwriting any values specified in the xContent.
- parseXContent(XContentParser, boolean, Supplier<B>, CheckedBiConsumer<XContentParser, B, IOException>) - Static method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- parseXContent(XContentParser, T, String) - Static method in class org.elasticsearch.search.aggregations.bucket.ParsedSingleBucketAggregation
- parseXContentField(XContentParser) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- parseXContentFields(XContentParser, DeleteResponse.Builder) - Static method in class org.elasticsearch.action.delete.DeleteResponse
-
Parse the current token and update the parsing context appropriately.
- parseXContentFields(XContentParser, IndexResponse.Builder) - Static method in class org.elasticsearch.action.index.IndexResponse
-
Parse the current token and update the parsing context appropriately.
- parseXContentFields(XContentParser, UpdateResponse.Builder) - Static method in class org.elasticsearch.action.update.UpdateResponse
-
Parse the current token and update the parsing context appropriately.
- PARSING - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- ParsingException - Exception in org.elasticsearch.common
-
Exception that can be used when parsing queries with a given
XContentParser
. - ParsingException(int, int, String, Throwable) - Constructor for exception org.elasticsearch.common.ParsingException
-
This constructor is provided for use in unit tests where a
XContentParser
may not be available - ParsingException(StreamInput) - Constructor for exception org.elasticsearch.common.ParsingException
- ParsingException(XContentLocation, String, Object...) - Constructor for exception org.elasticsearch.common.ParsingException
- ParsingException(XContentLocation, String, Throwable, Object...) - Constructor for exception org.elasticsearch.common.ParsingException
- partBytes(int) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns the size (in bytes) of a given part
- partial() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns true if indices with unavailable shards should be be partially snapshotted.
- partial() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns true if indices with failed to snapshot shards should be partially restored.
- partial() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- partial(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Set to true to allow indices with unavailable shards to be partially snapshotted.
- partial(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Set to true to allow indices with failed to snapshot shards should be partially restored.
- PARTIAL - Enum constant in enum class org.elasticsearch.snapshots.SnapshotState
-
Snapshot was partial successful
- PARTIAL_CONTENT - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server has fulfilled the partial GET request for the resource.
- partiallyBuiltBucketComparator - Variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- partiallyBuiltBucketComparator(ToLongFunction<T>, Aggregator) - Method in class org.elasticsearch.search.aggregations.BucketOrder
-
A builds comparator comparing buckets partially built buckets by delegating comparison of the results of any "child" aggregations to the provided Aggregator.
- partiallyBuiltBucketComparator(ToLongFunction<T>, Aggregator) - Method in class org.elasticsearch.search.aggregations.InternalOrder.Aggregation
- partiallyBuiltBucketComparator(ToLongFunction<T>, Aggregator) - Method in class org.elasticsearch.search.aggregations.InternalOrder.CompoundOrder
- PARTITION_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- PartitionedLongFilter() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.PartitionedLongFilter
- partName(int) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns part name if file is stored as multiple parts
- parts - Variable in class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
-
List of identifiers of already written chunks.
- parts() - Method in class org.elasticsearch.common.blobstore.BlobPath
- partSize() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns part size
- PATCH - Enum constant in enum class org.elasticsearch.rest.RestRequest.Method
- path - Variable in class org.elasticsearch.cluster.ClusterInfo.NodeAndPath
- path - Variable in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- path - Variable in class org.elasticsearch.env.NodeEnvironment.DataPath
- path - Variable in class org.elasticsearch.index.translog.BaseTranslogReader
- path() - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Gets the
BlobPath
that defines the implementation specific paths to where the blobs are contained. - path() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
- path() - Method in class org.elasticsearch.common.blobstore.support.AbstractBlobContainer
- path() - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- path() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- path() - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
- path() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- path() - Method in class org.elasticsearch.indices.TermsLookup
- path() - Method in class org.elasticsearch.rest.RestRequest
-
The path part of the URI (without the query string), decoded.
- path() - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
-
Get the path to use for this nested aggregation.
- path() - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
-
Get the path to use for this nested aggregation.
- path() - Method in class org.elasticsearch.search.aggregations.InternalOrder.Aggregation
- path(String) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper.Builder
- path(String) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
-
Set the path to use for this nested aggregation.
- Path() - Constructor for class org.elasticsearch.monitor.fs.FsInfo.Path
- Path(String, String, long, long, long) - Constructor for class org.elasticsearch.monitor.fs.FsInfo.Path
- Path(StreamInput) - Constructor for class org.elasticsearch.monitor.fs.FsInfo.Path
-
Read from a stream.
- PATH - Static variable in class org.elasticsearch.index.mapper.FieldAliasMapper.Names
- PATH_DATA_SETTING - Static variable in class org.elasticsearch.env.Environment
- PATH_FIELD - Static variable in class org.elasticsearch.search.sort.NestedSortBuilder
- PATH_HOME_SETTING - Static variable in class org.elasticsearch.env.Environment
- PATH_LOGS_SETTING - Static variable in class org.elasticsearch.env.Environment
- PATH_REPO_SETTING - Static variable in class org.elasticsearch.env.Environment
- PATH_SHARED_DATA_SETTING - Static variable in class org.elasticsearch.env.Environment
- pathAsText(String) - Method in class org.elasticsearch.index.mapper.ContentPath
- PathElement(String, String, String) - Constructor for class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
- pathMatch() - Method in class org.elasticsearch.index.mapper.DynamicTemplate
- PathTrie<T> - Class in org.elasticsearch.common.path
- PathTrie(PathTrie.Decoder) - Constructor for class org.elasticsearch.common.path.PathTrie
- PathTrie.Decoder - Interface in org.elasticsearch.common.path
- PathTrie.TrieNode - Class in org.elasticsearch.common.path
- pattern() - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- pattern() - Method in interface org.elasticsearch.common.time.DateFormatter
-
A name based format for this formatter.
- patterns() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- patterns() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- patterns(List<String>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- patterns(List<String>) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- patterns(List<String>) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutRequest
- PAY - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- payloads() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- payloads(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the payloads for each term or skip.
- Payloads - Enum constant in enum class org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
- PAYLOADS - Enum constant in enum class org.elasticsearch.index.search.stats.FieldUsageStats.UsageContext
- PAYLOADS - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- PAYMENT_REQUIRED - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
This code is reserved for future use.
- PB - Enum constant in enum class org.elasticsearch.common.unit.ByteSizeUnit
- peek() - Method in class org.elasticsearch.common.collect.EvictingQueue
- peek() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- PEER - Enum constant in enum class org.elasticsearch.cluster.routing.RecoverySource.Type
- PEER_RECOVERY - Enum constant in enum class org.elasticsearch.index.engine.Engine.Operation.Origin
- PEER_RECOVERY_RETENTION_LEASE_SOURCE - Static variable in class org.elasticsearch.index.seqno.ReplicationTracker
-
Source for peer recovery retention leases; see
ReplicationTracker.addPeerRecoveryRetentionLease(java.lang.String, long, org.elasticsearch.action.ActionListener<org.elasticsearch.action.support.replication.ReplicationResponse>)
. - PeerFinder - Class in org.elasticsearch.discovery
- PeerFinder(Settings, TransportService, TransportAddressConnector, ConfiguredHostsResolver) - Constructor for class org.elasticsearch.discovery.PeerFinder
- PeerOnlyRecoveryPlannerService - Class in org.elasticsearch.indices.recovery.plan
-
Service in charge of computing a
ShardRecoveryPlan
using only the physical files from the source peer. - PeerOnlyRecoveryPlannerService() - Constructor for class org.elasticsearch.indices.recovery.plan.PeerOnlyRecoveryPlannerService
- PeerRecoveryNotFound - Exception in org.elasticsearch.indices.recovery
- PeerRecoveryNotFound(long, ShardId, String) - Constructor for exception org.elasticsearch.indices.recovery.PeerRecoveryNotFound
- PeerRecoveryNotFound(StreamInput) - Constructor for exception org.elasticsearch.indices.recovery.PeerRecoveryNotFound
- peerRecoveryRetentionLeases() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
- PeerRecoverySourceService - Class in org.elasticsearch.indices.recovery
-
The source recovery accepts recovery requests from other peer shards and start the recovery process from this source shard to the target shard.
- PeerRecoverySourceService(TransportService, IndicesService, RecoverySettings, RecoveryPlannerService) - Constructor for class org.elasticsearch.indices.recovery.PeerRecoverySourceService
- PeerRecoverySourceService.Actions - Class in org.elasticsearch.indices.recovery
- PeerRecoveryTargetService - Class in org.elasticsearch.indices.recovery
-
The recovery target handles recoveries of peer shards of the shard+node to recover to.
- PeerRecoveryTargetService(ThreadPool, TransportService, RecoverySettings, ClusterService, SnapshotFilesProvider) - Constructor for class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
- PeerRecoveryTargetService.Actions - Class in org.elasticsearch.indices.recovery
- PeerRecoveryTargetService.RecoveryListener - Interface in org.elasticsearch.indices.recovery
- PeersRequest - Class in org.elasticsearch.discovery
- PeersRequest(DiscoveryNode, List<DiscoveryNode>) - Constructor for class org.elasticsearch.discovery.PeersRequest
- PeersRequest(StreamInput) - Constructor for class org.elasticsearch.discovery.PeersRequest
- PeersResponse - Class in org.elasticsearch.cluster.coordination
- PeersResponse(Optional<DiscoveryNode>, List<DiscoveryNode>, long) - Constructor for class org.elasticsearch.cluster.coordination.PeersResponse
- PeersResponse(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.PeersResponse
- Pending(Object, Priority, long, boolean) - Constructor for class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.Pending
- PENDING_CANCEL - Enum constant in enum class org.elasticsearch.persistent.AllocatedPersistentTask.State
- PENDING_OPERATIONS - Enum constant in enum class org.elasticsearch.index.engine.Engine.SyncedFlushResult
- pendingClusterStates() - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
-
returns all pending states, committed or not
- pendingClusterStates() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- PendingClusterStatesQueue - Class in org.elasticsearch.discovery.zen
-
A queue that holds all "in-flight" incoming cluster states from the master.
- PendingClusterStatesQueue(Logger, int) - Constructor for class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
- PendingClusterStateStats - Class in org.elasticsearch.discovery.zen
-
Class encapsulating stats about the PendingClusterStatsQueue
- PendingClusterStateStats(int, int, int) - Constructor for class org.elasticsearch.discovery.zen.PendingClusterStateStats
- PendingClusterStateStats(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.PendingClusterStateStats
- PendingClusterTask - Class in org.elasticsearch.cluster.service
- PendingClusterTask(long, Priority, Text, long, boolean) - Constructor for class org.elasticsearch.cluster.service.PendingClusterTask
- PendingClusterTask(StreamInput) - Constructor for class org.elasticsearch.cluster.service.PendingClusterTask
- pendingClusterTasks(PendingClusterTasksRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a list of the pending cluster tasks, that are scheduled to be executed.
- pendingClusterTasks(PendingClusterTasksRequest, ActionListener<PendingClusterTasksResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a list of the pending cluster tasks, that are scheduled to be executed.
- PendingClusterTasksAction - Class in org.elasticsearch.action.admin.cluster.tasks
- PendingClusterTasksRequest - Class in org.elasticsearch.action.admin.cluster.tasks
- PendingClusterTasksRequest() - Constructor for class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksRequest
- PendingClusterTasksRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksRequest
- PendingClusterTasksRequestBuilder - Class in org.elasticsearch.action.admin.cluster.tasks
- PendingClusterTasksRequestBuilder(ElasticsearchClient, PendingClusterTasksAction) - Constructor for class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksRequestBuilder
- PendingClusterTasksResponse - Class in org.elasticsearch.action.admin.cluster.tasks
- PendingClusterTasksResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
- pendingCount() - Method in class org.elasticsearch.index.shard.RefreshListeners
-
The total number of pending listeners.
- pendingGeneration() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
-
Returns the pending repository generation.
- pendingInSync() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Whether there are shards blocking global checkpoint advancement.
- pendingInSync() - Method in class org.elasticsearch.index.shard.IndexShard
-
Check if there are any recoveries pending in-sync.
- pendingNodes() - Method in class org.elasticsearch.discovery.BlockingClusterStatePublishResponseHandler
-
returns a list of nodes which didn't respond yet
- PendingReplicationActions - Class in org.elasticsearch.action.support.replication
- PendingReplicationActions(ShardId, ThreadPool) - Constructor for class org.elasticsearch.action.support.replication.PendingReplicationActions
- pendingTasks() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
- pendingTasks() - Method in class org.elasticsearch.cluster.service.MasterService
-
Returns the tasks that are pending.
- percent(double) - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks
- percent(double) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks
- percent(double) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentileRanks
- percent(double) - Method in interface org.elasticsearch.search.aggregations.metrics.PercentileRanks
-
Return the percentile for the given value.
- PercentageScore - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- PercentageScore() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.PercentageScore
- PercentageScore(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.PercentageScore
- PercentageScore.PercentageScoreBuilder - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- PercentageScoreBuilder() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.PercentageScore.PercentageScoreBuilder
- percentAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks
- percentAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks
- percentAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentileRanks
- percentAsString(double) - Method in interface org.elasticsearch.search.aggregations.metrics.PercentileRanks
-
Return the percentile for the given value as a String.
- percentile(double) - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- percentile(double) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- percentile(double) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedHDRPercentiles
- percentile(double) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentiles
- percentile(double) - Method in interface org.elasticsearch.search.aggregations.metrics.Percentiles
-
Return the value associated with the provided percentile.
- percentile(double) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket
- percentile(double) - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedPercentilesBucket
- Percentile - Class in org.elasticsearch.search.aggregations.metrics
- Percentile(double, double) - Constructor for class org.elasticsearch.search.aggregations.metrics.Percentile
- percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedHDRPercentiles
- percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentiles
- percentileAsString(double) - Method in interface org.elasticsearch.search.aggregations.metrics.Percentiles
-
Return the value associated with the provided percentile as a String.
- percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket
- percentileAsString(double) - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedPercentilesBucket
- percentileRank(TDigestState, double) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks
- percentileRank(DoubleHistogram, double) - Static method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks
- percentileRanks(String, double[]) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
PercentileRanks
aggregation with the given name. - PercentileRanks - Interface in org.elasticsearch.search.aggregations.metrics
-
An aggregation that computes approximate percentiles given values.
- PercentileRanksAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- PercentileRanksAggregationBuilder(String, double[]) - Constructor for class org.elasticsearch.search.aggregations.metrics.PercentileRanksAggregationBuilder
- PercentileRanksAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.PercentileRanksAggregationBuilder
- percentiles - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedPercentiles
- percentiles() - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
-
Get the values to compute percentiles from.
- percentiles(double...) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
-
Set the values to compute percentiles from.
- percentiles(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Percentiles
aggregation with the given name. - Percentiles - Interface in org.elasticsearch.search.aggregations.metrics
-
An aggregation that computes approximate percentiles.
- PercentilesAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- PercentilesAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
- PercentilesAggregationBuilder(String, double[], PercentilesConfig) - Constructor for class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
- PercentilesAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
- PercentilesAggregationBuilder(PercentilesAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
- PercentilesAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.metrics
- percentilesAsString - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedPercentiles
- percentilesBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- PercentilesBucket - Interface in org.elasticsearch.search.aggregations.pipeline
- PercentilesBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- PercentilesBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
- PercentilesBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
-
Read from a stream.
- PercentilesBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- PercentilesBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregator
-
Read from a stream.
- percentilesConfig() - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
-
Returns how the percentiles algorithm has been configured, or null if it has not been configured yet
- percentilesConfig(PercentilesConfig) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
-
Sets how the percentiles algorithm should be configured
- PercentilesConfig - Class in org.elasticsearch.search.aggregations.metrics
-
A small config object that carries algo-specific settings.
- PercentilesConfig.Hdr - Class in org.elasticsearch.search.aggregations.metrics
- PercentilesConfig.TDigest - Class in org.elasticsearch.search.aggregations.metrics
- PercentilesMethod - Enum Class in org.elasticsearch.search.aggregations.metrics
-
An enum representing the methods for calculating percentiles
- perFieldAnalyzer() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the overridden analyzers at each field.
- perFieldAnalyzer() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- perFieldAnalyzer(Map<String, String>) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Override the analyzer used at each field when generating term vectors.
- perFieldAnalyzer(Map<String, String>) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
Sets the analyzer(s) to use at any given field.
- PerFieldMappingPostingFormatCodec - Class in org.elasticsearch.index.codec
-
This postings format
is the defaultPostingsFormat
for Elasticsearch. - PerFieldMappingPostingFormatCodec(Lucene87Codec.Mode, MapperService) - Constructor for class org.elasticsearch.index.codec.PerFieldMappingPostingFormatCodec
- PerFieldUsageStats(long, long, long, long, long, long, long, long, long, long, long, long, long) - Constructor for class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- PerFieldUsageStats(StreamInput) - Constructor for class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- perform(RequestT, ActionListener<PrimaryResultT>) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Performs the given request on this primary.
- performOn(ShardRouting, ReplicaRequest, long, long, long, ActionListener<ReplicationOperation.ReplicaResponse>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicasProxy
- performOn(ShardRouting, RequestT, long, long, long, ActionListener<ReplicationOperation.ReplicaResponse>) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Replicas
-
Performs the specified request on the specified replica.
- performOnPrimary(BulkShardRequest, IndexShard, UpdateHelper, LongSupplier, MappingUpdatePerformer, Consumer<ActionListener<Void>>, ActionListener<TransportReplicationAction.PrimaryResult<BulkShardRequest, BulkShardResponse>>, ThreadPool, String) - Static method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- performOnPrimary(ResyncReplicationRequest) - Static method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- performOnReplica(BulkShardRequest, IndexShard) - Static method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- performOnReplica(ResyncReplicationRequest, IndexShard) - Static method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- performOperation(ShardIterator, ShardRouting, int) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- performRecoveryRestart() - Method in class org.elasticsearch.index.shard.IndexShard
-
called if recovery has to be restarted after network error / delay **
- performStateRecovery(Gateway.GatewayStateRecoveredListener) - Method in class org.elasticsearch.gateway.Gateway
- period(int) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
- PERMANENT - Enum constant in enum class org.elasticsearch.common.breaker.CircuitBreaker.Durability
- PERMIT_HANDSHAKES_FROM_INCOMPATIBLE_BUILDS_KEY - Static variable in class org.elasticsearch.transport.TransportService
- PersistedClusterStateService - Class in org.elasticsearch.gateway
-
Stores cluster metadata in a bare Lucene index (per data path) split across a number of documents.
- PersistedClusterStateService(Path[], String, NamedXContentRegistry, BigArrays, ClusterSettings, LongSupplier) - Constructor for class org.elasticsearch.gateway.PersistedClusterStateService
- PersistedClusterStateService(NodeEnvironment, NamedXContentRegistry, BigArrays, ClusterSettings, LongSupplier) - Constructor for class org.elasticsearch.gateway.PersistedClusterStateService
- PersistedClusterStateService.OnDiskState - Class in org.elasticsearch.gateway
- PersistedClusterStateService.Writer - Class in org.elasticsearch.gateway
- PERSISTENT_TASK_ORIGIN - Static variable in class org.elasticsearch.persistent.PersistentTasksService
- persistentSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- persistentSettings() - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- persistentSettings() - Method in class org.elasticsearch.cluster.metadata.Metadata
- persistentSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the source containing the persistent settings to be updated.
- persistentSettings(Map<String, ?>) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the persistent settings to be updated.
- persistentSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the persistent settings to be updated.
- persistentSettings(Settings) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- persistentSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Sets the persistent settings to be updated.
- PersistentTask(String, String, P, long, PersistentTasksCustomMetadata.Assignment) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- PersistentTask(StreamInput) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- PersistentTask(PersistentTasksCustomMetadata.PersistentTask<P>, long, PersistentTasksCustomMetadata.Assignment) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- PersistentTask(PersistentTasksCustomMetadata.PersistentTask<P>, PersistentTaskState) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- PersistentTaskParams - Interface in org.elasticsearch.persistent
-
Parameters used to start persistent task
- PersistentTaskPlugin - Interface in org.elasticsearch.plugins
-
Plugin for registering persistent tasks executors.
- PersistentTaskResponse - Class in org.elasticsearch.persistent
-
Response upon a successful start or an persistent task
- PersistentTaskResponse(StreamInput) - Constructor for class org.elasticsearch.persistent.PersistentTaskResponse
- PersistentTaskResponse(PersistentTasksCustomMetadata.PersistentTask<?>) - Constructor for class org.elasticsearch.persistent.PersistentTaskResponse
- PersistentTasksClusterService - Class in org.elasticsearch.persistent
-
Component that runs only on the master node and is responsible for assigning running tasks to nodes
- PersistentTasksClusterService(Settings, PersistentTasksExecutorRegistry, ClusterService, ThreadPool) - Constructor for class org.elasticsearch.persistent.PersistentTasksClusterService
- PersistentTasksCustomMetadata - Class in org.elasticsearch.persistent
-
A cluster state record that contains a list of all running persistent tasks
- PersistentTasksCustomMetadata(long, Map<String, PersistentTasksCustomMetadata.PersistentTask<?>>) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- PersistentTasksCustomMetadata(StreamInput) - Constructor for class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- PersistentTasksCustomMetadata.Assignment - Class in org.elasticsearch.persistent
- PersistentTasksCustomMetadata.Builder - Class in org.elasticsearch.persistent
- PersistentTasksCustomMetadata.PersistentTask<P extends PersistentTaskParams> - Class in org.elasticsearch.persistent
-
A record that represents a single running persistent task
- PersistentTasksExecutor<Params extends PersistentTaskParams> - Class in org.elasticsearch.persistent
-
An executor of tasks that can survive restart of requesting or executing node.
- PersistentTasksExecutor(String, String) - Constructor for class org.elasticsearch.persistent.PersistentTasksExecutor
- PersistentTasksExecutorRegistry - Class in org.elasticsearch.persistent
-
Components that registers all persistent task executors
- PersistentTasksExecutorRegistry(Collection<PersistentTasksExecutor<?>>) - Constructor for class org.elasticsearch.persistent.PersistentTasksExecutorRegistry
- PersistentTasksNodeService - Class in org.elasticsearch.persistent
-
This component is responsible for coordination of execution of persistent tasks on individual nodes.
- PersistentTasksNodeService(PersistentTasksService, PersistentTasksExecutorRegistry, TaskManager, NodePersistentTasksExecutor) - Constructor for class org.elasticsearch.persistent.PersistentTasksNodeService
- PersistentTasksNodeService.Status - Class in org.elasticsearch.persistent
- PersistentTasksService - Class in org.elasticsearch.persistent
-
This service is used by persistent tasks and allocated persistent tasks to communicate changes to the master node so that the master can update the cluster state and can track of the states of the persistent tasks.
- PersistentTasksService(ClusterService, ThreadPool, Client) - Constructor for class org.elasticsearch.persistent.PersistentTasksService
- PersistentTasksService.WaitForPersistentTaskListener<P extends PersistentTaskParams> - Interface in org.elasticsearch.persistent
- PersistentTaskState - Interface in org.elasticsearch.persistent
-
PersistentTaskState
represents the state of the persistent tasks, as it is persisted in the cluster state. - persistRetentionLeases() - Method in class org.elasticsearch.index.shard.IndexShard
-
Persists the current retention leases to their dedicated state file.
- persistRetentionLeases(Path) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Persists the current retention leases to their dedicated state file.
- peta() - Method in class org.elasticsearch.common.unit.SizeValue
- PETA - Enum constant in enum class org.elasticsearch.common.unit.SizeUnit
- petaFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- phase() - Method in exception org.elasticsearch.index.engine.RecoveryEngineException
- PHRASE - Enum constant in enum class org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Uses the best matching phrase field as main score and uses a tie-breaker to adjust the score based on remaining field matches
- PHRASE - Enum constant in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- PHRASE - Enum constant in enum class org.elasticsearch.index.search.MatchQueryParser.Type
-
The text is analyzed and used as a phrase query.
- PHRASE_LIMIT_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- PHRASE_PREFIX - Enum constant in enum class org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Uses the best matching phrase-prefix field as main score and uses a tie-breaker to adjust the score based on remaining field matches
- PHRASE_PREFIX - Enum constant in enum class org.elasticsearch.index.search.MatchQueryParser.Type
-
The text is analyzed and used in a phrase query, with the last term acting as a prefix.
- phraseLimit - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- phraseLimit() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- phraseLimit() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- phraseLimit(Integer) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Sets the maximum number of phrases the fvh will consider if the field doesn't also define phraseLimit.
- phrasePrefixQuery(TokenStream, int, int, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- phrasePrefixQuery(TokenStream, int, int, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- phrasePrefixQuery(TokenStream, int, int, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- phraseQuery(TokenStream, int, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- phraseQuery(TokenStream, int, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- phraseQuery(TokenStream, int, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- phraseSlop - Variable in class org.elasticsearch.index.search.MatchQueryParser
- phraseSlop() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- phraseSlop(int) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Sets the default slop for phrases.
- PhraseSuggester - Class in org.elasticsearch.search.suggest.phrase
- phraseSuggestion(String) - Static method in class org.elasticsearch.search.suggest.SuggestBuilders
-
Creates a phrase suggestion lookup query with the provided
field
- PhraseSuggestion - Class in org.elasticsearch.search.suggest.phrase
-
Suggestion entry returned from the
PhraseSuggester
. - PhraseSuggestion(String, int) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
- PhraseSuggestion(StreamInput) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
- PhraseSuggestion.Entry - Class in org.elasticsearch.search.suggest.phrase
- PhraseSuggestion.Entry.Option - Class in org.elasticsearch.search.suggest.phrase
- PhraseSuggestionBuilder - Class in org.elasticsearch.search.suggest.phrase
-
Defines the actual suggest command for phrase suggestions (
phrase
). - PhraseSuggestionBuilder(String) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- PhraseSuggestionBuilder(StreamInput) - Constructor for class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Read from a stream.
- PhraseSuggestionBuilder.CandidateGenerator - Interface in org.elasticsearch.search.suggest.phrase
-
PhraseSuggestionBuilder.CandidateGenerator
interface. - physicalName() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Returns original file name
- pick(BinaryDocValues, BytesRefBuilder, DocIdSetIterator, int, int, int) - Method in enum class org.elasticsearch.search.MultiValueMode
- pick(SortedDocValues, DocIdSetIterator, int, int, int) - Method in enum class org.elasticsearch.search.MultiValueMode
- pick(SortedNumericDocValues) - Method in enum class org.elasticsearch.search.MultiValueMode
- pick(SortedNumericDocValues, long, DocIdSetIterator, int, int, int) - Method in enum class org.elasticsearch.search.MultiValueMode
- pick(SortedSetDocValues) - Method in enum class org.elasticsearch.search.MultiValueMode
- pick(SortedBinaryDocValues) - Method in enum class org.elasticsearch.search.MultiValueMode
- pick(SortedNumericDoubleValues) - Method in enum class org.elasticsearch.search.MultiValueMode
- pick(SortedNumericDoubleValues, double, DocIdSetIterator, int, int, int) - Method in enum class org.elasticsearch.search.MultiValueMode
- pid() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
-
The process id.
- pidFile() - Method in class org.elasticsearch.env.Environment
-
The PID file location (can be null if no PID file is configured)
- PidFile - Class in org.elasticsearch.common
-
Process ID file abstraction that writes the current pid into a file and optionally removes it on system exit.
- PIDFILE_SETTING - Static variable in class org.elasticsearch.env.Environment
- ping(Consumer<ZenPing.PingCollection>, TimeValue) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
-
Sends three rounds of pings notifying the specified
Consumer
when pinging is complete. - ping(Consumer<ZenPing.PingCollection>, TimeValue) - Method in interface org.elasticsearch.discovery.zen.ZenPing
- ping(Consumer<ZenPing.PingCollection>, TimeValue, TimeValue) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
-
a variant of
UnicastZenPing.ping(Consumer, TimeValue)
, but allows separating the scheduling duration from the duration used for request level time outs. - PING - Enum constant in enum class org.elasticsearch.transport.TransportRequestOptions.Type
- PING_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.NodesFaultDetection
- PING_INTERVAL_SETTING - Static variable in class org.elasticsearch.discovery.zen.FaultDetection
- PING_RETRIES_SETTING - Static variable in class org.elasticsearch.discovery.zen.FaultDetection
- PING_SCHEDULE - Static variable in class org.elasticsearch.transport.TransportSettings
- PING_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.zen.FaultDetection
- PING_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- PingCollection() - Constructor for class org.elasticsearch.discovery.zen.ZenPing.PingCollection
- PingContextProvider - Interface in org.elasticsearch.discovery.zen
- pingInterval - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- PingRequest(DiscoveryNode, ClusterName, DiscoveryNode, long) - Constructor for class org.elasticsearch.discovery.zen.NodesFaultDetection.PingRequest
- PingRequest(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.NodesFaultDetection.PingRequest
- pingResponse - Variable in class org.elasticsearch.discovery.zen.UnicastZenPing.UnicastPingRequest
- PingResponse() - Constructor for class org.elasticsearch.discovery.zen.NodesFaultDetection.PingResponse
- PingResponse(long, DiscoveryNode, DiscoveryNode, ClusterName, long) - Constructor for class org.elasticsearch.discovery.zen.ZenPing.PingResponse
- PingResponse(DiscoveryNode, DiscoveryNode, ClusterName, long) - Constructor for class org.elasticsearch.discovery.zen.ZenPing.PingResponse
- PingResponse(DiscoveryNode, DiscoveryNode, ClusterState) - Constructor for class org.elasticsearch.discovery.zen.ZenPing.PingResponse
- PingResponse(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.NodesFaultDetection.PingResponse
- pingResponses - Variable in class org.elasticsearch.discovery.zen.UnicastZenPing.UnicastPingResponse
- pingRetryCount - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- pingRetryTimeout - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- pipeline() - Method in class org.elasticsearch.action.bulk.BulkRequest
- pipeline(String) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Note for internal callers (NOT high level rest client), the global parameter setting is ignored when used with: -
BulkRequest.add(IndexRequest)
-BulkRequest.add(UpdateRequest)
-BulkRequest.add(DocWriteRequest)
-BulkRequest.add(DocWriteRequest[])
)} -BulkRequest.add(Iterable)
- pipeline(String) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
- Pipeline - Class in org.elasticsearch.ingest
-
A pipeline is a list of
Processor
instances grouped under a unique id. - Pipeline(String, String, Integer, Map<String, Object>, CompoundProcessor) - Constructor for class org.elasticsearch.ingest.Pipeline
- PIPELINE_CYCLE_ERROR_MESSAGE - Static variable in class org.elasticsearch.ingest.IngestDocument
- PipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations
-
A factory that knows how to create an
PipelineAggregator
of a specific type. - PipelineAggregationBuilder(String, String[]) - Constructor for class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
-
Constructs a new pipeline aggregator factory.
- PipelineAggregationBuilder.ValidationContext - Class in org.elasticsearch.search.aggregations
- PipelineAggregationSpec(String, Writeable.Reader<? extends PipelineAggregationBuilder>, Writeable.Reader<? extends PipelineAggregator>, PipelineAggregator.Parser) - Constructor for class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Deprecated.prefer the ctor that takes a
ContextParser
- PipelineAggregationSpec(String, Writeable.Reader<? extends PipelineAggregationBuilder>, Writeable.Reader<? extends PipelineAggregator>, ContextParser<String, ? extends PipelineAggregationBuilder>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Deprecated.Use
PipelineAggregationSpec(String, Writeable.Reader, ContextParser)
for pipelines implemented after 7.8.0 - PipelineAggregationSpec(String, Writeable.Reader<? extends PipelineAggregationBuilder>, ContextParser<String, ? extends PipelineAggregationBuilder>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Specification of a
PipelineAggregator
. - PipelineAggregationSpec(ParseField, Writeable.Reader<? extends PipelineAggregationBuilder>, Writeable.Reader<? extends PipelineAggregator>, PipelineAggregator.Parser) - Constructor for class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Deprecated.prefer the ctor that takes a
ContextParser
- PipelineAggregationSpec(ParseField, Writeable.Reader<? extends PipelineAggregationBuilder>, Writeable.Reader<? extends PipelineAggregator>, ContextParser<String, ? extends PipelineAggregationBuilder>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Deprecated.Use
PipelineAggregationSpec(ParseField, Writeable.Reader, ContextParser)
for pipelines implemented after 7.8.0 - PipelineAggregationSpec(ParseField, Writeable.Reader<? extends PipelineAggregationBuilder>, ContextParser<String, ? extends PipelineAggregationBuilder>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.PipelineAggregationSpec
-
Specification of a
PipelineAggregator
. - PipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- PipelineAggregator(String, String[], Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- PipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
-
Deprecated.pipeline aggregations added after 7.8.0 shouldn't call this
- PipelineAggregator.Parser - Interface in org.elasticsearch.search.aggregations.pipeline
-
Parse the
PipelineAggregationBuilder
from aXContentParser
. - PipelineAggregator.PipelineTree - Class in org.elasticsearch.search.aggregations.pipeline
-
Tree of
PipelineAggregator
s to modify a tree of aggregations after their final reduction. - PipelineAggregatorBuilders - Class in org.elasticsearch.search.aggregations
- pipelineAggregatorsForBwcSerialization() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Deprecated.only use these for serializing to older Elasticsearch versions
- PipelineConfiguration - Class in org.elasticsearch.ingest
-
Encapsulates a pipeline's id and configuration as a blob
- PipelineConfiguration(String, BytesReference, XContentType) - Constructor for class org.elasticsearch.ingest.PipelineConfiguration
- PipelineProcessor - Class in org.elasticsearch.ingest
- PipelineProcessor.Factory - Class in org.elasticsearch.ingest
- pipelines() - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
-
Get the list of pipelines that were a part of this response.
- PipelineStat(String, IngestStats.Stats) - Constructor for class org.elasticsearch.ingest.IngestStats.PipelineStat
- PipelineTree(Map<String, PipelineAggregator.PipelineTree>, List<PipelineAggregator>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.PipelineTree
- pipelineTreeForBwcSerialization() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
-
Supplies the pipelines when the result of the reduce is serialized to node versions that need pipeline aggregators to be serialized to them.
- pipelineTreeRoot() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
-
The root of the tree of pipeline aggregations for this request.
- pitTiebreaker() - Static method in class org.elasticsearch.search.sort.SortBuilders
-
Constructs a sort tiebreaker that can be used within a point in time reader
PointInTimeBuilder
. - PlainActionFuture<T> - Class in org.elasticsearch.action.support
- PlainActionFuture() - Constructor for class org.elasticsearch.action.support.PlainActionFuture
- PlainBlobMetadata - Class in org.elasticsearch.common.blobstore.support
- PlainBlobMetadata(String, long) - Constructor for class org.elasticsearch.common.blobstore.support.PlainBlobMetadata
- PlainHighlighter - Class in org.elasticsearch.search.fetch.subphase.highlight
- PlainHighlighter() - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.PlainHighlighter
- PlainIterator<T> - Class in org.elasticsearch.common.util
- PlainIterator(List<T>) - Constructor for class org.elasticsearch.common.util.PlainIterator
- PlainShardIterator - Class in org.elasticsearch.cluster.routing
- PlainShardIterator(ShardId, List<ShardRouting>) - Constructor for class org.elasticsearch.cluster.routing.PlainShardIterator
-
Creates a
PlainShardIterator
instance that iterates over a subset of the given shards this the a givenshardId
. - PlainShardsIterator - Class in org.elasticsearch.cluster.routing
-
A simple
ShardsIterator
that iterates a list or sub-list ofshard indexRoutings
. - PlainShardsIterator(List<ShardRouting>) - Constructor for class org.elasticsearch.cluster.routing.PlainShardsIterator
- PlainTransportFuture<V extends TransportResponse> - Class in org.elasticsearch.transport
- PlainTransportFuture(TransportResponseHandler<V>) - Constructor for class org.elasticsearch.transport.PlainTransportFuture
- planDeletionAsNonPrimary(Engine.Delete) - Method in class org.elasticsearch.index.engine.InternalEngine
- PLANE - Enum constant in enum class org.elasticsearch.common.geo.GeoDistance
- planeDistance(double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- planeDistance(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 a simple tangential plane this provides a faster alternative to
GeoUtils.arcDistance(double, double, double, double)
but is inaccurate for distances greater than 4 decimal degrees - planeDistanceWithDefault(double, double, double) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- planIndexingAsNonPrimary(Engine.Index) - Method in class org.elasticsearch.index.engine.InternalEngine
- PLATFORM_NAME - Static variable in class org.elasticsearch.plugins.Platforms
- platformName(String, String) - Static method in class org.elasticsearch.plugins.Platforms
-
Return the platform name based on the OS name and architecture, for example: - darwin-x86_64 - linux-x86-64 - windows-x86_64 For *nix platforms this is more-or-less `uname -s`-`uname -m` converted to lower case.
- Platforms - Class in org.elasticsearch.plugins
-
Encapsulates platform-dependent methods for handling native components of plugins.
- plugin - Variable in class org.elasticsearch.plugins.PluginsService.Bundle
- Plugin - Class in org.elasticsearch.plugins
-
An extension point allowing to plug in custom functionality.
- Plugin() - Constructor for class org.elasticsearch.plugins.Plugin
- PluginDescriptor - Class in org.elasticsearch.plugins
-
An in-memory representation of the plugin descriptor.
- PluginDescriptor(String, String, String, Version, String, String, List<String>, boolean, PluginType, String, boolean) - Constructor for class org.elasticsearch.plugins.PluginDescriptor
-
Construct plugin info.
- PluginDescriptor(StreamInput) - Constructor for class org.elasticsearch.plugins.PluginDescriptor
-
Construct plugin info from a stream.
- PluginPolicyInfo - Class in org.elasticsearch.bootstrap
- plugins - Variable in class org.elasticsearch.shutdown.PluginShutdownService
- PLUGINS - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
- PLUGINS - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- PluginsAndModules - Class in org.elasticsearch.action.admin.cluster.node.info
-
Information about plugins and modules
- PluginsAndModules(List<PluginDescriptor>, List<PluginDescriptor>) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- PluginsAndModules(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- pluginsFile() - Method in class org.elasticsearch.env.Environment
- PluginShutdownService - Class in org.elasticsearch.shutdown
-
The
PluginShutdownService
is used for the node shutdown infrastructure to signal to plugins that a shutdown is occurring, and to check whether it is safe to shut down. - PluginShutdownService(List<ShutdownAwarePlugin>) - Constructor for class org.elasticsearch.shutdown.PluginShutdownService
- PluginsManager - Class in org.elasticsearch.bootstrap.plugins
-
This class is responsible for adding, updating or removing plugins so that the list of installed plugins matches those in the
elasticsearch-plugins.yml
config file. - PluginsManager() - Constructor for class org.elasticsearch.bootstrap.plugins.PluginsManager
- PluginsService - Class in org.elasticsearch.plugins
- PluginsService(Settings, Path, Path, Path, Collection<Class<? extends Plugin>>) - Constructor for class org.elasticsearch.plugins.PluginsService
-
Constructs a new PluginService
- PluginsService.Bundle - Class in org.elasticsearch.plugins
- PluginsSynchronizer - Interface in org.elasticsearch.plugins
-
This is a marker interface for classes that are capable of synchronizing the currently-installed ES plugins with those that ought to be installed according to a configuration file.
- pluginToFeature(SystemIndexPlugin, Settings) - Static method in class org.elasticsearch.indices.SystemIndices.Feature
- PluginType - Enum Class in org.elasticsearch.plugins
-
Indicates the type of an Elasticsearch plugin.
- plus(long, TemporalUnit) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plus(TemporalAmount) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusDays(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusHours(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusMinutes(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusMonths(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusNanos(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusSeconds(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusSkippedClasses(Class...) - Method in class org.elasticsearch.common.inject.internal.SourceProvider
-
Returns a new instance that also skips
moreClassesToSkip
. - plusWeeks(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- plusYears(long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- point() - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Returns the center point of the distance query.
- point(double, double) - Method in class org.elasticsearch.common.geo.SimpleFeatureFactory
-
Returns a
byte[]
containing the mvt representation of the provided point - point(double, double) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Sets the center point of the query.
- point(double, double) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
The point to create the range distance facets from.
- point(GeoPoint) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Sets the center point for the query.
- POINT_IN_TIME - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- pointInBounds(double, double) - Method in class org.elasticsearch.common.geo.GeoBoundingBox
-
If the bounding box crosses the date-line (left greater-than right) then the longitude of the point need only to be higher than the left or lower than the right.
- pointInPolygon(List<XTessellator.Triangle>, double, double) - Static method in class org.apache.lucene.geo.XTessellator
-
Brute force compute if a point is in the polygon by traversing entire triangulation todo: speed this up using either binary tree or prefix coding (filtering by bounding box of triangle)
- pointInTimeBuilder() - Method in class org.elasticsearch.action.search.SearchRequest
- pointInTimeBuilder() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Returns the point in time that is configured with this query
- pointInTimeBuilder(PointInTimeBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Specify a point in time that this query should execute against.
- PointInTimeBuilder - Class in org.elasticsearch.search.builder
-
A search request with a point in time will execute using the reader contexts associated with that point time instead of the latest reader contexts.
- PointInTimeBuilder(String) - Constructor for class org.elasticsearch.search.builder.PointInTimeBuilder
- PointInTimeBuilder(StreamInput) - Constructor for class org.elasticsearch.search.builder.PointInTimeBuilder
- pointInTimeId() - Method in class org.elasticsearch.action.search.SearchResponse
-
Returns the encoded string of the search context that the search request is used to executed
- pointInTriangle(double, double, double, double, double, double, double, double) - Static method in class org.apache.lucene.geo.XTessellator
-
compute whether the given x, y point is in a triangle; uses the winding order method
- PointParser(String, Supplier<T>, CheckedBiFunction<XContentParser, T, T, IOException>, T, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.PointParser
- pointReaderIfAvailable(ValuesSourceConfig) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Returns a converter for point values if it's safe to use the indexed data instead of doc values.
- pointReaderIfPossible() - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- pointReaderIfPossible() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
If the field supports using the indexed data to speed up operations related to ordering of data, such as sorting or aggs, return a function for doing that.
- pointReaderIfPossible() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- points() - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.
- points() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns the points to create the range distance facets from.
- points(List<GeoPoint>) - Method in class org.elasticsearch.common.geo.SimpleFeatureFactory
-
Returns a
byte[]
containing the mvt representation of the provided points - points(GeoPoint...) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
The point to create the range distance facets from.
- POINTS - Enum constant in enum class org.elasticsearch.index.search.stats.FieldUsageStats.UsageContext
- POINTS - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- POINTS - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- POINTS_IN_BYTES - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- policies() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Returns policy patterns
- policies(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Sets slm policy patterns
- policy - Variable in class org.elasticsearch.bootstrap.PluginPolicyInfo
- POLICY_ID_METADATA_FIELD - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- PolicyUtil - Class in org.elasticsearch.bootstrap
- PolicyUtil() - Constructor for class org.elasticsearch.bootstrap.PolicyUtil
- poll() - Method in class org.elasticsearch.common.collect.EvictingQueue
- poll() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- poll(long, TimeUnit) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- pollDecompressedPage(boolean) - Method in class org.elasticsearch.transport.DeflateTransportDecompressor
- pollDecompressedPage(boolean) - Method in class org.elasticsearch.transport.Lz4TransportDecompressor
- pollDecompressedPage(boolean) - Method in interface org.elasticsearch.transport.TransportDecompressor
- pollLast() - Method in class org.elasticsearch.search.profile.AbstractInternalProfileTree
-
Removes the last (e.g.
- pollLastElement() - Method in class org.elasticsearch.search.profile.AbstractProfiler
-
Removes the last (e.g.
- POPULAR - Enum constant in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
-
Only suggest terms that occur in more docs then the original suggest text term.
- populateCommonFields(SearchExecutionContext, SuggestionSearchContext.SuggestionContext) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
Transfers the text, prefix, regex, analyzer, field, size and shard size settings from the original
SuggestionBuilder
to the targetSuggestionSearchContext.SuggestionContext
- port - Variable in class org.elasticsearch.http.AbstractHttpServerTransport
- PORT - Static variable in class org.elasticsearch.transport.TransportSettings
- PORT_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- portOrRange - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- ports() - Method in class org.elasticsearch.common.transport.PortsRange
- PortsRange - Class in org.elasticsearch.common.transport
- PortsRange(String) - Constructor for class org.elasticsearch.common.transport.PortsRange
- PortsRange.PortCallback - Interface in org.elasticsearch.common.transport
- POS - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- posIncAttr - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- position - Variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- position() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- position() - Method in class org.elasticsearch.common.io.stream.PositionTrackingOutputStreamStreamOutput
- position() - Method in class org.elasticsearch.common.io.stream.StreamOutput
- position() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- Position(int, int, int) - Constructor for class org.elasticsearch.script.ScriptException.Position
- POSITION_INCREMENT_GAP - Static variable in class org.elasticsearch.index.mapper.TextFieldMapper.Defaults
-
The default position_increment_gap is set to 100 so that phrase queries of reasonably high slop will not match across field values.
- positionIncrementGap - Variable in class org.elasticsearch.index.mapper.TextParams.Analyzers
- positions() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- positions(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the positions for each term if stored or skip.
- Positions - Enum constant in enum class org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
- POSITIONS - Enum constant in enum class org.elasticsearch.index.mapper.TextSearchInfo.TermVector
- POSITIONS - Enum constant in enum class org.elasticsearch.index.search.stats.FieldUsageStats.UsageContext
- POSITIONS - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- PositionTrackingOutputStreamStreamOutput - Class in org.elasticsearch.common.io.stream
- PositionTrackingOutputStreamStreamOutput(OutputStream) - Constructor for class org.elasticsearch.common.io.stream.PositionTrackingOutputStreamStreamOutput
- positiveQuery() - Method in class org.elasticsearch.index.query.BoostingQueryBuilder
-
Get the positive query for this boosting query.
- positiveTimeSetting(String, Setting<TimeValue>, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- positiveTimeSetting(String, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- posLeft - Variable in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- posRight - Variable in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- post() - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- post(int) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- POST - Enum constant in enum class org.elasticsearch.rest.RestRequest.Method
- POST_COLLECTION - Enum constant in enum class org.elasticsearch.search.profile.aggregation.AggregationTimingType
- POST_FILTER_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- POST_RECOVERY - Enum constant in enum class org.elasticsearch.index.shard.IndexShardState
- POST_TAG_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- POST_TAGS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- postAdded() - Method in interface org.elasticsearch.cluster.TimeoutClusterStateListener
- postCollection() - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- postCollection() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Called after collection of all document is done.
- postCollection() - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- postCollection() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- postCollection() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- postCollection() - Method in class org.elasticsearch.search.aggregations.BucketCollector
-
Post-collection callback.
- postCollection() - Method in class org.elasticsearch.search.aggregations.MultiBucketCollector
- postCollection() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- postDelete(ShardId, Engine.Delete, Exception) - Method in class org.elasticsearch.index.shard.IndexingOperationListener.CompositeListener
- postDelete(ShardId, Engine.Delete, Exception) - Method in interface org.elasticsearch.index.shard.IndexingOperationListener
-
Called after the delete operation occurred with engine level exception.
- postDelete(ShardId, Engine.Delete, Engine.DeleteResult) - Method in class org.elasticsearch.index.shard.IndexingOperationListener.CompositeListener
- postDelete(ShardId, Engine.Delete, Engine.DeleteResult) - Method in interface org.elasticsearch.index.shard.IndexingOperationListener
-
Called after the delete operation occurred.
- postDelete(ShardId, Engine.Delete, Engine.DeleteResult) - Method in class org.elasticsearch.indices.IndexingMemoryController
- PostFeatureUpgradeAction - Class in org.elasticsearch.action.admin.cluster.migration
-
Action for beginning a system feature upgrade
- PostFeatureUpgradeRequest - Class in org.elasticsearch.action.admin.cluster.migration
-
Request to begin an upgrade of system features
- PostFeatureUpgradeRequest() - Constructor for class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeRequest
- PostFeatureUpgradeRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeRequest
- PostFeatureUpgradeResponse - Class in org.elasticsearch.action.admin.cluster.migration
-
The response to return to a request for a system feature upgrade
- PostFeatureUpgradeResponse(boolean, List<PostFeatureUpgradeResponse.Feature>, String, ElasticsearchException) - Constructor for class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse
- PostFeatureUpgradeResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse
- PostFeatureUpgradeResponse.Feature - Class in org.elasticsearch.action.admin.cluster.migration
-
A data class representing a feature that to be upgraded
- postFilter() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the post filter for this request
- postFilter(String) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets a filter (analyzer) that is applied to each of the generated tokens before they are passed to the actual phrase scorer.
- postFilter(QueryBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets a filter that will be executed after the query has been executed and only has affect on the search hits (not aggregations).
- postFilter(DirectCandidateGenerator.Candidate, CharsRefBuilder, BytesRefBuilder, List<DirectCandidateGenerator.Candidate>) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- POSTFILTER_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- postIndex(ShardId, Engine.Index, Exception) - Method in class org.elasticsearch.index.shard.IndexingOperationListener.CompositeListener
- postIndex(ShardId, Engine.Index, Exception) - Method in interface org.elasticsearch.index.shard.IndexingOperationListener
-
Called after the indexing operation occurred with engine level exception.
- postIndex(ShardId, Engine.Index, Engine.IndexResult) - Method in class org.elasticsearch.index.IndexingSlowLog
- postIndex(ShardId, Engine.Index, Engine.IndexResult) - Method in class org.elasticsearch.index.shard.IndexingOperationListener.CompositeListener
- postIndex(ShardId, Engine.Index, Engine.IndexResult) - Method in interface org.elasticsearch.index.shard.IndexingOperationListener
-
Called after the indexing operation occurred.
- postIndex(ShardId, Engine.Index, Engine.IndexResult) - Method in class org.elasticsearch.indices.IndexingMemoryController
- postings(PostingsEnum, int) - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- POSTINGS - Enum constant in enum class org.elasticsearch.index.search.stats.FieldUsageStats.UsageContext
- POSTINGS - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- postParse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper
- postParse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper
- postParse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper
- postParse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper
-
Called after
FieldMapper.parse(DocumentParserContext)
on theRootObjectMapper
. - postParse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- postParse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.VersionFieldMapper
- postProcess(Function<String, MappedFieldType>, String) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- postRecovery(String) - Method in class org.elasticsearch.index.shard.IndexShard
- postTag() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the post-tag for the highlighter set with
PhraseSuggestionBuilder.highlight(String, String)
- postTags - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- postTags() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- postTags() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- postTags(String...) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set the post tags that will be used for highlighting.
- pre() - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- pre(int) - Method in class org.elasticsearch.index.query.SpanNotQueryBuilder
- PRE_TAG_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- PRE_TAGS_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- PreallocatedCircuitBreakerService - Class in org.elasticsearch.common.breaker
-
CircuitBreakerService
that preallocates some bytes on construction. - PreallocatedCircuitBreakerService(CircuitBreakerService, String, long, String) - Constructor for class org.elasticsearch.common.breaker.PreallocatedCircuitBreakerService
- PreBuiltAnalyzerProvider - Class in org.elasticsearch.index.analysis
- PreBuiltAnalyzerProvider(String, AnalyzerScope, Analyzer) - Constructor for class org.elasticsearch.index.analysis.PreBuiltAnalyzerProvider
- PreBuiltAnalyzerProviderFactory - Class in org.elasticsearch.index.analysis
- PreBuiltAnalyzerProviderFactory(String, PreBuiltCacheFactory.CachingStrategy, Supplier<Analyzer>) - Constructor for class org.elasticsearch.index.analysis.PreBuiltAnalyzerProviderFactory
- PreBuiltAnalyzers - Enum Class in org.elasticsearch.indices.analysis
- PreBuiltCacheFactory - Class in org.elasticsearch.indices.analysis
- PreBuiltCacheFactory.CachingStrategy - Enum Class in org.elasticsearch.indices.analysis
-
The strategy of caching the analyzer ONE Exactly one version is stored.
- PreBuiltCacheFactory.PreBuiltCache<T> - Interface in org.elasticsearch.indices.analysis
- PreBuiltTokenizers - Enum Class in org.elasticsearch.indices.analysis
- PRECEDENCE - Enum constant in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- preceding(int) - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
-
Must be called with increasing offset.
- precision - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- precision() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- precision() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashCellIdSource
- precision() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileCellIdSource
- precision() - Method in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
-
Precision of the algorithm
- precision(double) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping.Builder
-
Set the precision use o make suggestions
- precision(double, DistanceUnit) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping.Builder
-
Set the precision use o make suggestions
- precision(int) - Method in class org.elasticsearch.search.aggregations.bucket.composite.GeoTileGridValuesSourceBuilder
- precision(int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
-
method to validate and set the precision value
- precision(int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- precision(int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregationBuilder
- precision(int) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping.Builder
-
Set the precision use o make suggestions
- precision(String) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping.Builder
-
Set the precision use o make suggestions
- PRECISION_THRESHOLD_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- precisionFromThreshold(long) - Static method in class org.elasticsearch.search.aggregations.metrics.HyperLogLogPlusPlus
-
Compute the required precision so that
count
distinct entries would be counted with linear counting. - precisionThreshold() - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
-
Get the precision threshold.
- precisionThreshold(long) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
-
Set a precision threshold.
- precludesParameters(FieldMapper.Parameter<?>...) - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- preCollection() - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- preCollection() - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- preCollection() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- preCollection() - Method in class org.elasticsearch.search.aggregations.BucketCollector
-
Pre collection callback.
- preCollection() - Method in class org.elasticsearch.search.aggregations.MultiBucketCollector
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.AvgBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregator
-
Called before initial collection and between successive collection runs.
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.MaxBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.MinBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.StatsBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.aggregations.pipeline.SumBucketPipelineAggregator
- preCollection() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- PRECONDITION_FAILED - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The precondition given in one or more of the request-header fields evaluated to false when it was tested on the server.
- PreConfiguredAnalysisComponent<T> - Class in org.elasticsearch.index.analysis
-
Shared implementation for pre-configured analysis components.
- PreConfiguredAnalysisComponent(String, PreBuiltCacheFactory.CachingStrategy) - Constructor for class org.elasticsearch.index.analysis.PreConfiguredAnalysisComponent
- PreConfiguredAnalysisComponent(String, PreBuiltCacheFactory.PreBuiltCache<T>) - Constructor for class org.elasticsearch.index.analysis.PreConfiguredAnalysisComponent
- PreConfiguredCharFilter - Class in org.elasticsearch.index.analysis
-
Provides pre-configured, shared
CharFilter
s. - PreConfiguredCharFilter(String, PreBuiltCacheFactory.CachingStrategy, boolean, BiFunction<Reader, Version, Reader>) - Constructor for class org.elasticsearch.index.analysis.PreConfiguredCharFilter
- PreConfiguredTokenFilter - Class in org.elasticsearch.index.analysis
-
Provides pre-configured, shared
TokenFilter
s. - PreConfiguredTokenizer - Class in org.elasticsearch.index.analysis
-
Provides pre-configured, shared
Tokenizer
s. - preDelete(ShardId, Engine.Delete) - Method in class org.elasticsearch.index.shard.IndexingOperationListener.CompositeListener
- preDelete(ShardId, Engine.Delete) - Method in interface org.elasticsearch.index.shard.IndexingOperationListener
-
Called before the delete occurs.
- predict() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Gets the number of predictions that should be returned.
- predict(int) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Sets the number of predictions that should be returned.
- predict(Collection<Double>, int) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
-
Predicts the next `n` values in the series.
- PREFER_NODES - Enum constant in enum class org.elasticsearch.cluster.routing.Preference
-
Route to preferred nodes, if possible
- preferAttributesActiveInitializingShardsIt(List<String>, DiscoveryNodes) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- preferAttributesActiveInitializingShardsIt(List<String>, DiscoveryNodes, int) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- preference - Variable in class org.elasticsearch.action.termvectors.TermVectorsRequest
- preference() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- preference() - Method in class org.elasticsearch.action.explain.ExplainRequest
- preference() - Method in class org.elasticsearch.action.get.GetRequest
- preference() - Method in class org.elasticsearch.action.get.MultiGetRequest
- preference() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- preference() - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- preference() - Method in class org.elasticsearch.action.search.SearchRequest
- preference() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- preference() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- preference(String) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
Sets the preference to execute the search.
- preference(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
- preference(String) - Method in class org.elasticsearch.action.get.GetRequest
-
Sets the preference to execute the search.
- preference(String) - Method in class org.elasticsearch.action.get.MultiGetRequest
-
Sets the preference to execute the search.
- preference(String) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
-
Sets the preference to execute the search.
- preference(String) - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- preference(String) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets the preference to execute the search.
- preference(String) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
-
Sets the preference to execute the search.
- preference(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Sets the preference to execute the search.
- Preference - Enum Class in org.elasticsearch.cluster.routing
-
Routing Preference Type
- preferNodeActiveInitializingShardsIt(Set<String>) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- preFilter(String) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets a filter (analyzer) that is applied to each of the tokens passed to this candidate generator.
- preFilter(BytesRef, CharsRefBuilder, BytesRefBuilder) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- PREFILTER_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- prefix - Variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- prefix() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the prefix for this suggestion
- prefix(String) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Sets the prefix to provide completions for.
- prefix(String) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- prefix(String, Fuzziness) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Same as
CompletionSuggestionBuilder.prefix(String)
with fuzziness offuzziness
- prefix(String, FuzzyOptions) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Same as
CompletionSuggestionBuilder.prefix(String)
with full fuzzy options seeFuzzyOptions.Builder
- Prefix(String, String, String) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.Prefix
- Prefix(StreamInput) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.Prefix
- PREFIX - Enum constant in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- PREFIX - Static variable in class org.elasticsearch.common.util.concurrent.ThreadContext
- PREFIX_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- PREFIX_LENGTH_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- PREFIX_LENGTH_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- prefixIntervals(BytesRef, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Create an
IntervalsSource
for the given prefix. - prefixIntervals(BytesRef, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- prefixKeySetting(String, Function<String, Setting<T>>) - 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.
- prefixLength() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- prefixLength() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Gets the length of a length of common (non-fuzzy) prefix for fuzzy match queries
- prefixLength() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Gets the length of a length of common (non-fuzzy) prefix for fuzzy match queries
- prefixLength() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- prefixLength() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- prefixLength() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the minimum prefix length that must match setting.
- prefixLength(int) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- prefixLength(int) - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Sets the length of a length of common (non-fuzzy) prefix for fuzzy match queries
- prefixLength(int) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets the length of a length of common (non-fuzzy) prefix for fuzzy match queries
- prefixLength(int) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- prefixLength(int) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- prefixLength(int) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets the number of minimal prefix characters that must match in order be a candidate suggestion.
- prefixLength(int) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets the number of minimal prefix characters that must match in order be a candidate suggestion.
- prefixQuery(Object) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
-
Completion prefix query
- prefixQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing terms with a specified prefix.
- prefixQuery(String, MultiTermQuery.RewriteMethod, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- prefixQuery(String, MultiTermQuery.RewriteMethod, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.ConstantFieldType
- prefixQuery(String, MultiTermQuery.RewriteMethod, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- prefixQuery(String, MultiTermQuery.RewriteMethod, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- prefixQuery(String, MultiTermQuery.RewriteMethod, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.StringFieldType
- prefixQuery(String, MultiTermQuery.RewriteMethod, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- prefixQuery(String, MultiTermQuery.RewriteMethod, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- PrefixQueryBuilder - Class in org.elasticsearch.index.query
-
A Query that matches documents containing terms with a specified prefix.
- PrefixQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.PrefixQueryBuilder
-
A Query that matches documents containing terms with a specified prefix.
- PrefixQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.PrefixQueryBuilder
-
Read from a stream.
- preFlightCheckForNoOp(Engine.NoOp) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Executes a pre-flight check for a given NoOp.
- preGetSubLeafCollectors(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Can be overridden by aggregator implementations that like the perform an operation before the leaf collectors of children aggregators are instantiated for the next segment.
- preGetSubLeafCollectors(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
- preGetSubLeafCollectors(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregator
- preIndex(ShardId, Engine.Index) - Method in class org.elasticsearch.index.shard.IndexingOperationListener.CompositeListener
- preIndex(ShardId, Engine.Index) - Method in interface org.elasticsearch.index.shard.IndexingOperationListener
-
Called before the indexing occurs.
- prepare(long, long) - Method in class org.elasticsearch.common.Rounding
-
Prepare to round many times.
- prepare(UpdateRequest, IndexShard, LongSupplier) - Method in class org.elasticsearch.action.update.UpdateHelper
-
Prepares an update request by converting it into an index or delete request or an update response (no action).
- prepare(ShardId, UpdateRequest, GetResult, LongSupplier) - Method in class org.elasticsearch.action.update.UpdateHelper
-
Prepares an update request by converting it into an index or delete request or an update response (no action, in the event of a noop).
- PREPARE_TRANSLOG - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- prepareAddBlock(IndexMetadata.APIBlock, String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Adds a block to an index
- prepareAliases() - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Allows to add/remove aliases from indices.
- prepareAliasesExist(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Allows to check to existence of aliases from indices.
- prepareAllocationExplain() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Explain the allocation of a shard
- prepareAnalyze() - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text/texts.
- prepareAnalyze(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text.
- prepareAnalyze(String, String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Analyze text under the provided index.
- prepareBulk() - Method in interface org.elasticsearch.client.Client
-
Executes a bulk of index / delete operations.
- prepareBulk() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareBulk(String, String) - Method in interface org.elasticsearch.client.Client
-
Executes a bulk of index / delete operations with default index and/or type
- prepareBulk(String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareCancelTasks(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Cancel active tasks
- prepareCleanupRepository(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Cleans up repository.
- prepareClearCache(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Clear indices cache.
- prepareClearScroll() - Method in interface org.elasticsearch.client.Client
-
Clears the search contexts associated with specified scroll ids.
- prepareClearScroll() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareCloneSnapshot(String, String, String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Clones a snapshot.
- prepareClose(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Closes one or more indices based on their index name.
- prepareClusterStats() - Method in interface org.elasticsearch.client.ClusterAdminClient
- prepareCreate(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Creates an index using an explicit request allowing to specify the settings of the index.
- prepareCreateSnapshot(String, String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Creates a new snapshot.
- prepareDelete() - Method in interface org.elasticsearch.client.Client
-
Deletes a document from the index based on the index, type and id.
- prepareDelete() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareDelete(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deletes an index based on the index name.
- prepareDelete(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Deletes a document from the index based on the index, type and id.
- prepareDelete(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareDeletePipeline() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Deletes a stored ingest pipeline
- prepareDeletePipeline(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Deletes a stored ingest pipeline
- prepareDeleteRepository(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Unregisters a repository.
- prepareDeleteSnapshot(String, String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete snapshot.
- prepareDeleteStoredScript() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete a script from the cluster state
- prepareDeleteStoredScript(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Delete a script from the cluster state
- prepareDeleteTemplate(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deletes an index template.
- prepareEnvironment(Settings, Map<String, String>, Path, Supplier<String>) - Static method in class org.elasticsearch.node.InternalSettingsPreparer
-
Prepares the settings by gathering all elasticsearch system properties, optionally loading the configuration settings.
- prepareExists(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices exists.
- prepareExplain(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Computes a score explanation for the specified request.
- prepareExplain(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareFieldCaps(String...) - Method in interface org.elasticsearch.client.Client
-
Builder for the field capabilities request.
- prepareFieldCaps(String...) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareFlush(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly flush one or more indices (releasing memory from the node).
- prepareForceMerge(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly force merge one or more indices into a the number of segments.
- prepareForIndexing(Geometry) - Method in class org.elasticsearch.index.mapper.GeoShapeIndexer
- prepareForIndexRecovery() - Method in class org.elasticsearch.index.shard.IndexShard
-
called before starting to copy index files over
- prepareForIndicesMigration(ClusterService, Client, ActionListener<Map<String, Object>>) - Method in interface org.elasticsearch.indices.SystemIndices.Feature.MigrationPreparationHandler
- prepareForIndicesMigration(ClusterService, Client, ActionListener<Map<String, Object>>) - Method in interface org.elasticsearch.plugins.SystemIndexPlugin
-
A method used to signal that the system indices owned by this plugin are about to be upgraded.
- prepareForTranslogOperations(int, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
Implementation of
RecoveryTargetHandler
- prepareForTranslogOperations(int, ActionListener<Void>) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
Prepares the target to receive translog operations, after all file have been copied
- prepareForTranslogOperations(int, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- prepareForUnknown() - Method in class org.elasticsearch.common.Rounding
-
Prepare to round many dates over an unknown range.
- prepareGet() - Method in interface org.elasticsearch.client.Client
-
Gets the document that was indexed from an index with a type and id.
- prepareGet() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareGet(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Gets the document that was indexed from an index with a type (optional) and id.
- prepareGet(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareGetAliases(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get specific index aliases that exists in particular indices and / or by name.
- prepareGetFieldMappings(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the mappings of specific fields
- prepareGetIndex() - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get index metadata for particular indices.
- prepareGetMappings(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Get the complete mappings of one or more types
- prepareGetPipeline(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a stored ingest pipeline
- prepareGetRepositories(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Gets repositories.
- prepareGetSettings(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Returns a builder for a per index settings get request.
- prepareGetSnapshots(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshots.
- prepareGetStoredScript() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get a script from the cluster state
- prepareGetStoredScript(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get a script from the cluster state
- prepareGetTask(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Fetch a task by id.
- prepareGetTask(TaskId) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Fetch a task by id.
- prepareGetTemplates(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Gets an index template (optional).
- prepareHealth(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
The health of the cluster.
- prepareIndex() - Method in interface org.elasticsearch.client.Client
-
Index a document associated with a given index and type.
- prepareIndex() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareIndex(String, String) - Method in interface org.elasticsearch.client.Client
-
Index a document associated with a given index and type.
- prepareIndex(String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareIndex(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Index a document associated with a given index and type.
- prepareIndex(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareIndex(MapperService, String, SourceToParse, long, long, long, VersionType, Engine.Operation.Origin, long, boolean, long, long) - Static method in class org.elasticsearch.index.shard.IndexShard
- prepareListTasks(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
List active tasks
- prepareMultiGet() - Method in interface org.elasticsearch.client.Client
-
Multi get documents.
- prepareMultiGet() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareMultiSearch() - Method in interface org.elasticsearch.client.Client
-
Performs multiple search requests.
- prepareMultiSearch() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareMultiTermVectors() - Method in interface org.elasticsearch.client.Client
-
Multi get term vectors.
- prepareMultiTermVectors() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareNodesHotThreads(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a request builder to fetch top N hot-threads samples per node.
- prepareNodesInfo(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes info of the cluster.
- prepareNodesStats(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes stats of the cluster.
- prepareNodesUsage(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Nodes usage of the cluster.
- prepareOpen(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Opens one or more indices based on their index name.
- preparePendingClusterTasks() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns a list of the pending cluster tasks, that are scheduled to be executed.
- preparePutMapping(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Add mapping definition for a type into one or more indices.
- preparePutPipeline(String, BytesReference, XContentType) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Stores an ingest pipeline
- preparePutRepository(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Registers a snapshot repository.
- preparePutStoredScript() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Store a script in the cluster state
- preparePutTemplate(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Puts an index template.
- prepareRecoveries(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices recoveries
- prepareRefresh(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly refresh one or more indices (making the content indexed since the last refresh searchable).
- prepareReloadSecureSettings() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Re initialize each cluster node and pass them the secret store password.
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.action.search.RestClosePointInTimeAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.action.search.RestOpenPointInTimeAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.dangling.RestDeleteDanglingIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.dangling.RestImportDanglingIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.dangling.RestListDanglingIndicesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestAddVotingConfigExclusionAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestCancelTasksAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestCleanupRepositoryAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClearVotingConfigExclusionsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestCloneSnapshotAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterAllocationExplainAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterGetSettingsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterHealthAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterRerouteAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterSearchShardsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStatsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterUpdateSettingsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestCreateSnapshotAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteRepositoryAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteSnapshotAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteStoredScriptAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetFeatureUpgradeStatusAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetRepositoriesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetScriptContextAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetScriptLanguageAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetSnapshotsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetStoredScriptAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetTaskAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestListTasksAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesHotThreadsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesInfoAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesStatsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesUsageAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestPendingClusterTasksAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestPostFeatureUpgradeAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestPutRepositoryAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestPutStoredScriptAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestReloadSecureSettingsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestRemoteClusterInfoAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestResetFeatureStateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestRestoreSnapshotAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestSnapshotsStatusAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestSnapshottableFeaturesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.cluster.RestVerifyRepositoryAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestAddIndexBlockAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeIndexDiskUsageAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestClearIndicesCacheAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestCloseIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestCreateIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteComponentTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteComposableIndexTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestFieldUsageStatsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestFlushAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestForceMergeAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetAliasesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetComponentTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetComposableIndexTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetFieldMappingAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndexTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndicesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetMappingAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestGetSettingsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestIndexDeleteAliasesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestIndexPutAliasAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesAliasesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesSegmentsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesShardStoresAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesStatsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestOpenIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestPutComponentTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestPutComposableIndexTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestPutIndexTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestPutMappingAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestRecoveryAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestRefreshAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestResolveIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestRolloverIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestSimulateIndexTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestSimulateTemplateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestSyncedFlushAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestUpdateSettingsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestUpgradeActionDeprecated
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestUpgradeStatusActionDeprecated
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.admin.indices.RestValidateQueryAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.AbstractCatAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.cat.RestCatAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.datastreams.RestModifyDataStreamsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestBulkAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestDeleteAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestGetAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestGetSourceAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestIndexAction.AutoIdHandler
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestIndexAction.CreateHandler
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestIndexAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestMultiGetAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestMultiTermVectorsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestTermVectorsAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.document.RestUpdateAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.ingest.RestDeletePipelineAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.ingest.RestGetPipelineAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.ingest.RestPutPipelineAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.ingest.RestSimulatePipelineAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.RestFieldCapabilitiesAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.RestMainAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.search.RestClearScrollAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.search.RestCountAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.search.RestExplainAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.search.RestSearchAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.action.search.RestSearchScrollAction
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.BaseRestHandler
-
Prepare the request for execution.
- prepareRequest(RestRequest, NodeClient) - Method in class org.elasticsearch.rest.BaseRestHandler.Wrapper
- prepareReroute() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Update settings in the cluster.
- prepareResizeIndex(String, String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Resize an index using an explicit request allowing to specify the settings, mappings and aliases of the target index of the index.
- prepareRestoreSnapshot(String, String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Restores a snapshot.
- prepareRolloverIndex(String) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Swaps the index pointed to by an alias given all provided conditions are satisfied
- prepareSearch(String...) - Method in interface org.elasticsearch.client.Client
-
Search across one or more indices and one or more types with a query.
- prepareSearch(String...) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareSearchScroll(String) - Method in interface org.elasticsearch.client.Client
-
A search scroll request to continue searching a previous scrollable search request.
- prepareSearchScroll(String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareSearchShards() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns list of shards the given search would be executed on.
- prepareSearchShards(String...) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns list of shards the given search would be executed on.
- prepareSegments(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
The segments of one or more indices.
- prepareSelectedBuckets(long...) - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
-
Replay the wrapped collector, but only on a selection of buckets.
- prepareSelectedBuckets(long...) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
-
Replay the deferred hits on the selected buckets.
- prepareSelectedBuckets(long...) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- prepareSettings(Settings) - Static method in class org.elasticsearch.node.InternalSettingsPreparer
-
Prepares settings for the transport client by gathering all elasticsearch system properties and setting defaults.
- prepareShardStores(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
The shard stores info of one or more indices.
- prepareSimulatePipeline(BytesReference, XContentType) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Simulates an ingest pipeline
- prepareSnapshotStatus() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshot status.
- prepareSnapshotStatus(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshot status.
- prepareState() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
The state of the cluster.
- prepareStats(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices stats.
- prepareSubAggs(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Hook to allow taking an action before building the sub agg results.
- prepareSubAggs(long[]) - Method in class org.elasticsearch.search.aggregations.bucket.DeferableBucketAggregator
- prepareSyncedFlush(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly sync flush one or more indices (write sync id to shards for faster recovery).
- prepareTermVectors() - Method in interface org.elasticsearch.client.Client
-
Builder for the term vector request.
- prepareTermVectors() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareTermVectors(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Builder for the term vector request.
- prepareTermVectors(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareTypesExists(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deprecated.Types are deprecated and are in the process of being removed.
- prepareUpdate() - Method in interface org.elasticsearch.client.Client
-
Updates a document based on a script.
- prepareUpdate() - Method in class org.elasticsearch.client.support.AbstractClient
- prepareUpdate(String, String, String) - Method in interface org.elasticsearch.client.Client
-
Updates a document based on a script.
- prepareUpdate(String, String, String) - Method in class org.elasticsearch.client.support.AbstractClient
- prepareUpdateSettings() - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Update settings in the cluster.
- prepareUpdateSettings(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Update indices settings.
- prepareUpgrade(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Check upgrade status of one or more indices
- prepareUpgradeStatus(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly upgrade one or more indices
- prepareValidateQuery(String...) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Validate a query for correctness.
- prepareVerifyRepository(String) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Verifies a repository.
- preParse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.IdFieldMapper
- preParse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper
-
Called before
FieldMapper.parse(DocumentParserContext)
on theRootObjectMapper
. - preParse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper
- preParse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- preParse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.SourceFieldMapper
- preParse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper
- preParse(DocumentParserContext) - Method in class org.elasticsearch.index.mapper.VersionFieldMapper
- preProcess() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- preProcess() - Method in class org.elasticsearch.search.internal.SearchContext
-
Should be called before executing the main query and after all other parameters have been set.
- preProcess() - Method in class org.elasticsearch.search.internal.SubSearchContext
- preProcess(SearchContext) - Method in class org.elasticsearch.search.aggregations.AggregationPhase
- PreProcessModule - Interface in org.elasticsearch.common.inject
-
A module can implement this interface to allow to pre process other modules before an injector is created.
- preRecovery() - Method in class org.elasticsearch.index.shard.IndexShard
- preserveContext(Runnable) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Saves the current thread context and wraps command in a Runnable that restores that context before running command.
- PreShardSyncedFlushRequest(StreamInput) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.PreShardSyncedFlushRequest
- PreShardSyncedFlushRequest(ShardId) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.PreShardSyncedFlushRequest
- preSpanQueryRewrite(Query) - Method in class org.apache.lucene.search.uhighlight.CustomUnifiedHighlighter
- preTag() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the pre-tag for the highlighter set with
PhraseSuggestionBuilder.highlight(String, String)
- preTags - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- preTags() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- preTags() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- preTags(String...) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set the pre tags that will be used for highlighting.
- prettyPrint() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- prettyPrint() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- prettyPrint() - Method in class org.elasticsearch.common.StopWatch
-
Return a string with a table describing all tasks performed.
- previous() - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- previous() - Method in class org.elasticsearch.common.LocalTimeOffset.Transition
-
The offset before the this one.
- previousLevel() - Method in class org.elasticsearch.index.query.support.NestedScope
-
Sets the previous nested level as current nested level and removes and returns the current nested level.
- previousMajor() - Method in class org.elasticsearch.Version
-
Returns a first major version previous to the version stored in this object.
- previousMasterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- previousState() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
The previous cluster state for this change event.
- PreVoteCollector - Class in org.elasticsearch.cluster.coordination
- PreVoteRequest - Class in org.elasticsearch.cluster.coordination
- PreVoteRequest(DiscoveryNode, long) - Constructor for class org.elasticsearch.cluster.coordination.PreVoteRequest
- PreVoteRequest(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.PreVoteRequest
- PreVoteResponse - Class in org.elasticsearch.cluster.coordination
- PreVoteResponse(long, long, long) - Constructor for class org.elasticsearch.cluster.coordination.PreVoteResponse
- PreVoteResponse(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.PreVoteResponse
- prevSetBit(int) - Method in class org.apache.lucene.util.CombinedBitSet
- PRIMARIES - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
- PRIMARIES - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
- primary - Variable in class org.elasticsearch.action.support.replication.TransportWriteAction.WritePrimaryResult
- primary - Variable in class org.elasticsearch.index.shard.ShardStateMetadata
- primary() - Method in exception org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- primary() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns
true
iff this shard is a primary. - primary() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- PRIMARY - Enum constant in enum class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus.AllocationStatus
-
Allocated as primary
- PRIMARY - Enum constant in enum class org.elasticsearch.index.engine.Engine.Operation.Origin
- PRIMARY - Enum constant in enum class org.elasticsearch.index.mapper.SourceToParse.Origin
- PRIMARY_FAILED - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of a failed primary while the replica was initializing.
- PRIMARY_TERM_NAME - Static variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- PrimaryContext(long, Map<String, ReplicationTracker.CheckpointState>, IndexShardRoutingTable) - Constructor for class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- PrimaryContext(StreamInput) - Constructor for class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- PrimaryMissingActionException - Exception in org.elasticsearch.action
- PrimaryMissingActionException(String) - Constructor for exception org.elasticsearch.action.PrimaryMissingActionException
- PrimaryMissingActionException(StreamInput) - Constructor for exception org.elasticsearch.action.PrimaryMissingActionException
- primaryOperationSize(BulkShardRequest) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- primaryOperationSize(ResyncReplicationRequest) - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- primaryOperationSize(Request) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- PrimaryReplicaSyncer - Class in org.elasticsearch.index.shard
- PrimaryReplicaSyncer(TransportService, TransportResyncReplicationAction) - Constructor for class org.elasticsearch.index.shard.PrimaryReplicaSyncer
- PrimaryReplicaSyncer(TransportService, PrimaryReplicaSyncer.SyncAction) - Constructor for class org.elasticsearch.index.shard.PrimaryReplicaSyncer
- PrimaryReplicaSyncer.ResyncRequest - Class in org.elasticsearch.index.shard
- PrimaryReplicaSyncer.ResyncTask - Class in org.elasticsearch.index.shard
- PrimaryReplicaSyncer.ResyncTask.Status - Class in org.elasticsearch.index.shard
- PrimaryReplicaSyncer.SyncAction - Interface in org.elasticsearch.index.shard
- PrimaryResult(ReplicaRequest, Response) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryResult
- PrimaryResult(ReplicaRequest, Response, Exception) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryResult
-
Result of executing a primary operation expects
finalResponseIfSuccessful
orfinalFailure
to be not-null - primaryShard() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- PrimaryShardAllocator - Class in org.elasticsearch.gateway
-
The primary shard allocator allocates unassigned primary shards to nodes that hold valid copies of the unassigned primaries.
- PrimaryShardAllocator() - Constructor for class org.elasticsearch.gateway.PrimaryShardAllocator
- primaryShardIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns an iterator only on the primary shard.
- primaryShardsActive() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Calculates the number of primary shards in active state in routing table
- primaryShardsUnassigned() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Calculates the number of primary shards in the routing tables that are in
ShardRoutingState.UNASSIGNED
state. - primaryTerm - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- primaryTerm - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndVersion
- primaryTerm - Variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SequenceIDFields
- primaryTerm() - Method in class org.elasticsearch.index.engine.Engine.Operation
- primaryTerm() - Method in class org.elasticsearch.index.seqno.RetentionLeases
-
The primary term of this retention lease collection.
- primaryTerm() - Method in class org.elasticsearch.index.translog.Translog.Delete
- primaryTerm() - Method in class org.elasticsearch.index.translog.Translog.Index
- primaryTerm() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- primaryTerm() - Method in interface org.elasticsearch.index.translog.Translog.Operation
- primaryTerm(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
-
returns the primary term for the given shard.
- primaryTerm(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
The term of the current selected primary.
- primaryTerm(int, long) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
-
sets the primary term for the given shard.
- print(Terminal.Verbosity, String, boolean) - Method in class org.elasticsearch.bootstrap.plugins.LoggerTerminal
- printAdditionalHelp(Terminal) - Method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- printBoostAndQueryName(XContentBuilder) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- printTo(Writer, long, Chronology, int, DateTimeZone, Locale) - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
-
Deprecated.We adjust the instant by displayOffset to adjust for the offset that might have been added in
DateTimeFormatter.printTo(Appendable, long, Chronology)
when using a time zone. - printTo(Writer, ReadablePartial, Locale) - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
-
Deprecated.
- printTo(StringBuffer, long, Chronology, int, DateTimeZone, Locale) - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
-
Deprecated.We adjust the instant by displayOffset to adjust for the offset that might have been added in
DateTimeFormatter.printTo(Appendable, long, Chronology)
when using a time zone. - printTo(StringBuffer, ReadablePartial, Locale) - Method in class org.elasticsearch.common.joda.Joda.EpochTimePrinter
-
Deprecated.
- PrioritizedCallable<T> - Class in org.elasticsearch.common.util.concurrent
- PrioritizedCallable(Priority) - Constructor for class org.elasticsearch.common.util.concurrent.PrioritizedCallable
- PrioritizedEsThreadPoolExecutor - Class in org.elasticsearch.common.util.concurrent
-
A prioritizing executor which uses a priority queue as a work queue.
- PrioritizedEsThreadPoolExecutor(String, int, int, long, TimeUnit, ThreadFactory, ThreadContext, ScheduledExecutorService, PrioritizedEsThreadPoolExecutor.StarvationWatcher) - Constructor for class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- PrioritizedEsThreadPoolExecutor.Pending - Class in org.elasticsearch.common.util.concurrent
- PrioritizedEsThreadPoolExecutor.StarvationWatcher - Interface in org.elasticsearch.common.util.concurrent
-
We expect the work queue to be empty fairly frequently; if the queue remains nonempty for sufficiently long then there's a risk that some lower-priority tasks are being starved of access to the executor.
- PrioritizedRunnable - Class in org.elasticsearch.common.util.concurrent
- PrioritizedRunnable(Priority) - Constructor for class org.elasticsearch.common.util.concurrent.PrioritizedRunnable
- priority - Variable in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.Pending
- priority() - Method in class org.elasticsearch.cluster.ClusterStateTaskConfig.Basic
- priority() - Method in interface org.elasticsearch.cluster.ClusterStateTaskConfig
-
The
Priority
for this cluster state update task configuration. - priority() - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
- priority() - Method in class org.elasticsearch.cluster.LocalClusterUpdateTask
- priority() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- priority() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- priority() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedCallable
- priority() - Method in class org.elasticsearch.common.util.concurrent.PrioritizedRunnable
- priority() - Method in class org.elasticsearch.common.xcontent.SuggestingErrorOnUnknown
- priority(Long) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.Builder
- Priority - Enum Class in org.elasticsearch.common
- PriorityComparator - Class in org.elasticsearch.gateway
-
A comparator that compares
ShardRouting
instances based on various properties. - PriorityComparator() - Constructor for class org.elasticsearch.gateway.PriorityComparator
- priorityOrZero() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- PrivateBinder - Interface in org.elasticsearch.common.inject
-
Returns a binder whose configuration information is hidden from its environment by default.
- PrivateElements - Interface in org.elasticsearch.common.inject.spi
-
A private collection of elements that are hidden from the enclosing injector or module by default.
- PrivateElementsImpl - Class in org.elasticsearch.common.inject.internal
- PrivateElementsImpl(Object) - Constructor for class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- PrivateIndex - Enum constant in enum class org.elasticsearch.common.settings.Setting.Property
-
Indicates an index-level setting that is privately managed.
- PrivateModule - Class in org.elasticsearch.common.inject
-
A module whose configuration information is hidden from its environment by default.
- PrivateModule() - Constructor for class org.elasticsearch.common.inject.PrivateModule
- probablySingleFieldRequest() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- PROBE_CONNECT_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.HandshakingTransportAddressConnector
- PROBE_HANDSHAKE_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.HandshakingTransportAddressConnector
- ProbeConnectionResult - Class in org.elasticsearch.discovery
-
The result of a "probe" connection to a transport address, if it successfully discovered a valid node and established a full connection with it.
- ProbeConnectionResult(DiscoveryNode, Releasable) - Constructor for class org.elasticsearch.discovery.ProbeConnectionResult
- Probes - Class in org.elasticsearch.monitor
- Probes() - Constructor for class org.elasticsearch.monitor.Probes
- proceed(Task, String, Request, ActionListener<Response>) - Method in interface org.elasticsearch.action.support.ActionFilterChain
-
Continue processing the request.
- process(FetchSubPhase.HitContext) - Method in interface org.elasticsearch.search.fetch.FetchSubPhaseProcessor
-
Called in doc id order for each hit in a leaf reader
- process(Version, MappingMetadata, String) - Method in class org.elasticsearch.action.index.IndexRequest
- PROCESS - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
- PROCESS - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- processAllocation(RoutingAllocation) - Method in class org.elasticsearch.gateway.AsyncShardFetch.FetchResult
-
Process any changes needed to the allocation based on this fetch result.
- processAsyncFetch(List<T>, List<FailedNodeException>, long) - Method in class org.elasticsearch.gateway.AsyncShardFetch
-
Called by the response handler of the async action to fetch data.
- processButSkipLucene(boolean, long) - Static method in class org.elasticsearch.index.engine.InternalEngine.DeletionStrategy
- processButSkipLucene(boolean, long) - Static method in class org.elasticsearch.index.engine.InternalEngine.IndexingStrategy
- ProcessClusterEventTimeoutException - Exception in org.elasticsearch.cluster.metadata
- ProcessClusterEventTimeoutException(StreamInput) - Constructor for exception org.elasticsearch.cluster.metadata.ProcessClusterEventTimeoutException
- ProcessClusterEventTimeoutException(TimeValue, String) - Constructor for exception org.elasticsearch.cluster.metadata.ProcessClusterEventTimeoutException
- processDanglingIndices(Metadata) - Method in class org.elasticsearch.gateway.DanglingIndicesState
-
Process dangling indices based on the provided meta data, handling cleanup, finding new dangling indices, and allocating outstanding ones.
- processDataPaths(Terminal, Path[], int, OptionSet, Environment) - Method in class org.elasticsearch.cluster.coordination.DetachClusterCommand
- processDataPaths(Terminal, Path[], int, OptionSet, Environment) - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
-
Process the paths.
- processDataPaths(Terminal, Path[], int, OptionSet, Environment) - Method in class org.elasticsearch.cluster.coordination.RemoveCustomsCommand
- processDataPaths(Terminal, Path[], int, OptionSet, Environment) - Method in class org.elasticsearch.cluster.coordination.RemoveSettingsCommand
- processDataPaths(Terminal, Path[], int, OptionSet, Environment) - Method in class org.elasticsearch.cluster.coordination.UnsafeBootstrapMasterCommand
- processDataPaths(Terminal, Path[], int, OptionSet, Environment) - Method in class org.elasticsearch.env.NodeRepurposeCommand
- processDataPaths(Terminal, Path[], int, OptionSet, Environment) - Method in class org.elasticsearch.env.OverrideNodeVersionCommand
- processDataPaths(Terminal, Path[], int, OptionSet, Environment) - Method in class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- processDataPaths(Terminal, OptionSet, Environment) - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- processed - Variable in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
-
whether the task has been processed already
- processExistingRecoveries(RoutingAllocation) - Method in class org.elasticsearch.gateway.ReplicaShardAllocator
-
Process existing recoveries of replicas and see if we need to cancel them if we find a better match.
- processInfo(long) - Method in class org.elasticsearch.monitor.process.ProcessProbe
- ProcessInfo - Class in org.elasticsearch.monitor.process
- ProcessInfo(long, boolean, long) - Constructor for class org.elasticsearch.monitor.process.ProcessInfo
- ProcessInfo(StreamInput) - Constructor for class org.elasticsearch.monitor.process.ProcessInfo
- processMessageReceived(Request, TransportChannel) - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- processModule(Module) - Method in interface org.elasticsearch.common.inject.PreProcessModule
- Processor - Interface in org.elasticsearch.ingest
-
A processor implementation may modify the data belonging to a document.
- PROCESSOR_RESULT_FIELD - Static variable in class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
- Processor.Factory - Interface in org.elasticsearch.ingest
-
A factory that knows how to construct a processor based on a map of maps.
- Processor.Parameters - Class in org.elasticsearch.ingest
-
Infrastructure class that holds services that can be used by processor factories to create processor instances and that gets passed around to all
IngestPlugin
s. - ProcessorInfo - Class in org.elasticsearch.ingest
- ProcessorInfo(String) - Constructor for class org.elasticsearch.ingest.ProcessorInfo
- ProcessorInfo(StreamInput) - Constructor for class org.elasticsearch.ingest.ProcessorInfo
-
Read from a stream.
- PROCESSORS_KEY - Static variable in class org.elasticsearch.ingest.Pipeline
- PROCESSORS_SETTING - Static variable in class org.elasticsearch.common.util.concurrent.EsExecutors
-
Setting to manually set the number of available processors.
- ProcessorStat(String, String, IngestStats.Stats) - Constructor for class org.elasticsearch.ingest.IngestStats.ProcessorStat
- processPendingDeletes(Index, IndexSettings, TimeValue) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
- processPendingDeletes(Index, IndexSettings, TimeValue) - Method in class org.elasticsearch.indices.IndicesService
-
Processes all pending deletes for the given index.
- ProcessProbe - Class in org.elasticsearch.monitor.process
- processRanges(Function<RangeAggregator.Range, RangeAggregator.Range>) - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
-
Resolve any strings in the ranges so we have a number value for the from and to of each range.
- processReader(ElasticsearchDirectoryReader) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- processRecoverySettings(ClusterSettings, RecoverySettings) - Method in class org.elasticsearch.node.Node
- processResponse(Response) - Method in class org.elasticsearch.rest.action.DispatchingRestToXContentListener
- processResponse(Response) - Method in class org.elasticsearch.rest.action.RestActionListener
- processResponse(Response) - Method in class org.elasticsearch.rest.action.RestResponseListener
- processScale(double, double) - Method in interface org.elasticsearch.index.query.functionscore.DecayFunction
-
The final scale parameter is computed from the scale parameter given by the user and a value.
- processService() - Method in class org.elasticsearch.monitor.MonitorService
- ProcessService - Class in org.elasticsearch.monitor.process
- ProcessService(Settings) - Constructor for class org.elasticsearch.monitor.process.ProcessService
- processStats() - Method in class org.elasticsearch.monitor.process.ProcessProbe
- ProcessStats - Class in org.elasticsearch.monitor.process
- ProcessStats(long, long, long, ProcessStats.Cpu, ProcessStats.Mem) - Constructor for class org.elasticsearch.monitor.process.ProcessStats
- ProcessStats(StreamInput) - Constructor for class org.elasticsearch.monitor.process.ProcessStats
- ProcessStats.Cpu - Class in org.elasticsearch.monitor.process
- ProcessStats.Mem - Class in org.elasticsearch.monitor.process
- processTasks(CancelTasksRequest, Consumer<CancellableTask>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.TransportCancelTasksAction
- processTasks(ListTasksRequest, Consumer<Task>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
- processTasks(TasksRequest, Consumer<OperationTask>) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- processValue(long, Double) - Method in enum class org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
- PRODUCTION - Enum constant in enum class org.elasticsearch.common.inject.Stage
-
We want to catch errors as early as possible and take performance hits up front.
- ProductionAggregationContext(AnalysisRegistry, SearchExecutionContext, BigArrays, long, Supplier<Query>, AggregationProfiler, MultiBucketConsumerService.MultiBucketConsumer, Supplier<SubSearchContext>, BitsetFilterCache, int, LongSupplier, Supplier<Boolean>, Function<Query, Query>, boolean) - Constructor for class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- ProductOriginConverter - Class in org.elasticsearch.common.logging
-
Pattern converter to format the X-elastic-product-origin into plaintext logs.
- ProductOriginConverter() - Constructor for class org.elasticsearch.common.logging.ProductOriginConverter
- profile() - Method in class org.elasticsearch.action.search.SearchResponseSections
-
Returns the profile results for this search response (including all shards).
- profile() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Return whether to profile query execution, or
null
if unspecified. - profile(boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Should the query be profiled.
- profile(String, String, FetchSubPhaseProcessor) - Method in class org.elasticsearch.search.fetch.FetchProfiler
- PROFILE_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- PROFILE_FIELD - Static variable in class org.elasticsearch.search.profile.SearchProfileResults
- profileAddresses() - Method in class org.elasticsearch.transport.TransportInfo
- profileBoundAddresses() - Method in class org.elasticsearch.transport.TcpTransport
- profileBoundAddresses() - Method in interface org.elasticsearch.transport.Transport
-
Further profile bound addresses
- profileIfEnabled(Aggregator) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- profileIfEnabled(Aggregator) - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Wrap the aggregator for profiling if profiling is enabled.
- profileName - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- profileResult() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- ProfileResult - Class in org.elasticsearch.search.profile
-
The result of a profiled *thing*, like a query or an aggregation.
- ProfileResult(String, String, Map<String, Long>, Map<String, Object>, long, List<ProfileResult>) - Constructor for class org.elasticsearch.search.profile.ProfileResult
- ProfileResult(StreamInput) - Constructor for class org.elasticsearch.search.profile.ProfileResult
-
Read from a stream.
- profileResults - Variable in class org.elasticsearch.action.search.SearchResponseSections
- profileResults(SearchProfileQueryPhaseResult) - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Sets the finalized profiling results for this query
- Profilers - Class in org.elasticsearch.search.profile
-
Wrapper around all the profilers that makes management easier.
- Profilers(ContextIndexSearcher) - Constructor for class org.elasticsearch.search.profile.Profilers
- ProfileSettings(Settings, String) - Constructor for class org.elasticsearch.transport.TcpTransport.ProfileSettings
- profileSettingsSet - Variable in class org.elasticsearch.transport.TcpTransport
- profileTree - Variable in class org.elasticsearch.search.profile.AbstractProfiler
- ProfileWeight - Class in org.elasticsearch.search.profile.query
-
Weight wrapper that will compute how much time it takes to build the
Scorer
and then return aScorer
that is wrapped in order to compute timings as well. - ProfileWeight(Query, Weight, QueryProfileBreakdown) - Constructor for class org.elasticsearch.search.profile.query.ProfileWeight
- profiling() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- profiling() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Are we profiling the aggregation?
- ProfilingAggregator - Class in org.elasticsearch.search.profile.aggregation
- ProfilingAggregator(Aggregator, AggregationProfiler) - Constructor for class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- ProfilingLeafBucketCollector - Class in org.elasticsearch.search.profile.aggregation
- ProfilingLeafBucketCollector(LeafBucketCollector, AggregationProfileBreakdown) - Constructor for class org.elasticsearch.search.profile.aggregation.ProfilingLeafBucketCollector
- promoteDataStream() - Method in class org.elasticsearch.cluster.metadata.DataStream
- PROPERTY_NAME - Static variable in class org.elasticsearch.transport.NetworkTraceFlag
- protocolVersion() - Method in class org.elasticsearch.http.HttpPipelinedRequest
- protocolVersion() - Method in interface org.elasticsearch.http.HttpRequest
- ProvidedBy - Annotation Interface in org.elasticsearch.common.inject
-
A pointer to the default provider type for a type.
- Provider<T> - Interface in org.elasticsearch.common.inject
-
An object capable of providing instances of type
T
. - ProviderBinding<T extends Provider<?>> - Interface in org.elasticsearch.common.inject.spi
-
A binding to a
Provider
that delegates to the binding for the provided type. - ProviderInstanceBinding<T> - Interface in org.elasticsearch.common.inject.spi
-
A binding to a provider instance.
- ProviderInstanceBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- ProviderInstanceBindingImpl(Object, Key<T>, Scoping, Set<InjectionPoint>, Provider<? extends T>) - Constructor for class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- ProviderInstanceBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping, Provider<? extends T>, Set<InjectionPoint>) - Constructor for class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- ProviderKeyBinding<T> - Interface in org.elasticsearch.common.inject.spi
-
A binding to a provider key.
- ProviderLookup<T> - Class in org.elasticsearch.common.inject.spi
-
A lookup of the provider for a type.
- ProviderLookup(Object, Key<T>) - Constructor for class org.elasticsearch.common.inject.spi.ProviderLookup
- ProviderLookup.ProviderImpl<T> - Class in org.elasticsearch.common.inject.spi
- ProviderMethod<T> - Class in org.elasticsearch.common.inject.internal
-
A provider that invokes a method and returns its result.
- ProviderMethodsModule - Class in org.elasticsearch.common.inject.internal
-
Creates bindings to methods annotated with @
Provides
. - providerOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a type modelling a
Provider
that provides elements of typeelementType
. - Providers - Class in org.elasticsearch.common.inject.util
-
Static utility methods for creating and working with instances of
Provider
. - ProviderWithDependencies<T> - Interface in org.elasticsearch.common.inject.spi
-
A provider with dependencies on other injected types.
- Provides - Annotation Interface in org.elasticsearch.common.inject
-
Annotates methods of a
Module
to create a provider method binding. - ProvisionException - Exception in org.elasticsearch.common.inject
-
Indicates that there was a runtime failure while providing an instance.
- ProvisionException(Iterable<Message>) - Constructor for exception org.elasticsearch.common.inject.ProvisionException
-
Creates a ConfigurationException containing
messages
. - ProvisionException(String) - Constructor for exception org.elasticsearch.common.inject.ProvisionException
- ProvisionException(String, Throwable) - Constructor for exception org.elasticsearch.common.inject.ProvisionException
- PROXIMITY - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- PROXY_ADDRESS - Static variable in class org.elasticsearch.transport.ProxyConnectionStrategy
-
The remote address for the proxy.
- PROXY_AUTHENTICATION - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
This code is similar to 401 (Unauthorized), but indicates that the client must first authenticate itself with the proxy.
- ProxyConnectionStrategy - Class in org.elasticsearch.transport
- ProxyConnectionStrategy.ProxyModeInfo - Class in org.elasticsearch.transport
- ProxyModeInfo(String, String, int, int) - Constructor for class org.elasticsearch.transport.ProxyConnectionStrategy.ProxyModeInfo
- prune(Predicate<Transport.ResponseContext<? extends TransportResponse>>) - Method in class org.elasticsearch.transport.Transport.ResponseHandlers
-
Removes and returns all
Transport.ResponseContext
instances that match the predicate - pruneUnreferencedFiles(String, Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
-
This method removes all files from the given directory that are not referenced by the given segments file.
- Publication - Class in org.elasticsearch.cluster.coordination
- Publication(PublishRequest, ClusterStatePublisher.AckListener, LongSupplier) - Constructor for class org.elasticsearch.cluster.coordination.Publication
- publicationMayFail() - Method in class org.elasticsearch.cluster.service.MasterService
- PublicationTransportHandler - Class in org.elasticsearch.cluster.coordination
- PublicationTransportHandler(BigArrays, TransportService, NamedWriteableRegistry, Function<PublishRequest, PublishWithJoinResponse>, BiConsumer<ApplyCommitRequest, ActionListener<Void>>) - Constructor for class org.elasticsearch.cluster.coordination.PublicationTransportHandler
- PublicationTransportHandler.PublicationContext - Class in org.elasticsearch.cluster.coordination
-
Publishing a cluster state typically involves sending the same cluster state (or diff) to every node, so the work of diffing, serializing, and compressing the state can be done once and the results shared across publish requests.
- publish(ClusterStatePublicationEvent, int, ClusterStatePublisher.AckListener) - Method in class org.elasticsearch.discovery.zen.PublishClusterStateAction
-
publishes a cluster change event to other nodes.
- publish(ClusterStatePublicationEvent, ActionListener<Void>, ClusterStatePublisher.AckListener) - Method in interface org.elasticsearch.cluster.coordination.ClusterStatePublisher
-
Publish all the changes to the cluster from the master (can be called just by the master).
- publish(ClusterStatePublicationEvent, ActionListener<Void>, ClusterStatePublisher.AckListener) - Method in class org.elasticsearch.cluster.coordination.Coordinator
- publish(ClusterStatePublicationEvent, ActionListener<Void>, ClusterStatePublisher.AckListener) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- publish(ClusterStatePublicationEvent, MasterService.TaskOutputs) - Method in class org.elasticsearch.cluster.service.MasterService
- PUBLISH_DIFF_ENABLE_SETTING - Static variable in class org.elasticsearch.discovery.DiscoverySettings
- PUBLISH_HOST - Static variable in class org.elasticsearch.transport.TransportSettings
- PUBLISH_HOST_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- PUBLISH_INFO_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.Coordinator
- PUBLISH_PORT - Static variable in class org.elasticsearch.transport.TransportSettings
- PUBLISH_PORT_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- PUBLISH_STATE_ACTION_NAME - Static variable in class org.elasticsearch.cluster.coordination.PublicationTransportHandler
- PUBLISH_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.Coordinator
- PUBLISH_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.DiscoverySettings
-
sets the timeout for a complete publishing cycle, including both sending and committing.
- publishAddress() - Method in class org.elasticsearch.common.transport.BoundTransportAddress
- PublishClusterStateAction - Class in org.elasticsearch.discovery.zen
- PublishClusterStateAction(TransportService, NamedWriteableRegistry, PublishClusterStateAction.IncomingClusterStateListener, DiscoverySettings) - Constructor for class org.elasticsearch.discovery.zen.PublishClusterStateAction
- PublishClusterStateAction.CommitClusterStateRequest - Class in org.elasticsearch.discovery.zen
- PublishClusterStateAction.IncomingClusterStateListener - Interface in org.elasticsearch.discovery.zen
- PublishClusterStateStats - Class in org.elasticsearch.discovery.zen
-
Class encapsulating stats about the PublishClusterStateAction
- PublishClusterStateStats(long, long, long, ClusterStateSerializationStats) - Constructor for class org.elasticsearch.discovery.zen.PublishClusterStateStats
- PublishClusterStateStats(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.PublishClusterStateStats
- publishHosts - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- publishPort - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- PublishRequest - Class in org.elasticsearch.cluster.coordination
-
Request which is used by the master node to publish cluster state changes.
- PublishRequest(ClusterState) - Constructor for class org.elasticsearch.cluster.coordination.PublishRequest
- PublishResponse - Class in org.elasticsearch.cluster.coordination
-
Response to a
PublishRequest
, carrying the term and version of the request. - PublishResponse(long, long) - Constructor for class org.elasticsearch.cluster.coordination.PublishResponse
- PublishResponse(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.PublishResponse
- PublishWithJoinResponse - Class in org.elasticsearch.cluster.coordination
-
Response to a
PublishRequest
. - PublishWithJoinResponse(PublishResponse, Optional<Join>) - Constructor for class org.elasticsearch.cluster.coordination.PublishWithJoinResponse
- PublishWithJoinResponse(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.PublishWithJoinResponse
- put(int, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- put(long, T) - Method in interface org.elasticsearch.common.util.concurrent.ConcurrentMapLong
- put(long, T) - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
-
Put this new (key, value) pair into this hash table and return the value that was previously associated with
key
or null in case of an insertion. - put(E) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- put(Item, Consumer<Exception>) - Method in class org.elasticsearch.common.util.concurrent.AsyncIOProcessor
-
Adds the given item to the queue.
- put(Object, FieldLookup) - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- put(String, boolean) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the boolean value.
- put(String, double) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the double value.
- put(String, float) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the float value.
- put(String, int) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the int value.
- put(String, long) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the long value.
- put(String, long, TimeUnit) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the time value.
- put(String, long, ByteSizeUnit) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and the size value.
- put(String, Enum<?>) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets an enum setting with the provided setting key and enum instance.
- put(String, Object) - Method in class org.elasticsearch.script.DynamicMap
- put(String, Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
- put(String, String) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets a setting with the provided setting key and value.
- put(String, String, Boolean, String) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- put(String, Path) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets a path setting with the provided setting key and path.
- put(String, Level) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets an level setting with the provided setting key and level instance.
- put(String, Version) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets an lucene version setting with the provided setting key and lucene version instance.
- put(String, ComponentTemplate) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- put(String, ComposableIndexTemplate) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- put(String, ByteSizeValue) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets a byteSizeValue setting with the provided setting key and byteSizeValue.
- put(String, TimeValue) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets a time value setting with the provided setting key and value.
- put(String, ScriptDocValues<?>) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- put(String, Version) - Method in class org.elasticsearch.common.settings.Settings.Builder
- put(K, V) - Method in class org.elasticsearch.common.cache.Cache
-
Associates the specified value with the specified key in this map.
- put(K, V) - Method in class org.elasticsearch.common.collect.MapBuilder
- put(K, V) - Method in class org.elasticsearch.common.util.LazyMap
- put(KType, VType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- put(DataStream) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- put(IndexMetadata.Builder) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- put(IndexMetadata, boolean) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- put(IndexTemplateMetadata) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- put(IndexTemplateMetadata.Builder) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- put(Settings) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets all the provided settings including secure settings
- put(Settings, boolean) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets all the provided settings.
- put(IndexId, int, SnapshotsInProgress.ShardSnapshotStatus) - Method in class org.elasticsearch.repositories.ShardGenerations.Builder
- put(IndexId, int, ShardGeneration) - Method in class org.elasticsearch.repositories.ShardGenerations.Builder
- put(Task, T) - Method in class org.elasticsearch.tasks.CancellableTasksTracker
-
Add an item for the given task.
- put(Version, T) - Method in interface org.elasticsearch.indices.analysis.PreBuiltCacheFactory.PreBuiltCache
- PUT - Enum constant in enum class org.elasticsearch.rest.RestRequest.Method
- putAlias(AliasMetadata) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- putAlias(AliasMetadata) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- putAlias(AliasMetadata.Builder) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- putAlias(AliasMetadata.Builder) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- putAll(IntObjectAssociativeContainer<? extends VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- putAll(ObjectObjectAssociativeContainer<? extends KType, ? extends VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- putAll(Iterable<? extends IntObjectCursor<? extends VType>>) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- putAll(Iterable<? extends ObjectObjectCursor<? extends KType, ? extends VType>>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- putAll(Map) - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- putAll(Map<? extends String, ?>) - Method in class org.elasticsearch.script.DynamicMap
- putAll(Map<? extends String, ? extends Object>) - Method in class org.elasticsearch.search.lookup.SourceLookup
- putAll(Map<? extends String, ? extends ScriptDocValues<?>>) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- putAll(Map<? extends K, ? extends V>) - Method in class org.elasticsearch.common.util.LazyMap
- putAll(Map<Integer, VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
-
Puts all the entries in the map to the builder.
- putAll(Map<K, V>) - Method in class org.elasticsearch.common.collect.MapBuilder
- putAll(Map<KType, VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
-
Puts all the entries in the map to the builder.
- putAll(ShardGenerations) - Method in class org.elasticsearch.repositories.ShardGenerations.Builder
- putComponentTemplate(String, boolean, String, TimeValue, ComponentTemplate, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Add the given component template to the cluster state.
- PutComponentTemplateAction - Class in org.elasticsearch.action.admin.indices.template.put
-
An action for putting a single component template into the cluster state
- PutComponentTemplateAction.Request - Class in org.elasticsearch.action.admin.indices.template.put
-
A request for putting a single component template into the cluster state
- PutComposableIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.put
- PutComposableIndexTemplateAction.Request - Class in org.elasticsearch.action.admin.indices.template.put
-
A request for putting a single index template into the cluster state
- putCustom(String, Map<String, String>) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- putCustom(String, ClusterState.Custom) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- putCustom(String, Metadata.Custom) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- putHeader(String, String) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Puts a header into the context
- putHeader(Map<String, String>) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Puts all of the given headers into this context
- putIfAbsent(K, V) - Method in class org.elasticsearch.common.util.LazyMap
- putInContext(String, Object) - Method in class org.elasticsearch.search.internal.ReaderContext
-
Puts the object into the context
- PutIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.put
- PutIndexTemplateRequest - Class in org.elasticsearch.action.admin.indices.template.put
-
A request to create an index template.
- PutIndexTemplateRequest() - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- PutIndexTemplateRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
Constructs a new put index template request with the provided name.
- PutIndexTemplateRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- PutIndexTemplateRequestBuilder - Class in org.elasticsearch.action.admin.indices.template.put
- PutIndexTemplateRequestBuilder(ElasticsearchClient, PutIndexTemplateAction) - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
- PutIndexTemplateRequestBuilder(ElasticsearchClient, PutIndexTemplateAction, String) - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
- putIndexTemplateV2(String, boolean, String, TimeValue, ComposableIndexTemplate, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Add the given index template to the cluster state.
- putInSyncAllocationIds(int, Set<String>) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- putList(String, String...) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and an array of values.
- putList(String, List<String>) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets the setting with the provided setting key and a list of values.
- putMapper(Mapper) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- putMapping(String, String) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- putMapping(String, String) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- putMapping(String, String) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutRequest
- putMapping(String, CompressedXContent) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- putMapping(PutMappingClusterStateUpdateRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataMappingService
- putMapping(PutMappingRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Add mapping definition for a type into one or more indices.
- putMapping(PutMappingRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Add mapping definition for a type into one or more indices.
- putMapping(MappingMetadata) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- PutMappingAction - Class in org.elasticsearch.action.admin.indices.mapping.put
- PutMappingClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.mapping.put
-
Cluster state update request that allows to put a mapping
- PutMappingClusterStateUpdateRequest() - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
- PutMappingClusterStateUpdateRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
- putMappingRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Create a create mapping request against one or more indices.
- PutMappingRequest - Class in org.elasticsearch.action.admin.indices.mapping.put
-
Puts mapping definition registered under a specific type into one or more indices.
- PutMappingRequest() - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- PutMappingRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
Constructs a new put mapping request against one or more indices.
- PutMappingRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- PutMappingRequestBuilder - Class in org.elasticsearch.action.admin.indices.mapping.put
-
Builder for a put mapping request
- PutMappingRequestBuilder(ElasticsearchClient, PutMappingAction) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
- putNull(String) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Sets a null value for the given setting key
- putPipeline(PutPipelineRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Stores an ingest pipeline
- putPipeline(PutPipelineRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Stores an ingest pipeline
- putPipeline(PutPipelineRequest, ActionListener<AcknowledgedResponse>, Consumer<ActionListener<NodesInfoResponse>>) - Method in class org.elasticsearch.ingest.IngestService
-
Stores the specified pipeline definition in the request.
- PutPipelineAction - Class in org.elasticsearch.action.ingest
- PutPipelineAction() - Constructor for class org.elasticsearch.action.ingest.PutPipelineAction
- PutPipelineRequest - Class in org.elasticsearch.action.ingest
- PutPipelineRequest(String, BytesReference, XContentType) - Constructor for class org.elasticsearch.action.ingest.PutPipelineRequest
- PutPipelineRequest(String, BytesReference, XContentType, Integer) - Constructor for class org.elasticsearch.action.ingest.PutPipelineRequest
-
Create a new pipeline request with the id and source along with the content type of the source
- PutPipelineRequest(StreamInput) - Constructor for class org.elasticsearch.action.ingest.PutPipelineRequest
- PutPipelineRequestBuilder - Class in org.elasticsearch.action.ingest
- PutPipelineRequestBuilder(ElasticsearchClient, PutPipelineAction) - Constructor for class org.elasticsearch.action.ingest.PutPipelineRequestBuilder
- PutPipelineRequestBuilder(ElasticsearchClient, PutPipelineAction, String, BytesReference, XContentType) - Constructor for class org.elasticsearch.action.ingest.PutPipelineRequestBuilder
- PutPipelineTransportAction - Class in org.elasticsearch.action.ingest
- PutPipelineTransportAction(ThreadPool, TransportService, ActionFilters, IndexNameExpressionResolver, IngestService, NodeClient) - Constructor for class org.elasticsearch.action.ingest.PutPipelineTransportAction
- putProperties(Map<String, String>, Function<String, String>) - Method in class org.elasticsearch.common.settings.Settings.Builder
- putReaderContext(ReaderContext) - Method in class org.elasticsearch.search.SearchService
- putRepository(PutRepositoryRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Registers a snapshot repository.
- putRepository(PutRepositoryRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Registers a snapshot repository.
- PutRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.put
-
Register repository action
- putRepositoryRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Registers snapshot repository
- PutRepositoryRequest - Class in org.elasticsearch.action.admin.cluster.repositories.put
-
Register repository request.
- PutRepositoryRequest() - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
- PutRepositoryRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Constructs a new put repository request with the provided name.
- PutRepositoryRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
- PutRepositoryRequestBuilder - Class in org.elasticsearch.action.admin.cluster.repositories.put
-
Register repository request builder
- PutRepositoryRequestBuilder(ElasticsearchClient, PutRepositoryAction) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Constructs register repository request
- PutRepositoryRequestBuilder(ElasticsearchClient, PutRepositoryAction, String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Constructs register repository request for the repository with a given name
- PutRequest(String, String) - Constructor for class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutRequest
- PutResponse(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutResponse
- putRolloverInfo(RolloverInfo) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- putSingleNodeMetadata(SingleNodeShutdownMetadata) - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
-
Add or update the shutdown metadata for a single node.
- putStoredScript(PutStoredScriptRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Store a script in the cluster state
- putStoredScript(PutStoredScriptRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Store a script in the cluster state
- putStoredScript(ClusterService, PutStoredScriptRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.script.ScriptService
- PutStoredScriptAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- PutStoredScriptRequest - Class in org.elasticsearch.action.admin.cluster.storedscripts
- PutStoredScriptRequest() - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- PutStoredScriptRequest(String, String, BytesReference, XContentType, StoredScriptSource) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- PutStoredScriptRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- PutStoredScriptRequestBuilder - Class in org.elasticsearch.action.admin.cluster.storedscripts
- PutStoredScriptRequestBuilder(ElasticsearchClient, PutStoredScriptAction) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequestBuilder
- putTemplate(PutIndexTemplateRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Puts an index template.
- putTemplate(PutIndexTemplateRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Puts an index template.
- putTemplate(MetadataIndexTemplateService.PutRequest, MetadataIndexTemplateService.PutListener) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
- putTransient(String, Object) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Puts a transient header object into this context
Q
- quadTreeCellHeight(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the height (in meters) of quadtree cells at a specific level
- quadTreeCellSize(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the size (in meters) of quadtree cells at a specific level
- quadTreeCellWidth(int) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the width (in meters) of quadtree cells at a specific level
- quadTreeLevelsForPrecision(double) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the number of levels needed for a specific precision.
- quadTreeLevelsForPrecision(String) - Static method in class org.elasticsearch.common.geo.GeoUtils
-
Calculate the number of levels needed for a specific precision.
- QUARTER - Enum constant in enum class org.elasticsearch.common.rounding.DateTimeUnit
- QUARTER - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- QUARTER_OF_YEAR - Enum constant in enum class org.elasticsearch.common.Rounding.DateTimeUnit
- QuarterOfYear - Static variable in class org.elasticsearch.common.joda.Joda
-
Deprecated.
- Quarters - Static variable in class org.elasticsearch.common.joda.Joda
-
Deprecated.
- Queries - Class in org.elasticsearch.common.lucene.search
- Queries() - Constructor for class org.elasticsearch.common.lucene.search.Queries
- QUERIES - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- query - Variable in class org.elasticsearch.index.query.InnerHitContextBuilder
- query - Variable in class org.elasticsearch.search.fetch.subphase.highlight.FieldHighlightContext
- query() - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- query() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
The query to validate.
- query() - Method in class org.elasticsearch.action.explain.ExplainRequest
- query() - Method in class org.elasticsearch.index.cache.IndexCache
- query() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Returns the query that defines which documents the function_score query will be executed on.
- query() - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
-
Returns the query builder that defines which documents the script_score query will be executed on.
- query() - Method in class org.elasticsearch.index.query.NestedQueryBuilder
-
Returns the nested query to execute.
- query() - Method in class org.elasticsearch.index.query.ParsedQuery
-
The query parsed.
- query() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- query() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
The query at the top level of the search in which these aggregations are running.
- query() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the query for this request
- query() - Method in class org.elasticsearch.search.fetch.FetchContext
-
The original query, not rewritten.
- query() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- query() - Method in class org.elasticsearch.search.internal.SearchContext
-
The query to execute, not rewritten.
- query() - Method in class org.elasticsearch.search.internal.SubSearchContext
- query() - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- query(TemporalQuery<R>) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- query(QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- query(QueryBuilder) - Method in class org.elasticsearch.action.explain.ExplainRequest
- query(QueryBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets the search query for this request.
- QUERY_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- QUERY_AND_FETCH_TYPE - Static variable in class org.elasticsearch.action.search.ParsedScrollId
- QUERY_ARRAY - Static variable in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- QUERY_CAN_MATCH_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- QUERY_CAN_MATCH_NODE_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- QUERY_CONTENT_TYPE - Static variable in class org.elasticsearch.index.reindex.RemoteInfo
- QUERY_FETCH_SCROLL_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- QUERY_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- QUERY_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- QUERY_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- QUERY_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- QUERY_ID_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- QUERY_SCROLL_ACTION_NAME - Static variable in class org.elasticsearch.action.search.SearchTransportService
- QUERY_STRING_ALLOW_LEADING_WILDCARD - Static variable in class org.elasticsearch.index.IndexSettings
- QUERY_STRING_ANALYZE_WILDCARD - Static variable in class org.elasticsearch.index.IndexSettings
- QUERY_STRING_LENIENT_SETTING - Static variable in class org.elasticsearch.index.IndexSettings
- QUERY_THEN_FETCH - Enum constant in enum class org.elasticsearch.action.search.SearchType
-
The query is executed against all shards, but only enough information is returned (not the document content).
- QUERY_THEN_FETCH_TYPE - Static variable in class org.elasticsearch.action.search.ParsedScrollId
- QueryBuilder - Interface in org.elasticsearch.index.query
- QueryBuilders - Class in org.elasticsearch.index.query
-
Utility class to create search queries.
- queryCache - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- queryCache() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- queryCache() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- queryCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- queryCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- QueryCache - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- QueryCache - Interface in org.elasticsearch.index.cache.query
- QueryCacheStats - Class in org.elasticsearch.index.cache.query
- QueryCacheStats() - Constructor for class org.elasticsearch.index.cache.query.QueryCacheStats
- QueryCacheStats(long, long, long, long, long) - Constructor for class org.elasticsearch.index.cache.query.QueryCacheStats
- QueryCacheStats(StreamInput) - Constructor for class org.elasticsearch.index.cache.query.QueryCacheStats
- queryCollectors() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- queryCollectors() - Method in class org.elasticsearch.search.internal.SearchContext
-
Return a view of the additional query collectors that should be run for this context.
- QueryExplanation - Class in org.elasticsearch.action.admin.indices.validate.query
- QueryExplanation(String, int, boolean, String, String) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- QueryExplanation(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- QueryFetchSearchResult - Class in org.elasticsearch.search.fetch
- QueryFetchSearchResult(StreamInput) - Constructor for class org.elasticsearch.search.fetch.QueryFetchSearchResult
- QueryFetchSearchResult(QuerySearchResult, FetchSearchResult) - Constructor for class org.elasticsearch.search.fetch.QueryFetchSearchResult
- queryName - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- queryName - Variable in class org.elasticsearch.index.query.AbstractQueryBuilder
- queryName() - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Returns the query name for the query.
- queryName() - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Returns the arbitrary name assigned to the query (see named queries).
- queryName() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- queryName(String) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
-
Sets the query name for the query.
- queryName(String) - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Sets the arbitrary name to be assigned to the query (see named queries).
- queryName(String) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- QueryParser<QB extends QueryBuilder> - Interface in org.elasticsearch.index.query
-
Defines a query parser that is able to parse
QueryBuilder
s fromXContent
. - QueryParserHelper - Class in org.elasticsearch.index.search
-
Helpers to extract and expand field names and boosts
- QueryParsers - Class in org.elasticsearch.index.query.support
- QueryPhase - Class in org.elasticsearch.search.query
-
Query phase of a search request, used to run the query and get back from each shard information about the matching documents (document ids and score or sort criteria) so that matches can be reduced on the coordinating node
- QueryPhase() - Constructor for class org.elasticsearch.search.query.QueryPhase
- QueryPhaseExecutionException - Exception in org.elasticsearch.search.query
- QueryPhaseExecutionException(StreamInput) - Constructor for exception org.elasticsearch.search.query.QueryPhaseExecutionException
- QueryPhaseExecutionException(SearchShardTarget, String) - Constructor for exception org.elasticsearch.search.query.QueryPhaseExecutionException
- QueryPhaseExecutionException(SearchShardTarget, String, Throwable) - Constructor for exception org.elasticsearch.search.query.QueryPhaseExecutionException
- QueryPhaseResultConsumer - Class in org.elasticsearch.action.search
-
A
ArraySearchPhaseResults
implementation that incrementally reduces aggregation results as shard results are consumed. - QueryPhaseResultConsumer(SearchRequest, Executor, CircuitBreaker, SearchPhaseController, Supplier<Boolean>, SearchProgressListener, int, Consumer<Exception>) - Constructor for class org.elasticsearch.action.search.QueryPhaseResultConsumer
-
Creates a
QueryPhaseResultConsumer
that incrementally reduces aggregation results as shard results are consumed. - QueryProfileBreakdown - Class in org.elasticsearch.search.profile.query
-
A record of timings for the various operations that may happen during query execution.
- QueryProfileBreakdown() - Constructor for class org.elasticsearch.search.profile.query.QueryProfileBreakdown
-
Sole constructor.
- QueryProfiler - Class in org.elasticsearch.search.profile.query
-
This class acts as a thread-local storage for profiling a query.
- QueryProfiler() - Constructor for class org.elasticsearch.search.profile.query.QueryProfiler
- QueryProfileShardResult - Class in org.elasticsearch.search.profile.query
-
A container class to hold the profile results for a single shard in the request.
- QueryProfileShardResult(List<ProfileResult>, long, CollectorResult) - Constructor for class org.elasticsearch.search.profile.query.QueryProfileShardResult
- QueryProfileShardResult(StreamInput) - Constructor for class org.elasticsearch.search.profile.query.QueryProfileShardResult
-
Read from a stream.
- QueryRescoreContext(int) - Constructor for class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- QueryRescoreMode - Enum Class in org.elasticsearch.search.rescore
- QueryRescorer - Class in org.elasticsearch.search.rescore
- QueryRescorer() - Constructor for class org.elasticsearch.search.rescore.QueryRescorer
- QueryRescorer.QueryRescoreContext - Class in org.elasticsearch.search.rescore
- QueryRescorerBuilder - Class in org.elasticsearch.search.rescore
- QueryRescorerBuilder(StreamInput) - Constructor for class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Read from a stream.
- QueryRescorerBuilder(QueryBuilder) - Constructor for class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Creates a new
QueryRescorerBuilder
instance - queryResult() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- queryResult() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- queryResult() - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- queryResult() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- queryResult() - Method in class org.elasticsearch.search.internal.SearchContext
- queryResult() - Method in class org.elasticsearch.search.internal.SubSearchContext
- queryResult() - Method in class org.elasticsearch.search.query.QuerySearchResult
- queryResult() - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
- queryResult() - Method in class org.elasticsearch.search.SearchPhaseResult
-
Returns the query result iff it's included in this response otherwise
null
- QueryRewriteContext - Class in org.elasticsearch.index.query
-
Context object used to rewrite
QueryBuilder
instances into simplified version. - QueryRewriteContext(NamedXContentRegistry, NamedWriteableRegistry, Client, LongSupplier) - Constructor for class org.elasticsearch.index.query.QueryRewriteContext
- QuerySearchRequest - Class in org.elasticsearch.search.query
- QuerySearchRequest(OriginalIndices, ShardSearchContextId, ShardSearchRequest, AggregatedDfs) - Constructor for class org.elasticsearch.search.query.QuerySearchRequest
- QuerySearchRequest(StreamInput) - Constructor for class org.elasticsearch.search.query.QuerySearchRequest
- QuerySearchResult - Class in org.elasticsearch.search.query
- QuerySearchResult() - Constructor for class org.elasticsearch.search.query.QuerySearchResult
- QuerySearchResult(StreamInput) - Constructor for class org.elasticsearch.search.query.QuerySearchResult
- QuerySearchResult(StreamInput, boolean) - Constructor for class org.elasticsearch.search.query.QuerySearchResult
-
Read the object, but using a delayed aggregations field when delayedAggregations=true.
- QuerySearchResult(ShardSearchContextId, SearchShardTarget, ShardSearchRequest) - Constructor for class org.elasticsearch.search.query.QuerySearchResult
- QueryShardException - Exception in org.elasticsearch.index.query
-
Exception that is thrown when creating lucene queries on the shard
- QueryShardException(StreamInput) - Constructor for exception org.elasticsearch.index.query.QueryShardException
- QueryShardException(Index, String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.query.QueryShardException
-
This constructor is provided for use in unit tests where a
SearchExecutionContext
may not be available - QueryShardException(SearchExecutionContext, String, Object...) - Constructor for exception org.elasticsearch.index.query.QueryShardException
- QueryShardException(SearchExecutionContext, String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.query.QueryShardException
- QuerySpec(String, Writeable.Reader<T>, QueryParser<T>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.QuerySpec
-
Specification of custom
Query
. - QuerySpec(ParseField, Writeable.Reader<T>, QueryParser<T>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.QuerySpec
-
Specification of custom
Query
. - queryStillMatchesAfterRewrite(ShardSearchRequest, QueryRewriteContext) - Static method in class org.elasticsearch.search.SearchService
- queryString() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- queryStringAllowLeadingWildcard() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- queryStringAnalyzeWildcard() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- queryStringLenient() - Method in class org.elasticsearch.index.query.SearchExecutionContext
- queryStringQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that parses a query string and runs it.
- QueryStringQueryBuilder - Class in org.elasticsearch.index.query
-
A query that parses a query string and runs it.
- QueryStringQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.QueryStringQueryBuilder
- QueryStringQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.QueryStringQueryBuilder
-
Read from a stream.
- QueryStringQueryParser - Class in org.elasticsearch.index.search
-
A
XQueryParser
that uses theMapperService
in order to build smarter queries based on the mapping information. - QueryStringQueryParser(SearchExecutionContext, boolean) - Constructor for class org.elasticsearch.index.search.QueryStringQueryParser
-
Defaults to all queryable fields extracted from the mapping for query terms
- QueryStringQueryParser(SearchExecutionContext, String) - Constructor for class org.elasticsearch.index.search.QueryStringQueryParser
- QueryStringQueryParser(SearchExecutionContext, String, boolean) - Constructor for class org.elasticsearch.index.search.QueryStringQueryParser
- QueryStringQueryParser(SearchExecutionContext, Map<String, Float>) - Constructor for class org.elasticsearch.index.search.QueryStringQueryParser
- QueryStringQueryParser(SearchExecutionContext, Map<String, Float>, boolean) - Constructor for class org.elasticsearch.index.search.QueryStringQueryParser
- QueryTimingType - Enum Class in org.elasticsearch.search.profile.query
- QueryToFilterAdapter<Q extends org.apache.lucene.search.Query> - Class in org.elasticsearch.search.aggregations.bucket.filter
-
Adapts a Lucene
Query
to the behaviors used be theFiltersAggregator
. - queryTypes() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Returns the narrowed down explicit types, or, if not set, all types.
- QueryValidationException - Exception in org.elasticsearch.index.query
-
This exception can be used to indicate various reasons why validation of a query has failed.
- QueryValidationException() - Constructor for exception org.elasticsearch.index.query.QueryValidationException
- queryWeight() - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- QUEUE - Enum constant in enum class org.elasticsearch.common.util.PageCacheRecycler.Type
- QUEUED - Enum constant in enum class org.elasticsearch.cluster.SnapshotsInProgress.ShardState
-
Shard snapshot is waiting for another shard snapshot for the same shard and to the same repository to finish.
- QueueResizingEsThreadPoolExecutor - Class in org.elasticsearch.common.util.concurrent
-
An extension to thread pool executor, which automatically adjusts the queue size of the
ResizableBlockingQueue
according to Little's Law. - queueSize - Variable in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- quote(String) - Static method in class org.elasticsearch.common.Strings
-
Quote the given String with single quotes.
- quoteAnalyzer() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
The optional analyzer used to analyze the query string for phrase searches.
- quoteAnalyzer(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
The optional analyzer used to analyze the query string for phrase searches.
- quoteFieldSuffix() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- quoteFieldSuffix() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Return the suffix to append to field names for phrase matching.
- quoteFieldSuffix() - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Return the suffix to append for phrase matching, or
null
if no suffix should be appended. - quoteFieldSuffix(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
An optional field name suffix to automatically try and add to the field searched when using quoted text.
- quoteFieldSuffix(String) - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Set the suffix to append to field names for phrase matching.
- quoteFieldSuffix(String) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Set the suffix to append to field names for phrase matching.
R
- RamAccountingTermsEnum - Class in org.elasticsearch.index.fielddata
-
TermsEnum
that takes a CircuitBreaker, increasing the breaker every time.next(...)
is called. - RamAccountingTermsEnum(TermsEnum, CircuitBreaker, AbstractIndexOrdinalsFieldData.PerValueEstimator, String) - Constructor for class org.elasticsearch.index.fielddata.RamAccountingTermsEnum
- ramBytesUsed() - Method in class org.apache.lucene.util.CombinedBitSet
- ramBytesUsed() - Method in class org.elasticsearch.action.bulk.BulkItemRequest
- ramBytesUsed() - Method in class org.elasticsearch.action.bulk.BulkRequest
- ramBytesUsed() - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- ramBytesUsed() - Method in class org.elasticsearch.action.delete.DeleteRequest
- ramBytesUsed() - Method in class org.elasticsearch.action.index.IndexRequest
- ramBytesUsed() - Method in class org.elasticsearch.action.update.UpdateRequest
- ramBytesUsed() - Method in class org.elasticsearch.common.bytes.BytesArray
- ramBytesUsed() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
The amount of memory used by this BytesReference
- ramBytesUsed() - Method in class org.elasticsearch.common.bytes.CompositeBytesReference
- ramBytesUsed() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
- ramBytesUsed() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- ramBytesUsed() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
-
Returns the number of bytes used by the underlying
ByteArray
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.BinaryScriptFieldData.BinaryScriptLeafFieldData
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData.Consumer
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.ordinals.MultiOrdinals
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.ordinals.Ordinals
-
The memory size this ordinals take.
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.ordinals.SinglePackedOrdinals
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.BinaryDVLeafFieldData
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.LeafDoubleFieldData
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.LeafLongFieldData
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesLeafFieldData
- ramBytesUsed() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetBytesLeafFieldData
- ramBytesUsed() - Method in class org.elasticsearch.index.mapper.flattened.KeyedFlattenedLeafFieldData
- ramTree - Variable in class org.elasticsearch.index.engine.Segment
- RANDOM_SHARD - Static variable in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- randomAllActiveShardsIt() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
-
Returns an unordered iterator over all active shards (including replicas).
- randomBase64UUID() - Static method in class org.elasticsearch.common.UUIDs
-
Returns a Base64 encoded version of a Version 4.0 compatible UUID as defined here: http://www.ietf.org/rfc/rfc4122.txt, using a private
SecureRandom
instance - randomBase64UUID(Random) - Static method in class org.elasticsearch.common.UUIDs
-
Returns a Base64 encoded version of a Version 4.0 compatible UUID as defined here: http://www.ietf.org/rfc/rfc4122.txt, using the provided
Random
instance - randomBase64UUIDSecureString() - Static method in class org.elasticsearch.common.UUIDs
-
Returns a Base64 encoded
SecureString
of a Version 4.0 compatible UUID as defined here: http://www.ietf.org/rfc/rfc4122.txt, using a privateSecureRandom
instance - randomFunction() - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- Randomness - Class in org.elasticsearch.common
-
Provides factory methods for producing reproducible sources of randomness.
- randomScore() - Method in class org.elasticsearch.script.ScoreScriptUtils.RandomScoreDoc
- randomScore() - Method in class org.elasticsearch.script.ScoreScriptUtils.RandomScoreField
- RandomScoreDoc(ScoreScript, int) - Constructor for class org.elasticsearch.script.ScoreScriptUtils.RandomScoreDoc
- RandomScoreField(ScoreScript, int, String) - Constructor for class org.elasticsearch.script.ScoreScriptUtils.RandomScoreField
- RandomScoreFunction - Class in org.elasticsearch.common.lucene.search.function
-
Pseudo randomly generate a score for each
LeafScoreFunction.score(int, float)
. - RandomScoreFunction(int, int, IndexFieldData<?>) - Constructor for class org.elasticsearch.common.lucene.search.function.RandomScoreFunction
-
Creates a RandomScoreFunction.
- RandomScoreFunctionBuilder - Class in org.elasticsearch.index.query.functionscore
-
A function that computes a random score for the matched documents
- RandomScoreFunctionBuilder() - Constructor for class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
- RandomScoreFunctionBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
-
Read from a stream.
- range() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- range(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Range
aggregation with the given name. - range(TemporalField) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- Range - Interface in org.elasticsearch.search.aggregations.bucket.range
-
A
range
aggregation. - Range(String, Double, Double) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder.Range
- Range(String, Double, Double) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- Range(String, Double, String, Double, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- Range(String, Double, String, Double, String, DoubleUnaryOperator) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
-
Build the range.
- Range(String, String, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- Range(String, BytesRef, BytesRef) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregator.Range
- Range(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder.Range
-
Read from a stream.
- Range(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
-
Read from a stream.
- Range(IndexFieldData<?>, RangeType) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Range
- Range(RangeType, Object, Object, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.Range
- RANGE - Enum constant in enum class org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- RANGE - Enum constant in enum class org.elasticsearch.search.aggregations.support.ValueType
- Range.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.range
-
A bucket associated with a specific range
- RangeAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.range
- RangeAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- RangeAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
-
Read from a stream.
- RangeAggregationBuilder(RangeAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- RangeAggregator - Class in org.elasticsearch.search.aggregations.bucket.range
-
Aggregator for
range
. - RangeAggregator(String, AggregatorFactories, ValuesSource, DocValueFormat, InternalRange.Factory, RangeAggregator.Range[], double, boolean, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- RangeAggregator.Range - Class in org.elasticsearch.search.aggregations.bucket.range
- RangeAggregator.Unmapped<R extends RangeAggregator.Range> - Class in org.elasticsearch.search.aggregations.bucket.range
- RangeAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.range
- RangeAggregatorFactory(String, ValuesSourceConfig, RangeAggregator.Range[], boolean, InternalRange.Factory<?, ?>, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>, RangeAggregatorSupplier) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregatorFactory
- RangeAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.bucket.range
- rangeFactory - Variable in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- RangeFieldMapper - Class in org.elasticsearch.index.mapper
-
A
FieldMapper
for indexing numeric and date ranges, and creating queries - RangeFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- RangeFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- RangeFieldMapper.Range - Class in org.elasticsearch.index.mapper
-
Class defining a range
- RangeFieldMapper.RangeFieldType - Class in org.elasticsearch.index.mapper
- RangeFieldType(String, boolean, boolean, boolean, DateFormatter, boolean, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- RangeFieldType(String, DateFormatter) - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- RangeFieldType(String, RangeType) - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- RangeFieldType(String, RangeType, boolean, boolean, boolean, boolean, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- RangeHistogramAggregator - Class in org.elasticsearch.search.aggregations.bucket.histogram
- RangeHistogramAggregator(String, AggregatorFactories, double, double, BucketOrder, boolean, long, DoubleBounds, DoubleBounds, ValuesSourceConfig, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.RangeHistogramAggregator
- rangeQuery(Object, Object, boolean, boolean, ZoneId, DateMathParser, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.BooleanScriptFieldType
- rangeQuery(Object, Object, boolean, boolean, ZoneId, DateMathParser, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DateScriptFieldType
- rangeQuery(Object, Object, boolean, boolean, ZoneId, DateMathParser, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DoubleScriptFieldType
- rangeQuery(Object, Object, boolean, boolean, ZoneId, DateMathParser, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.GeoPointScriptFieldType
- rangeQuery(Object, Object, boolean, boolean, ZoneId, DateMathParser, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.IpScriptFieldType
- rangeQuery(Object, Object, boolean, boolean, ZoneId, DateMathParser, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- rangeQuery(Object, Object, boolean, boolean, ZoneId, DateMathParser, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- rangeQuery(Object, Object, boolean, boolean, BiFunction<InetAddress, InetAddress, Query>) - Static method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
-
Processes query bounds into
long
s and delegates the providedbuilder
to build a range query. - rangeQuery(Object, Object, boolean, boolean, ShapeRelation, ZoneId, DateMathParser, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- rangeQuery(Object, Object, boolean, boolean, ShapeRelation, ZoneId, DateMathParser, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- rangeQuery(Object, Object, boolean, boolean, ShapeRelation, ZoneId, DateMathParser, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Factory method for range queries.
- rangeQuery(Object, Object, boolean, boolean, ShapeRelation, ZoneId, DateMathParser, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- rangeQuery(Object, Object, boolean, boolean, ShapeRelation, ZoneId, DateMathParser, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.SimpleMappedFieldType
- rangeQuery(Object, Object, boolean, boolean, ShapeRelation, ZoneId, DateMathParser, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypeFieldType
- rangeQuery(Object, Object, boolean, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- rangeQuery(Object, Object, boolean, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldType
- rangeQuery(Object, Object, boolean, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- rangeQuery(Object, Object, boolean, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- rangeQuery(Object, Object, boolean, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.SimpleMappedFieldType
-
Same as
SimpleMappedFieldType.rangeQuery(Object, Object, boolean, boolean, ShapeRelation, ZoneId, DateMathParser, SearchExecutionContext)
but without the trouble of relations or date-specific options. - rangeQuery(Object, Object, boolean, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.StringFieldType
- rangeQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents within an range of terms.
- rangeQuery(String, boolean, Object, Object, boolean, boolean, ShapeRelation, ZoneId, DateMathParser, SearchExecutionContext) - Method in enum class org.elasticsearch.index.mapper.RangeType
- rangeQuery(String, Object, Object, boolean, boolean, boolean, SearchExecutionContext) - Method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- RangeQueryBuilder - Class in org.elasticsearch.index.query
-
A Query that matches documents within an range of terms.
- RangeQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.RangeQueryBuilder
-
A Query that matches documents within an range of terms.
- RangeQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.RangeQueryBuilder
-
Read from a stream.
- ranges - Variable in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- ranges - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- ranges() - Method in class org.elasticsearch.search.aggregations.bucket.range.AbstractRangeBuilder
- RANGES_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- rangeType - Variable in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- rangeType() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- rangeType() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Range
- RangeType - Enum Class in org.elasticsearch.index.mapper
-
Enum defining the type of range
- RangeType.LengthType - Enum Class in org.elasticsearch.index.mapper
- rank(long) - Method in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- RareTerms - Interface in org.elasticsearch.search.aggregations.bucket.terms
- RareTerms.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.terms
-
A bucket that is associated with a single term
- RareTermsAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.terms
- RareTermsAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- RareTermsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
-
Read from a stream.
- RareTermsAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.terms
- RareTermsAggregatorFactory.ExecutionMode - Enum Class in org.elasticsearch.search.aggregations.bucket.terms
- rateLimiter() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- RateLimitingFilter - Class in org.elasticsearch.common.logging
-
A filter used for throttling deprecation logs.
- RateLimitingFilter() - Constructor for class org.elasticsearch.common.logging.RateLimitingFilter
- RateLimitingFilter(Filter.Result, Filter.Result) - Constructor for class org.elasticsearch.common.logging.RateLimitingFilter
- RateLimitingInputStream - Class in org.elasticsearch.index.snapshots.blobstore
-
Rate limiting wrapper for InputStream
- RateLimitingInputStream(InputStream, Supplier<RateLimiter>, RateLimitingInputStream.Listener) - Constructor for class org.elasticsearch.index.snapshots.blobstore.RateLimitingInputStream
- RateLimitingInputStream.Listener - Interface in org.elasticsearch.index.snapshots.blobstore
- ratio - Variable in enum class org.elasticsearch.common.Rounding.DateTimeUnit
-
ratio to milliseconds if isMillisBased == true or to month otherwise
- RatioValue - Class in org.elasticsearch.common.unit
-
Utility class to represent ratio and percentage values between 0 and 100
- RatioValue(double) - Constructor for class org.elasticsearch.common.unit.RatioValue
- RAW - Static variable in interface org.elasticsearch.search.DocValueFormat
- RawIndexingDataTransportRequest - Interface in org.elasticsearch.transport
-
Requests that implement this interface will be compressed when
TransportSettings.TRANSPORT_COMPRESS
is configured toCompression.Enabled.INDEXING_DATA
and isRawIndexingData() returns true. - rawPath() - Method in class org.elasticsearch.rest.RestRequest
-
The non decoded, raw path provided.
- rawRelativeTimeInMillis() - Method in class org.elasticsearch.threadpool.ThreadPool
-
Returns a value of milliseconds that may be used for relative time calculations.
- RawTaskStatus - Class in org.elasticsearch.tasks
-
Raw, unparsed status from the task results index.
- RawTaskStatus(BytesReference) - Constructor for class org.elasticsearch.tasks.RawTaskStatus
- RawTaskStatus(StreamInput) - Constructor for class org.elasticsearch.tasks.RawTaskStatus
-
Read from a stream.
- rawToXContent(XContentBuilder) - Method in class org.elasticsearch.search.sort.SortValue
-
Write the key as xcontent using the most native type possible.
- read() - Method in class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- read() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- read() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- read() - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- read() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- read() - Method in class org.elasticsearch.index.snapshots.blobstore.RateLimitingInputStream
- read() - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
- read() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- read(byte[]) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- read(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- read(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- read(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- read(byte[], int, int) - Method in class org.elasticsearch.index.snapshots.blobstore.RateLimitingInputStream
- read(byte[], int, int) - Method in class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
- read(String, BlobContainer, String, NamedXContentRegistry) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
-
Reads and parses the blob with given name, applying name translation using the {link #blobName} method
- read(StreamInput) - Method in class org.elasticsearch.action.ActionListenerResponseHandler
- read(StreamInput) - Method in interface org.elasticsearch.common.io.stream.Writeable.Reader
-
Read
V
-type value from a stream. - read(StreamInput) - Static method in class org.elasticsearch.common.Rounding
- read(StreamInput) - Static method in class org.elasticsearch.common.rounding.Rounding.Streams
-
Deprecated.
- read(StreamInput) - Static method in class org.elasticsearch.search.aggregations.metrics.TDigestState
- read(StreamInput) - Method in class org.elasticsearch.transport.EmptyTransportResponseHandler
- read(StreamInput) - Method in class org.elasticsearch.transport.PlainTransportFuture
- read(StreamInput) - Method in class org.elasticsearch.transport.TransportResponseHandler.Empty
- read(StreamInput) - Method in class org.elasticsearch.transport.TransportService.ContextRestoreResponseHandler
- read(StreamInput, long, long, DocValueFormat) - Method in interface org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket.Reader
- read(StreamInput, String) - Method in class org.elasticsearch.cluster.NamedDiffableValueSerializer
- read(StreamInput, K) - Method in class org.elasticsearch.cluster.DiffableUtils.DiffableValueReader
- read(StreamInput, K) - Method in class org.elasticsearch.cluster.DiffableUtils.StringSetValueSerializer
- read(StreamInput, K) - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Reads value from stream.
- read(StreamInput, DocValueFormat) - Method in interface org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket.Reader
- read(StreamInput, DocValueFormat, boolean) - Method in interface org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket.Reader
- read(HttpRequest) - Method in class org.elasticsearch.http.HttpPipeliningAggregator
- read(BufferedChecksumStreamInput) - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- read(NamedXContentRegistry, Path) - Method in class org.elasticsearch.gateway.MetadataStateFormat
-
Reads the state from a given file and compares the expected version against the actual version of the state.
- READ - Enum constant in enum class org.elasticsearch.cluster.block.ClusterBlockLevel
- READ - Enum constant in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
- READ_ONLY - Enum constant in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
- READ_ONLY_ALLOW_DELETE - Enum constant in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
- READ_WRITE - Static variable in enum class org.elasticsearch.cluster.block.ClusterBlockLevel
- readAllLines(InputStream) - Static method in class org.elasticsearch.common.io.Streams
- readAllLines(InputStream, Consumer<String>) - Static method in class org.elasticsearch.common.io.Streams
- readAllowed() - Method in class org.elasticsearch.index.shard.IndexShard
- readArray(Writeable.Reader<T>, IntFunction<T[]>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an array from the stream using the specified
Writeable.Reader
to read array elements from the stream. - readArraySize() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a vint via
StreamInput.readVInt()
and applies basic checks to ensure the read array size is sane. - readBigInteger() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readBlob(String) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Creates a new
InputStream
for the given blob name. - readBlob(String) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- readBlob(String) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- readBlob(String, long, long) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Creates a new
InputStream
that can be used to read the given blob starting from a specificposition
in the blob. - readBlob(String, long, long) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- readBlob(String, long, long) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- readBlobPreferredLength() - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Provides a hint to clients for a suitable length to use with
BlobContainer.readBlob(String, long, long)
. - readBlobPreferredLength() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- readBlobPreferredLength() - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- readBoolean() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a boolean.
- readBooleanProperty(String, String, Map<String, Object>, String, boolean) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- readBuild(StreamInput) - Static method in class org.elasticsearch.Build
- readByte() - Method in class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- readByte() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- readByte() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- readByte() - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- readByte() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads and returns a single byte.
- readByte() - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- readByte() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- readByteArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- readBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- readBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- readBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- readBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a specified number of bytes into an array at the specified offset.
- readBytes(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- readBytes(byte[], int, int) - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- readBytes(ByteBuffer, long) - Method in class org.elasticsearch.index.translog.BaseTranslogReader
-
reads bytes at position into the given buffer, filling it.
- readBytes(ByteBuffer, long) - Method in class org.elasticsearch.index.translog.TranslogReader
-
reads an operation at the given position into the given buffer.
- readBytes(ByteBuffer, long) - Method in class org.elasticsearch.index.translog.TranslogWriter
- readBytesRef() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readBytesRef(int) - Method in class org.elasticsearch.common.io.stream.StreamInput
- readBytesReference() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a bytes reference from this stream, copying any bytes read to a new
byte[]
. - readBytesReference(int) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a bytes reference from this stream, might hold an actual reference to the underlying bytes of the stream.
- readCompressedString(StreamInput) - Static method in class org.elasticsearch.common.compress.CompressedXContent
- readDiff(StreamInput, String) - Method in class org.elasticsearch.cluster.NamedDiffableValueSerializer
- readDiff(StreamInput, K) - Method in class org.elasticsearch.cluster.DiffableUtils.DiffableValueReader
- readDiff(StreamInput, K) - Method in class org.elasticsearch.cluster.DiffableUtils.NonDiffableValueSerializer
- readDiff(StreamInput, K) - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Reads value as diff from stream if this serializer supports diffable values.
- readDiffFrom(Class<? extends T>, String, StreamInput) - Static method in class org.elasticsearch.cluster.AbstractNamedDiffable
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.block.ClusterBlocks
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.AliasMetadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.DataStream
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.DataStreamAlias
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.DiffableStringMap
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.MappingMetadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.Metadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.RepositoryCleanupInProgress
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.RestoreInProgress
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.RoutingTable
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.cluster.SnapshotsInProgress
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.ingest.IngestMetadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.ingest.PipelineConfiguration
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.script.ScriptMetadata
- readDiffFrom(StreamInput) - Static method in class org.elasticsearch.script.StoredScriptSource
-
Required for
ScriptMetadata.ScriptMetadataDiff
. - readDiffFrom(StreamInput) - Static method in class org.elasticsearch.upgrades.FeatureMigrationResults
- readDiffFrom(StreamInput, DiscoveryNode) - Static method in class org.elasticsearch.cluster.ClusterState
- readDiffFrom(StreamInput, DiscoveryNode) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes
- readDiffFrom(Writeable.Reader<T>, StreamInput) - Static method in class org.elasticsearch.cluster.AbstractDiffable
- readDocumentRequest(ShardId, StreamInput) - Static method in interface org.elasticsearch.action.DocWriteRequest
-
Read a document write (index/delete/update) request
- readDouble() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readDoubleArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readDoubleLE(byte[], int) - Static method in enum class org.elasticsearch.common.util.ByteUtils
-
Read a double in little-endian format.
- readDoubleProperty(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property from the specified configuration map.
- readEmptyResultFrom(StreamInput) - Static method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.EmptyResult
- readEnum(Class<E>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an enum with type E that was serialized based on the value of its ordinal
- readEnumSet(Class<E>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an enum with type E that was serialized based on the value of it's ordinal
- reader - Variable in class org.elasticsearch.common.io.stream.NamedWriteableRegistry.Entry
-
A reader capability of reading
- reader - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndVersion
- reader - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- reader() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- readerContext() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- readerContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- readerContext() - Method in class org.elasticsearch.search.internal.SearchContext
- ReaderContext - Class in org.elasticsearch.search.internal
-
Holds a reference to a point in time
Engine.Searcher
that will be used to constructSearchContext
. - ReaderContext(ShardSearchContextId, IndexService, IndexShard, Engine.SearcherSupplier, long, boolean) - Constructor for class org.elasticsearch.search.internal.ReaderContext
- readerId() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
-
Returns a non-null value if this request should execute using a specific point-in-time reader; otherwise, using the most up to date point-in-time reader.
- readerKey - Variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
- readerValue() - Method in class org.elasticsearch.index.mapper.CustomDocValuesField
- readException() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readException(StreamInput) - Static method in exception org.elasticsearch.ElasticsearchException
- readException(StreamInput, int) - Static method in exception org.elasticsearch.ElasticsearchException
- readExplanation(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readFieldDoc(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readFloat() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readFloatArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readFloatLE(byte[], int) - Static method in enum class org.elasticsearch.common.util.ByteUtils
-
Read a float in little-endian format.
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.action.DocWriteResponse.Result
- readFrom(StreamInput) - Static method in class org.elasticsearch.action.support.ActiveShardCount
- readFrom(StreamInput) - Static method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.action.support.WriteRequest.RefreshPolicy
- readFrom(StreamInput) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.block.ClusterBlocks
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.cluster.health.ClusterHealthStatus
-
Read from a stream.
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.DiffableStringMap
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.Metadata
- readFrom(StreamInput) - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Reads restore status from stream input
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Reads a
AllocationCommands
from aStreamInput
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.allocation.RerouteExplanation
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
-
Read in a RoutingExplanations object
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.RecoverySource
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.routing.RoutingTable
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.cluster.SnapshotDeletionsInProgress.State
- readFrom(StreamInput) - Static method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.common.geo.Orientation
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.common.Priority
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.common.unit.ByteSizeUnit
-
Reads a
ByteSizeUnit
from a givenStreamInput
- readFrom(StreamInput) - Static method in class org.elasticsearch.index.shard.IndexLongFieldRange
- readFrom(StreamInput) - Static method in class org.elasticsearch.index.shard.ShardLongFieldRange
- readFrom(StreamInput) - Static method in class org.elasticsearch.ingest.PipelineConfiguration
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.rest.RestStatus
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.script.ScriptType
-
Reads an int from the input stream and converts it to a
ScriptType
. - readFrom(StreamInput) - Static method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceParserHelper
- readFrom(StreamInput) - Static method in class org.elasticsearch.search.aggregations.InternalAggregations
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Deserialize the GapPolicy from the input stream
- readFrom(StreamInput) - Static method in enum class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.SeasonalityType
-
Deserialize the SeasonalityType from the input stream
- readFrom(StreamInput) - Static method in class org.elasticsearch.snapshots.SnapshotInfo
-
Constructs snapshot information from stream input
- readFrom(StreamInput, DefaultShardOperationFailedException) - Static method in exception org.elasticsearch.action.support.DefaultShardOperationFailedException
- readFrom(StreamInput, DiscoveryNode) - Static method in class org.elasticsearch.cluster.ClusterState
- readFrom(StreamInput, DiscoveryNode) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes
- readFrom(StreamInput, BigArrays) - Static method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
- readFromFileChannel(FileChannel, long, byte[], int, int) - Static method in class org.elasticsearch.common.io.Channels
-
read length bytes from position of a file channel.
- readFromFileChannel(FileChannel, long, int) - Static method in class org.elasticsearch.common.io.Channels
-
read length bytes from position of a file channel
- readFromFileChannel(FileChannel, long, ByteBuffer) - Static method in class org.elasticsearch.common.io.Channels
-
read from a file channel into a byte buffer, starting at a certain position.
- readFromFileChannelWithEofException(FileChannel, long, byte[], int, int) - Static method in class org.elasticsearch.common.io.Channels
-
read length bytes from position of a file channel.
- readFromFileChannelWithEofException(FileChannel, long, ByteBuffer) - Static method in class org.elasticsearch.common.io.Channels
-
read from a file channel into a byte buffer, starting at a certain position.
- readFromProperties(Path) - Static method in class org.elasticsearch.plugins.PluginDescriptor
-
Reads the plugin descriptor file.
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.common.geo.GeoDistance
-
Creates a GeoDistance instance from an input stream
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.common.geo.ShapeRelation
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.common.geo.SpatialStrategy
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.common.lucene.search.function.CombineFunction
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Read a
DistanceUnit
from aStreamInput
. - readFromStream(StreamInput) - Static method in enum class org.elasticsearch.index.query.GeoExecType
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.index.query.GeoValidationMethod
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.index.query.Operator
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.index.query.ZeroTermsQueryOption
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.index.search.MatchQueryParser.Type
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.index.VersionType
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.search.aggregations.bucket.composite.MissingOrder
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.search.aggregations.metrics.PercentilesMethod
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.search.aggregations.support.ValueType
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.search.rescore.QueryRescoreMode
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.search.sort.SortMode
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.search.sort.SortOrder
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.search.suggest.SortBy
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
- readFromStream(StreamInput) - Static method in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
- readFromStream(StreamInput) - Static method in class org.elasticsearch.tasks.TaskId
-
Read a TaskId from a stream.
- readFromThin(StreamInput, Index) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- readFromWithId(ShardSearchContextId, StreamInput) - Method in class org.elasticsearch.search.query.QuerySearchResult
- readFully(byte[]) - Method in class org.elasticsearch.common.io.stream.StreamInput
- readFully(InputStream) - Static method in class org.elasticsearch.common.io.Streams
-
Reads all bytes from the given
InputStream
and closes it afterwards. - readFully(InputStream, byte[]) - Static method in class org.elasticsearch.common.io.Streams
- readFully(InputStream, byte[], int, int) - Static method in class org.elasticsearch.common.io.Streams
- readFully(Reader, char[]) - Static method in class org.elasticsearch.common.io.Streams
- readFully(Reader, char[], int, int) - Static method in class org.elasticsearch.common.io.Streams
- readGenericValue() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a value of unspecified type.
- readGeometry(StreamInput) - Static method in class org.elasticsearch.common.geo.GeometryIO
- readGeoPoint() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a
GeoPoint
from this stream input - readGlobalCheckpoint(Path, String) - Static method in class org.elasticsearch.index.translog.Translog
-
Reads the sequence numbers global checkpoint from the translog checkpoint.
- readHeaders(StreamInput) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Reads the headers from the stream into the current context
- readHeadersFromStream(StreamInput) - Static method in class org.elasticsearch.common.util.concurrent.ThreadContext
- readHistogramOrder(StreamInput, boolean) - Static method in class org.elasticsearch.search.aggregations.InternalOrder.Streams
-
ONLY FOR HISTOGRAM ORDER: Backwards compatibility logic to read a
BucketOrder
from aStreamInput
. - readHistoryOperations(String, Engine.HistorySource, MapperService, long) - Method in class org.elasticsearch.index.engine.Engine
-
Creates a new history snapshot for reading operations since
startingSeqNo
(inclusive). - readHistoryOperations(String, Engine.HistorySource, MapperService, long) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Creates a new history snapshot for reading operations since the provided seqno.
- readHistoryOperations(String, Engine.HistorySource, MapperService, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- readImmutableMap(Writeable.Reader<K>, Writeable.Reader<V>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read
ImmutableOpenMap
using given key and value readers. - readImmutableOpenIntMapDiff(StreamInput, DiffableUtils.KeySerializer<Integer>, DiffableUtils.ValueSerializer<Integer, T>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two ImmutableOpenMaps
- readImmutableOpenIntMapDiff(StreamInput, DiffableUtils.KeySerializer<Integer>, Writeable.Reader<T>, Writeable.Reader<Diff<T>>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two ImmutableOpenIntMaps of Diffable objects using Diffable proto object
- readImmutableOpenMapDiff(StreamInput, DiffableUtils.KeySerializer<K>, DiffableUtils.DiffableValueReader<K, T>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two ImmutableOpenMaps of Diffable objects using Diffable proto object
- readImmutableOpenMapDiff(StreamInput, DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two ImmutableOpenMaps
- readIndicesOptions(StreamInput) - Static method in class org.elasticsearch.action.support.IndicesOptions
- readInstant() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read an
Instant
from the stream with nanosecond resolution - readInt() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- readInt() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- readInt() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads four bytes and returns an int.
- readInt() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- readIntArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readIntLE(byte[], int) - Static method in enum class org.elasticsearch.common.util.ByteUtils
-
Read an int in little-endian format.
- readIntProperty(String, String, Map<String, Object>, String, Integer) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property from the specified configuration map.
- readJdkMapDiff(StreamInput, DiffableUtils.KeySerializer<K>, DiffableUtils.ValueSerializer<K, T>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two Maps of Diffable objects
- readJdkMapDiff(StreamInput, DiffableUtils.KeySerializer<K>, Writeable.Reader<T>, Writeable.Reader<Diff<T>>) - Static method in class org.elasticsearch.cluster.DiffableUtils
-
Loads an object that represents difference between two Maps of Diffable objects using Diffable proto object
- readKey(StreamInput) - Method in interface org.elasticsearch.cluster.DiffableUtils.KeySerializer
- readKilobytes() - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- readLastCommittedSegmentsInfo() - Method in class org.elasticsearch.index.store.Store
-
Returns the last committed segments info for this store
- readLength(byte[], int) - Method in enum class org.elasticsearch.index.mapper.RangeType.LengthType
-
Return the length of the value that starts at
offset
inbytes
. - readList(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property of type list from the specified configuration map.
- readList(Writeable.Reader<T>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a list of objects.
- readListShardStoreNodeOperationResponse(StreamInput) - Static method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodeStoreFilesMetadata
- readLock - Variable in class org.elasticsearch.index.engine.Engine
- readLock - Variable in class org.elasticsearch.index.translog.Translog
- readLong() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- readLong() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- readLong() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads eight bytes and returns a long.
- readLong() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- readLongArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readLongLE(byte[], int) - Static method in enum class org.elasticsearch.common.util.ByteUtils
-
Write a long in little-endian format.
- readMap() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
If the returned map contains any entries it will be mutable.
- readMap(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property of type map from the specified configuration map.
- readMap(Writeable.Reader<K>, Writeable.Reader<V>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
If the returned map contains any entries it will be mutable.
- readMapOfLists(Writeable.Reader<K>, Writeable.Reader<V>) - Method in class org.elasticsearch.common.io.stream.StreamInput
- readMediaTypeProperty(String, String, Map<String, Object>, String, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- readMessageLength(BytesReference) - Static method in class org.elasticsearch.transport.TcpTransport
-
Validates the first 6 bytes of the message header and returns the length of the message.
- readMetadataSnapshot(Path, ShardId, NodeEnvironment.ShardLocker, Logger) - Static method in class org.elasticsearch.index.store.Store
-
Reads a MetadataSnapshot from the given index locations or returns an empty snapshot if it can't be read.
- readMinTranslogGeneration(Path, String) - Static method in class org.elasticsearch.index.translog.Translog
-
Returns the minimum translog generation retained by the translog at the given location.
- readMultiLineFormat(BytesReference, XContent, CheckedBiConsumer<SearchRequest, XContentParser, IOException>, String[], IndicesOptions, String[], String, String, Boolean, NamedXContentRegistry, boolean, DeprecationLogger) - Static method in class org.elasticsearch.action.search.MultiSearchRequest
- readMultiLineFormat(BytesReference, XContent, CheckedBiConsumer<SearchRequest, XContentParser, IOException>, String[], IndicesOptions, String[], String, String, Boolean, NamedXContentRegistry, boolean, DeprecationLogger, TriFunction<String, Object, SearchRequest, Boolean>) - Static method in class org.elasticsearch.action.search.MultiSearchRequest
- readMultiValueModeFrom(StreamInput) - Static method in enum class org.elasticsearch.search.MultiValueMode
- readNamedWriteable(Class<C>) - Method in class org.elasticsearch.common.io.stream.NamedWriteableAwareStreamInput
- readNamedWriteable(Class<C>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a
NamedWriteable
from the current stream, by first reading its name and then looking for the corresponding entry in the registry by name, so that the proper object can be read and returned. - readNamedWriteable(Class<C>, String) - Method in class org.elasticsearch.common.io.stream.NamedWriteableAwareStreamInput
- readNamedWriteable(Class<C>, String) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a
NamedWriteable
from the current stream with the given name. - readNamedWriteableList(Class<T>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a list of
NamedWriteable
s. - readNodeResponse(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodesSnapshotStatus
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.dangling.find.FindDanglingIndexResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesResponse
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
Read the
BaseNodesResponse.nodes
from the stream. - readNodesFrom(StreamInput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodesGatewayMetaState
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodesGatewayStartedShards
- readNodesFrom(StreamInput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodesStoreFilesMetadata
- readObject(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property as an
Object
from the specified configuration map. - READONCE_CHECKSUM - Static variable in class org.elasticsearch.index.store.Store
-
Specific
IOContext
indicating that we will read only the Lucene file footer (containing the file checksum) SeeStore.MetadataSnapshot.checksumFromLuceneFile(org.apache.lucene.store.Directory, java.lang.String, java.util.Map<java.lang.String, org.elasticsearch.index.store.StoreFileMetadata>, org.apache.logging.log4j.Logger, java.lang.String, boolean, org.apache.lucene.util.BytesRef)
. - READONLY_SETTING_KEY - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
All
BlobStoreRepository
implementations can be made read-only by setting this key totrue
in their settings. - ReadOnlyEngine - Class in org.elasticsearch.index.engine
-
A basic read-only engine that allows switching a shard to be true read-only temporarily or permanently.
- ReadOnlyEngine(EngineConfig, SeqNoStats, TranslogStats, boolean, Function<DirectoryReader, DirectoryReader>, boolean, boolean) - Constructor for class org.elasticsearch.index.engine.ReadOnlyEngine
-
Creates a new ReadOnlyEngine.
- readOperation(StreamInput) - Static method in interface org.elasticsearch.index.translog.Translog.Operation
-
Reads the type and the operation from the given stream.
- readOperation(Translog.Location) - Method in class org.elasticsearch.index.translog.Translog
-
Reads and returns the operation from the given location if the generation it references is still available.
- readOperations() - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- readOperations(StreamInput, String) - Static method in class org.elasticsearch.index.translog.Translog
-
Reads a list of operations written with
Translog.writeOperations(StreamOutput, List)
- readOptionalArray(Writeable.Reader<T>, IntFunction<T[]>) - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalBoolean() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalBytesReference() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an optional bytes reference from this stream.
- readOptionalCommitStatsFrom(StreamInput) - Static method in class org.elasticsearch.index.engine.CommitStats
- readOptionalDouble() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalEnum(Class<E>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an optional enum with type E that was serialized based on the value of its ordinal
- readOptionalFloat() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalInstant() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read an optional
Instant
from the stream. - readOptionalInt() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an optional
Integer
. - readOptionalList(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property of type list from the specified configuration map.
- readOptionalLong() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalMap(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property of type map from the specified configuration map.
- readOptionalNamedWriteable(Class<C>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an optional
NamedWriteable
. - readOptionalRestoreInfo(StreamInput) - Static method in class org.elasticsearch.snapshots.RestoreInfo
-
Reads optional restore info from
StreamInput
- readOptionalSecureString() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalString() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalStringArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalStringList() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an optional list of strings.
- readOptionalStringOrIntProperty(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property from the specified configuration map.
- readOptionalStringOrLongProperty(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property from the specified configuration map.
- readOptionalStringProperty(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified optional property from the specified configuration map.
- readOptionalText() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalTimeValue() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read an optional
TimeValue
from the stream, returning null if no TimeValue was written. - readOptionalTimeZone() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read an optional DateTimeZone.
- readOptionalVInt() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalVLong() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalWriteable(Writeable.Reader<T>) - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOptionalZoneId() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read an optional ZoneId.
- readOrder(StreamInput) - Static method in class org.elasticsearch.search.aggregations.InternalOrder.Streams
-
Read a
BucketOrder
from aStreamInput
. - readOrderedMap(Writeable.Reader<K>, Writeable.Reader<V>) - Method in class org.elasticsearch.common.io.stream.StreamInput
- readOriginalIndices(StreamInput) - Static method in class org.elasticsearch.action.OriginalIndices
- readPassword(Terminal, boolean) - Static method in class org.elasticsearch.cli.KeyStoreAwareCommand
-
Reads the keystore password from the
Terminal
, prompting for verification where applicable and returns it as aSecureString
. - readPerFieldAnalyzer(Map<String, Object>) - Static method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- readPolicy(URL, Map<String, URL>) - Static method in class org.elasticsearch.bootstrap.PolicyUtil
-
Reads and returns the specified
policyFile
. - readProcessor(Map<String, Processor.Factory>, ScriptService, String, Object) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- readProcessor(Map<String, Processor.Factory>, ScriptService, String, Map<String, Object>) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- readProcessorConfigs(List<Map<String, Object>>, ScriptService, Map<String, Processor.Factory>) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- readRecoveryState(StreamInput) - Static method in class org.elasticsearch.indices.recovery.RecoveryState
- readReleasableBytesReference() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- readReleasableBytesReference() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a releasable bytes reference from this stream.
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.TransportFieldUsageAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
- readRequestFrom(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Deserialize a request from an input stream
- readResponseFrom(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- readScoreDoc(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readSecret(String) - Method in class org.elasticsearch.bootstrap.plugins.LoggerTerminal
- readSecret(String, int) - Method in class org.elasticsearch.bootstrap.plugins.LoggerTerminal
- readSecureString() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readSegmentInfos(IndexCommit) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Reads the segments infos from the given commit, failing if it fails to load
- readSegmentInfos(Directory) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Reads the segments infos, failing if it fails to load
- readSet(Writeable.Reader<T>) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a set of objects.
- readSettingsFromStream(StreamInput) - Static method in class org.elasticsearch.common.settings.Settings
- readShardOperationFailed(StreamInput) - Static method in exception org.elasticsearch.action.support.DefaultShardOperationFailedException
- readShardResponse(StreamInput) - Method in class org.elasticsearch.action.admin.indices.diskusage.TransportAnalyzeIndexDiskUsageAction
- readShardResponse(StreamInput) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- readShardResponse(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- readShardRestoreStatus(StreamInput) - Static method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Reads restore status from stream input
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.TransportFieldUsageAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
- readShardResult(StreamInput) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Deserialize a shard-level result from an input stream
- readShardSearchFailure(StreamInput) - Static method in exception org.elasticsearch.action.search.ShardSearchFailure
- readShort() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- readShort() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- readShort() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readShort() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- readSize(ByteBuffer, long) - Method in class org.elasticsearch.index.translog.BaseTranslogReader
-
read the size of the op (i.e., number of bytes, including the op size) written at the given position
- readSize(StreamInput) - Static method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Read a size under the assumption that a value of 0 means unlimited.
- readSortField(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readSortType(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readSortValue(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readStackTrace(T, StreamInput) - Static method in exception org.elasticsearch.ElasticsearchException
-
Deserializes stacktrace elements as well as suppressed exceptions from the given output stream and adds it to the given exception.
- readStats(StreamInput) - Static method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- readString() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readStringArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readStringList() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a list of strings.
- readStringOrIntProperty(String, String, Map<String, Object>, String, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property from the specified configuration map.
- readStringProperty(String, String, Map<String, Object>, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property from the specified configuration map.
- readStringProperty(String, String, Map<String, Object>, String, String) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
-
Returns and removes the specified property from the specified configuration map.
- readSyncedFlushResponse(StreamInput) - Static method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- readTemplateProperty(String, String, Map<String, Object>, String, ScriptService) - Static method in class org.elasticsearch.ingest.ConfigurationUtils
- readText() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readText(String) - Method in class org.elasticsearch.bootstrap.plugins.LoggerTerminal
- readTimeValue() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read a
TimeValue
from the stream - readTimeZone() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read a DateTimeZone.
- readTopDocs(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readTotalHits(StreamInput) - Static method in class org.elasticsearch.common.lucene.Lucene
- readURIParameters(TermVectorsRequest, RestRequest) - Static method in class org.elasticsearch.rest.action.document.RestTermVectorsAction
- readValue(BytesRef) - Method in interface org.elasticsearch.search.aggregations.bucket.terms.BytesKeyedBucketOrds.BucketOrdsEnum
-
Read the current value.
- readVersion(StreamInput) - Static method in class org.elasticsearch.Version
- readVInt() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- readVInt() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads an int stored in variable-length format.
- readVInt() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- readVIntArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readVIntSlow() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readVLong() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- readVLong() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Reads a long stored in variable-length format.
- readVLong() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- readVLongArray() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readVLongSlow() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readyToShutdown(String, SingleNodeShutdownMetadata.Type) - Method in class org.elasticsearch.shutdown.PluginShutdownService
-
Check with registered plugins whether the shutdown is safe for the given node id and type
- readZLong() - Method in class org.elasticsearch.common.io.stream.StreamInput
- readZoneId() - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Read a DateTimeZone.
- REALLOCATED_REPLICA - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
A better replica location is identified and causes the existing replica allocation to be cancelled.
- realtime() - Method in class org.elasticsearch.action.get.GetRequest
- realtime() - Method in class org.elasticsearch.action.get.MultiGetRequest
- realtime() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- realtime() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return whether term vectors should be generated real-time (default to true).
- realtime() - Method in class org.elasticsearch.index.engine.Engine.Get
- realtime(boolean) - Method in class org.elasticsearch.action.get.GetRequest
- realtime(boolean) - Method in class org.elasticsearch.action.get.MultiGetRequest
- realtime(boolean) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- realtime(boolean) - Method in interface org.elasticsearch.action.RealtimeRequest
- realtime(boolean) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- realtime(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- RealtimeRequest - Interface in org.elasticsearch.action
-
Indicates that a request can execute in realtime (reads from the translog).
- realWordErrorLikelihood() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the
PhraseSuggestionBuilder.realWordErrorLikelihood(float)
parameter - realWordErrorLikelihood(float) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets the likelihood of a term being a misspelled even if the term exists in the dictionary.
- realWordLikelihood - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- reason - Variable in exception org.elasticsearch.action.ShardOperationFailedException
- reason - Variable in class org.elasticsearch.index.shard.IndexShard.ShardFailure
- reason() - Method in exception org.elasticsearch.action.ShardOperationFailedException
-
The reason of the failure.
- reason() - Method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor.Task
- reason() - Method in class org.elasticsearch.cluster.coordination.NodeRemovalClusterStateTaskExecutor.Task
- reason() - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Returns failure reason
- reason() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- reason() - Element in annotation interface org.elasticsearch.common.SuppressLoggerChecks
- reason() - Method in class org.elasticsearch.index.engine.Engine.NoOp
- reason() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- reason() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns snapshot failure reason;
null
if the snapshot succeeded. - REASON_AGGREGATION - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_AGGREGATION_GLOBAL - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_FIELD - Static variable in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- REASON_FIELD - Static variable in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- REASON_SEARCH_COUNT - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_SEARCH_MIN_SCORE - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_SEARCH_MULTI - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_SEARCH_POST_FILTER - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_SEARCH_TERMINATE_AFTER_COUNT - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- REASON_SEARCH_TOP_HITS - Static variable in class org.elasticsearch.search.profile.query.CollectorResult
- reassignTask(String, PersistentTasksCustomMetadata.Assignment) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Builder
-
Reassigns the task to another node
- rebalance(Decision, AllocationDecision, DiscoveryNode, int, List<NodeAllocationResult>) - Static method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Creates a decision for whether to move the shard to a different node to form a better cluster balance.
- RebalanceOnlyWhenActiveAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
Only allow rebalancing when all shards are active within the shard replication group.
- RebalanceOnlyWhenActiveAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.RebalanceOnlyWhenActiveAllocationDecider
- receiveBufferSize - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- receiveFileInfo(List<String>, List<Long>, List<String>, List<Long>, int, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- receiveFileInfo(List<String>, List<Long>, List<String>, List<Long>, int, ActionListener<Void>) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
Notifies the target of the files it is going to receive
- receiveFileInfo(List<String>, List<Long>, List<String>, List<Long>, int, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- ReceiveTimeoutTransportException - Exception in org.elasticsearch.transport
- ReceiveTimeoutTransportException(DiscoveryNode, String, String) - Constructor for exception org.elasticsearch.transport.ReceiveTimeoutTransportException
- ReceiveTimeoutTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.ReceiveTimeoutTransportException
- RECIPROCAL - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- Reconfigurator - Class in org.elasticsearch.cluster.coordination
-
Computes the optimal configuration of voting nodes in the cluster.
- Reconfigurator(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.coordination.Reconfigurator
- reconfigure(Set<DiscoveryNode>, Set<String>, DiscoveryNode, CoordinationMetadata.VotingConfiguration) - Method in class org.elasticsearch.cluster.coordination.Reconfigurator
-
Compute an optimal configuration for the cluster.
- reconnectToNodes(DiscoveryNodes, Runnable) - Method in class org.elasticsearch.cluster.NodeConnectionsService
- Recording(long, long) - Constructor for class org.elasticsearch.cluster.service.ClusterApplierRecordingService.Stats.Recording
- Recording(StreamInput) - Constructor for class org.elasticsearch.cluster.service.ClusterApplierRecordingService.Stats.Recording
- RECOVER_AFTER_DATA_NODES_SETTING - Static variable in class org.elasticsearch.gateway.GatewayService
- RECOVER_AFTER_MASTER_NODES_SETTING - Static variable in class org.elasticsearch.gateway.GatewayService
- RECOVER_AFTER_NODES_SETTING - Static variable in class org.elasticsearch.gateway.GatewayService
- RECOVER_AFTER_TIME_SETTING - Static variable in class org.elasticsearch.gateway.GatewayService
- recovered() - Method in class org.elasticsearch.indices.recovery.RecoveryState.FileDetail
-
number of bytes recovered for this file (so far).
- recoveredBytes() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
total number of bytes recovered so far, including both existing and reused
- recoveredBytesPercent() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
percent of bytes recovered out of total files bytes *to be* recovered
- recoveredFileCount() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
number of file that were recovered (excluding on ongoing files)
- recoveredFilesPercent() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
percent of recovered (i.e., not reused) files out of the total files to be recovered
- recoveredFromSnapshot() - Method in class org.elasticsearch.indices.recovery.RecoveryState.FileDetail
-
number of bytes recovered from this file (so far) from a snapshot.
- recoveredFromSnapshotBytes() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- recoveredOperations() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
-
returns the total number of translog operations recovered so far
- recoveredPercent() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- RecoverFilesRecoveryException - Exception in org.elasticsearch.indices.recovery
- RecoverFilesRecoveryException(StreamInput) - Constructor for exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
- RecoverFilesRecoveryException(ShardId, int, ByteSizeValue, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
- recoverFrom() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- recoverFrom(Index) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- recoverFromLocalShards(BiConsumer<String, MappingMetadata>, List<IndexShard>, ActionListener<Boolean>) - Method in class org.elasticsearch.index.shard.IndexShard
- recoverFromStore(ActionListener<Boolean>) - Method in class org.elasticsearch.index.shard.IndexShard
- recoverFromTranslog(Engine.TranslogRecoveryRunner, long) - Method in class org.elasticsearch.index.engine.Engine
-
Performs recovery from the transaction log up to
recoverUpToSeqNo
(inclusive). - recoverFromTranslog(Engine.TranslogRecoveryRunner, long) - Method in class org.elasticsearch.index.engine.InternalEngine
- recoverFromTranslog(Engine.TranslogRecoveryRunner, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- recoveries(RecoveryRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices recoveries
- recoveries(RecoveryRequest, ActionListener<RecoveryResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices recoveries
- RecoveriesCollection - Class in org.elasticsearch.indices.recovery
-
This class holds a collection of all on going recoveries on the current node (i.e., the node is the target node of those recoveries).
- RecoveriesCollection(Logger, ThreadPool) - Constructor for class org.elasticsearch.indices.recovery.RecoveriesCollection
- RecoveriesCollection.RecoveryRef - Class in org.elasticsearch.indices.recovery
-
a reference to
RecoveryTarget
, which implementsAutoCloseable
. - RECOVERING - Enum constant in enum class org.elasticsearch.index.shard.IndexShardState
- recoverLocallyUpToGlobalCheckpoint() - Method in class org.elasticsearch.index.shard.IndexShard
-
A best effort to bring up this shard to the global checkpoint using the local translog before performing a peer recovery.
- recoverToTarget(ActionListener<RecoveryResponse>) - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
-
performs the recovery from the local engine to the target
- recovery() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- recovery(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- Recovery - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- RECOVERY - Enum constant in enum class org.elasticsearch.transport.TransportRequestOptions.Type
- RECOVERY_SOURCE_NAME - Static variable in class org.elasticsearch.index.mapper.SourceFieldMapper
- RecoveryAction - Class in org.elasticsearch.action.admin.indices.recovery
-
Recovery information action
- RecoveryCleanFilesRequest - Class in org.elasticsearch.indices.recovery
- RecoveryCleanFilesRequest(long, long, ShardId, Store.MetadataSnapshot, int, long) - Constructor for class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- recoveryDiff(Store.MetadataSnapshot) - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns a diff between the two snapshots that can be used for recovery.
- RecoveryEngineException - Exception in org.elasticsearch.index.engine
- RecoveryEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.RecoveryEngineException
- RecoveryEngineException(ShardId, int, String, Throwable) - Constructor for exception org.elasticsearch.index.engine.RecoveryEngineException
- RecoveryFailedException - Exception in org.elasticsearch.indices.recovery
- RecoveryFailedException(StreamInput) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
- RecoveryFailedException(ShardId, DiscoveryNode, DiscoveryNode, String, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
- RecoveryFailedException(RecoveryState, String, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
- RecoveryFailedException(StartRecoveryRequest, String, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
- RecoveryFailedException(StartRecoveryRequest, Throwable) - Constructor for exception org.elasticsearch.indices.recovery.RecoveryFailedException
- RecoveryFileChunkRequest - Class in org.elasticsearch.indices.recovery
- RecoveryFileChunkRequest(long, long, ShardId, StoreFileMetadata, long, ReleasableBytesReference, boolean, int, long) - Constructor for class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- RecoveryFileChunkRequest(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- RecoveryFilesDetails() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- RecoveryFilesInfoRequest - Class in org.elasticsearch.indices.recovery
- RecoveryFilesInfoRequest(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryFilesInfoRequest
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryFilesInfoRequest
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- recoveryId() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- recoveryId() - Method in class org.elasticsearch.indices.recovery.ReestablishRecoveryRequest
- recoveryId() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- RecoveryPlannerService - Interface in org.elasticsearch.indices.recovery.plan
- RecoveryRef(RecoveryTarget) - Constructor for class org.elasticsearch.indices.recovery.RecoveriesCollection.RecoveryRef
-
Important:
AbstractRefCounted.tryIncRef()
should be *successfully* called on status before - RecoveryRequest - Class in org.elasticsearch.action.admin.indices.recovery
-
Request for recovery information
- RecoveryRequest() - Constructor for class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
-
Constructs a request for recovery information for all shards
- RecoveryRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
-
Constructs a request for recovery information for all shards for the given indices
- RecoveryRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
- RecoveryRequestBuilder - Class in org.elasticsearch.action.admin.indices.recovery
-
Recovery information request builder.
- RecoveryRequestBuilder(ElasticsearchClient, RecoveryAction) - Constructor for class org.elasticsearch.action.admin.indices.recovery.RecoveryRequestBuilder
-
Constructs a new recovery information request builder.
- RecoveryRequestTracker - Class in org.elasticsearch.indices.recovery
- RecoveryRequestTracker() - Constructor for class org.elasticsearch.indices.recovery.RecoveryRequestTracker
- RecoveryResponse - Class in org.elasticsearch.action.admin.indices.recovery
-
Information regarding the recovery state of indices and their associated shards.
- RecoveryResponse - Class in org.elasticsearch.indices.recovery
- RecoveryResponse(int, int, int, Map<String, List<RecoveryState>>, List<DefaultShardOperationFailedException>) - Constructor for class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
-
Constructs recovery information for a collection of indices and associated shards.
- RecoveryResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
- RecoverySettings - Class in org.elasticsearch.indices.recovery
- RecoverySettings(Settings, ClusterSettings) - Constructor for class org.elasticsearch.indices.recovery.RecoverySettings
- RecoverySnapshotFileRequest - Class in org.elasticsearch.indices.recovery
- RecoverySnapshotFileRequest(long, long, ShardId, String, IndexId, BlobStoreIndexShardSnapshot.FileInfo) - Constructor for class org.elasticsearch.indices.recovery.RecoverySnapshotFileRequest
- RecoverySnapshotFileRequest(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoverySnapshotFileRequest
- recoverySource() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns recovery source for the given shard.
- RecoverySource - Class in org.elasticsearch.cluster.routing
-
Represents the recovery source of a shard.
- RecoverySource() - Constructor for class org.elasticsearch.cluster.routing.RecoverySource
- RecoverySource.EmptyStoreRecoverySource - Class in org.elasticsearch.cluster.routing
-
Recovery from a fresh copy
- RecoverySource.ExistingStoreRecoverySource - Class in org.elasticsearch.cluster.routing
-
Recovery from an existing on-disk store
- RecoverySource.LocalShardsRecoverySource - Class in org.elasticsearch.cluster.routing
-
recovery from other shards on same node (shrink index action)
- RecoverySource.PeerRecoverySource - Class in org.elasticsearch.cluster.routing
-
peer recovery from a primary shard
- RecoverySource.SnapshotRecoverySource - Class in org.elasticsearch.cluster.routing
-
recovery from a snapshot
- RecoverySource.Type - Enum Class in org.elasticsearch.cluster.routing
- RecoverySourceHandler - Class in org.elasticsearch.indices.recovery
-
RecoverySourceHandler handles the three phases of shard recovery, which is everything relating to copying the segment files as well as sending translog operations across the wire once the segments have been copied.
- RecoverySourceHandler(IndexShard, RecoveryTargetHandler, ThreadPool, StartRecoveryRequest, int, int, int, int, boolean, RecoveryPlannerService) - Constructor for class org.elasticsearch.indices.recovery.RecoverySourceHandler
- recoveryState - Variable in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- recoveryState() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the current
RecoveryState
if this shard is recovering or has been recovering. - recoveryState() - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.Shard
-
Returns the recovery state associated with this shard.
- RecoveryState - Class in org.elasticsearch.indices.recovery
-
Keeps track of state related to shard recovery.
- RecoveryState(ShardRouting, DiscoveryNode, DiscoveryNode) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState
- RecoveryState(ShardRouting, DiscoveryNode, DiscoveryNode, RecoveryState.Index) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState
- RecoveryState(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState
- RecoveryState.FileDetail - Class in org.elasticsearch.indices.recovery
- RecoveryState.Index - Class in org.elasticsearch.indices.recovery
- RecoveryState.RecoveryFilesDetails - Class in org.elasticsearch.indices.recovery
- RecoveryState.Stage - Enum Class in org.elasticsearch.indices.recovery
- RecoveryState.Timer - Class in org.elasticsearch.indices.recovery
- RecoveryState.Translog - Class in org.elasticsearch.indices.recovery
- RecoveryState.VerifyIndex - Class in org.elasticsearch.indices.recovery
- recoveryStats - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- recoveryStats() - Method in class org.elasticsearch.index.shard.IndexShard
-
returns stats about ongoing recoveries, both source and target
- RecoveryStats - Class in org.elasticsearch.index.recovery
-
Recovery related statistics, starting at the shard level and allowing aggregation to indices and node level
- RecoveryStats() - Constructor for class org.elasticsearch.index.recovery.RecoveryStats
- RecoveryStats(StreamInput) - Constructor for class org.elasticsearch.index.recovery.RecoveryStats
- RecoveryTarget - Class in org.elasticsearch.indices.recovery
-
Represents a recovery where the current node is the target node of the recovery.
- RecoveryTarget(IndexShard, DiscoveryNode, SnapshotFilesProvider, Releasable, PeerRecoveryTargetService.RecoveryListener) - Constructor for class org.elasticsearch.indices.recovery.RecoveryTarget
-
Creates a new recovery target object that represents a recovery to the provided shard.
- RecoveryTargetHandler - Interface in org.elasticsearch.indices.recovery
- RecoveryTranslogOperationsRequest - Class in org.elasticsearch.indices.recovery
- RecoveryTransportRequest - Class in org.elasticsearch.indices.recovery
- recToSphericalMercator(Rectangle) - Static method in class org.elasticsearch.common.geo.SphericalMercatorUtils
-
Transforms WGS84 rectangle to a Spherical mercator rectangle
- RECURSIVE - Enum constant in enum class org.elasticsearch.common.geo.SpatialStrategy
- recursiveBinding() - Method in class org.elasticsearch.common.inject.internal.Errors
- recursiveImplementationType() - Method in class org.elasticsearch.common.inject.internal.Errors
- recursiveProviderType() - Method in class org.elasticsearch.common.inject.internal.Errors
- recycle(T) - Method in class org.elasticsearch.common.recycler.AbstractRecyclerC
- recycle(T) - Method in interface org.elasticsearch.common.recycler.Recycler.C
-
Recycle the data.
- Recycler<T> - Interface in org.elasticsearch.common.recycler
-
A recycled object, note, implementations should support calling obtain and then recycle on different threads.
- Recycler.C<T> - Interface in org.elasticsearch.common.recycler
- Recycler.Factory<T> - Interface in org.elasticsearch.common.recycler
- Recycler.V<T> - Interface in org.elasticsearch.common.recycler
- Recyclers - Enum Class in org.elasticsearch.common.recycler
- RecyclingBytesStreamOutput - Class in org.elasticsearch.common.bytes
-
An in-memory
StreamOutput
which first fills the givenbyte[]
and then allocates more space from the givenBigArrays
if needed. - RecyclingBytesStreamOutput(byte[], BigArrays) - Constructor for class org.elasticsearch.common.bytes.RecyclingBytesStreamOutput
- RED - Enum constant in enum class org.elasticsearch.cluster.health.ClusterHealthStatus
- reduce() - Method in class org.elasticsearch.action.search.QueryPhaseResultConsumer
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.DoubleTerms
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Reduces the given aggregations to a single one and returns it.
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalAvg
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalCardinality
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalMax
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalMedianAbsoluteDeviation
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalMin
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalScriptedMetric
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalSum
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTopHits
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalValueCount
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.metrics.InternalWeightedAvg
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalBucketMetricValue
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalExtendedStatsBucket
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- reduce(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalStatsBucket
- reduce(List<InternalAggregations>, InternalAggregation.ReduceContext) - Static method in class org.elasticsearch.search.aggregations.InternalAggregations
-
Version of
InternalAggregations.reduce(List, ReduceContext, Function)
for nodes inside the aggregation tree. - reduce(List<InternalAggregations>, InternalAggregation.ReduceContext, Function<List<InternalAggregation>, InternalAggregations>) - Static method in class org.elasticsearch.search.aggregations.InternalAggregations
-
Reduces the given list of aggregations as well as the top-level pipeline aggregators extracted from the first
InternalAggregations
object found in the list. - reduce(List<Suggest.Suggestion<CompletionSuggestion.Entry>>) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- reduce(List<Suggest.Suggestion<T>>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
-
Merges the result of another suggestion into this suggestion.
- reduce(List<T>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- reduce(Map<String, List<Suggest.Suggestion<?>>>) - Static method in class org.elasticsearch.search.suggest.Suggest
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregator
- reduce(InternalAggregation, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.pipeline.SiblingPipelineAggregator
- REDUCE - Enum constant in enum class org.elasticsearch.search.profile.aggregation.AggregationTimingType
- reduceBucket(List<B>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange
- reduceBucket(List<B>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- reduceBucket(List<B>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
- reduceBucket(List<B>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- reduceBucket(List<B>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
-
Reduce a list of same-keyed buckets (from multiple shards) to a single bucket.
- reduceBucket(List<InternalAdjacencyMatrix.InternalBucket>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix
- reduceBucket(List<InternalComposite.InternalBucket>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite
- reduceBucket(List<InternalFilters.InternalBucket>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters
- reduceBucket(List<InternalGeoGridBucket>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- reduceBucket(List<InternalAutoDateHistogram.Bucket>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram
- reduceBucket(List<InternalDateHistogram.Bucket>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram
-
Reduce a list of same-keyed buckets (from multiple shards) to a single bucket.
- reduceBucket(List<InternalHistogram.Bucket>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram
- reduceBucket(List<InternalVariableWidthHistogram.Bucket>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- reduceBucket(List<InternalBinaryRange.Bucket>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange
- reduceBuckets(List<InternalAggregation>, InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram
- reduced() - Method in class org.elasticsearch.search.aggregations.DelayedBucket
-
The reduced bucket.
- reducedType() - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
- reducedType() - Method in class org.elasticsearch.index.fielddata.fieldcomparator.DoubleValuesComparatorSource
- reducedType() - Method in class org.elasticsearch.index.fielddata.fieldcomparator.FloatValuesComparatorSource
- reducedType() - Method in class org.elasticsearch.index.fielddata.fieldcomparator.LongValuesComparatorSource
- reducedType() - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- reduceOrder - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- reducePipelines(InternalAggregation, InternalAggregation.ReduceContext, PipelineAggregator.PipelineTree) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
-
Amulti-bucket agg needs to first reduce the buckets and *their* pipelines before allowing sibling pipelines to materialize.
- reducePipelines(InternalAggregation, InternalAggregation.ReduceContext, PipelineAggregator.PipelineTree) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Creates the output from all pipeline aggs that this aggregation is associated with.
- reducePipelines(InternalAggregation, InternalAggregation.ReduceContext, PipelineAggregator.PipelineTree) - Method in class org.elasticsearch.search.aggregations.InternalMultiBucketAggregation
-
A multi-bucket agg needs to first reduce the buckets and *their* pipelines before allowing sibling pipelines to materialize.
- reduceScript() - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
-
Get the
reduce
script. - reduceScript(Script) - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
-
Set the
reduce
script. - ReduceScript(Map<String, Object>, List<Object>) - Constructor for class org.elasticsearch.script.ScriptedMetricAggContexts.ReduceScript
- ReduceSearchPhaseException - Exception in org.elasticsearch.action.search
-
A failure during a reduce phase (when receiving results from several shards, and reducing them into one or more results and possible actions).
- ReduceSearchPhaseException(String, String, Throwable, ShardSearchFailure[]) - Constructor for exception org.elasticsearch.action.search.ReduceSearchPhaseException
- ReduceSearchPhaseException(StreamInput) - Constructor for exception org.elasticsearch.action.search.ReduceSearchPhaseException
- reduceToStoredPrecision(double) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
-
This method reinterprets a double precision value based on the maximum precision of the stored number field.
- reduceToStoredPrecisionFunction() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
Returns a function from the mapper that adjusts a double value to the value it would have been had it been parsed by that mapper and then cast up to a double.
- REESTABLISH_RECOVERY - Static variable in class org.elasticsearch.indices.recovery.PeerRecoverySourceService.Actions
- reestablishRecovery(StartRecoveryRequest, String, TimeValue) - Method in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
- ReestablishRecoveryRequest - Class in org.elasticsearch.indices.recovery
-
Represents a request for starting a peer recovery.
- ReestablishRecoveryRequest(long, ShardId, String) - Constructor for class org.elasticsearch.indices.recovery.ReestablishRecoveryRequest
- ReestablishRecoveryRequest(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.ReestablishRecoveryRequest
- refCount() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- refCount() - Method in class org.elasticsearch.index.store.Store
-
Returns the current reference count.
- referencing(Writeable.Reader<T>, StreamInput) - Static method in class org.elasticsearch.common.io.stream.DelayableWriteable
- referencing(T) - Static method in class org.elasticsearch.common.io.stream.DelayableWriteable
-
Build a DelayableWriteable that wraps an existing object but is serialized so that deserializing it can be delayed.
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.miscellaneous.DisableGraphAttributeImpl
- reflectWith(AttributeReflector) - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- refresh - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- refresh() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- refresh() - Method in class org.elasticsearch.action.get.GetRequest
- refresh() - Method in class org.elasticsearch.action.get.MultiGetRequest
- refresh() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- refresh() - Method in class org.elasticsearch.common.cache.Cache
-
Force any outstanding size-based and time-based evictions to occur
- refresh() - Method in class org.elasticsearch.common.util.SingleObjectCache
-
Returns a new instance to cache
- refresh(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- refresh(boolean) - Method in class org.elasticsearch.action.get.GetRequest
-
Should a refresh be executed before this get operation causing the operation to return the latest value.
- refresh(boolean) - Method in class org.elasticsearch.action.get.MultiGetRequest
- refresh(boolean) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- refresh(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Call refresh on the indexes we've written to after the request ends?
- refresh(Input, Runnable, BooleanSupplier, ActionListener<Value>) - Method in class org.elasticsearch.common.util.CancellableSingleObjectCache
-
Compute a new value for the cache.
- refresh(String) - Method in class org.elasticsearch.index.engine.Engine
-
Synchronously refreshes the engine for new search operations to reflect the latest changes.
- refresh(String) - Method in class org.elasticsearch.index.engine.InternalEngine
- refresh(String) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- refresh(String) - Method in class org.elasticsearch.index.shard.IndexShard
-
Writes all indexing changes to disk and opens a new searcher reflecting all changes.
- refresh(RefreshRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly refresh one or more indices (making the content indexed since the last refresh searchable).
- refresh(RefreshRequest, ActionListener<RefreshResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly refresh one or more indices (making the content indexed since the last refresh searchable).
- Refresh - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- REFRESH - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.monitor.fs.FsHealthService
- REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.monitor.fs.FsService
- REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.monitor.jvm.JvmGcMonitorService
- REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.monitor.jvm.JvmService
- REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.monitor.os.OsService
- REFRESH_INTERVAL_SETTING - Static variable in class org.elasticsearch.monitor.process.ProcessService
- REFRESH_REPO_UUID_ON_RESTORE_SETTING - Static variable in class org.elasticsearch.snapshots.RestoreService
- RefreshAction - Class in org.elasticsearch.action.admin.indices.refresh
- RefreshFailedEngineException - Exception in org.elasticsearch.index.engine
- RefreshFailedEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.RefreshFailedEngineException
- RefreshFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.RefreshFailedEngineException
- refreshIfNeeded(String, long) - Method in class org.elasticsearch.index.engine.InternalEngine
-
Refresh this engine **internally** iff the requesting seq_no is greater than the last refreshed checkpoint.
- refreshInterval() - Method in class org.elasticsearch.monitor.process.ProcessInfo
- RefreshListeners - Class in org.elasticsearch.index.shard
-
Allows for the registration of listeners that are called when a change becomes visible for search.
- RefreshListeners(IntSupplier, Runnable, Logger, ThreadContext, MeanMetric) - Constructor for class org.elasticsearch.index.shard.RefreshListeners
- refreshNeeded() - Method in class org.elasticsearch.index.engine.Engine
- refreshNeeded() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- refreshNeeded() - Method in class org.elasticsearch.index.shard.RefreshListeners
-
Returns true if there are pending listeners.
- refreshRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a refresh indices request.
- RefreshRequest - Class in org.elasticsearch.action.admin.indices.refresh
-
A refresh request making all operations performed since the last refresh available for search.
- RefreshRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
- RefreshRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.refresh.RefreshRequest
- RefreshRequestBuilder - Class in org.elasticsearch.action.admin.indices.refresh
-
A refresh request making all operations performed since the last refresh available for search.
- RefreshRequestBuilder(ElasticsearchClient, RefreshAction) - Constructor for class org.elasticsearch.action.admin.indices.refresh.RefreshRequestBuilder
- RefreshResponse - Class in org.elasticsearch.action.admin.indices.refresh
-
The response of a refresh action.
- RefreshResponse(int, int, int, List<DefaultShardOperationFailedException>) - Constructor for class org.elasticsearch.action.admin.indices.refresh.RefreshResponse
- refreshStats() - Method in class org.elasticsearch.index.shard.IndexShard
- RefreshStats - Class in org.elasticsearch.index.refresh
- RefreshStats() - Constructor for class org.elasticsearch.index.refresh.RefreshStats
- RefreshStats(long, long, long, long, int) - Constructor for class org.elasticsearch.index.refresh.RefreshStats
- RefreshStats(StreamInput) - Constructor for class org.elasticsearch.index.refresh.RefreshStats
- REG - Enum constant in enum class org.elasticsearch.transport.TransportRequestOptions.Type
- regex - Variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- regex() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the regex for this suggestion
- regex(String) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Sets a regular expression pattern for prefixes to provide completions for.
- regex(String) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- regex(String, RegexOptions) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Same as
CompletionSuggestionBuilder.regex(String)
with full regular expression options seeRegexOptions.Builder
- Regex - Class in org.elasticsearch.common.regex
- Regex() - Constructor for class org.elasticsearch.common.regex.Regex
- REGEX - Enum constant in enum class org.elasticsearch.index.mapper.DynamicTemplate.MatchType
- REGEX_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- regexOptions - Variable in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- RegexOptions - Class in org.elasticsearch.search.suggest.completion
-
Regular expression options for completion suggester
- RegexOptions.Builder - Class in org.elasticsearch.search.suggest.completion
-
Options for regular expression queries
- RegExp - Class in org.elasticsearch.common.lucene
-
Simple wrapper for
RegExp
that avoids throwingStackOverflowError
s when working with regular expressions as this will crash an Elasticsearch node. - RegExp(String) - Constructor for class org.elasticsearch.common.lucene.RegExp
- RegExp(String, int) - Constructor for class org.elasticsearch.common.lucene.RegExp
- RegExp(String, int, int) - Constructor for class org.elasticsearch.common.lucene.RegExp
- RegexpFlag - Enum Class in org.elasticsearch.index.query
-
Regular expression syntax flags.
- regexpQuery(Object, int, int) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
-
Completion prefix regular expression query
- regexpQuery(String, int, int, int, MultiTermQuery.RewriteMethod, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- regexpQuery(String, int, int, int, MultiTermQuery.RewriteMethod, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldType
- regexpQuery(String, int, int, int, MultiTermQuery.RewriteMethod, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- regexpQuery(String, int, int, int, MultiTermQuery.RewriteMethod, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- regexpQuery(String, int, int, int, MultiTermQuery.RewriteMethod, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.StringFieldType
- regexpQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing terms with a specified regular expression.
- RegexpQueryBuilder - Class in org.elasticsearch.index.query
-
A Query that does fuzzy matching for a specific value.
- RegexpQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.RegexpQueryBuilder
-
Constructs a new regex query.
- RegexpQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.RegexpQueryBuilder
-
Read from a stream.
- register(String, String, TaskAwareRequest) - Method in class org.elasticsearch.tasks.TaskManager
-
Registers a task without parent task
- register(String, T) - Method in class org.elasticsearch.common.NamedRegistry
- register(MembersInjector<? super I>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Registers a members injector for type
I
. - register(InjectionListener<? super I>) - Method in interface org.elasticsearch.common.inject.spi.TypeEncounter
-
Registers an injection listener for type
I
. - register(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- register(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- register(ValuesSourceRegistry.RegistryKey<T>, List<ValuesSourceType>, T, boolean) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry.Builder
-
Register a ValuesSource to Aggregator mapping.
- register(ValuesSourceRegistry.RegistryKey<T>, ValuesSourceType, T, boolean) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry.Builder
-
Register a ValuesSource to Aggregator mapping.
- register(T, String) - Method in class org.elasticsearch.common.xcontent.ParseFieldRegistry
-
Register a parser.
- register(T, ParseField) - Method in class org.elasticsearch.common.xcontent.ParseFieldRegistry
-
Register a parser.
- REGISTER_CONNECTION_LISTENER_SETTING - Static variable in class org.elasticsearch.discovery.zen.FaultDetection
- registerAggregationUsage(String) - Method in class org.elasticsearch.search.aggregations.support.AggregationUsageService.Builder
- registerAggregationUsage(String, String) - Method in class org.elasticsearch.search.aggregations.support.AggregationUsageService.Builder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregatorFactory
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregatorFactory
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregatorFactory
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregatorFactory
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregatorFactory
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceRangeAggregatorFactory
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregatorFactory
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.PercentileRanksAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
- registerAggregators(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- registerAsDeprecatedHandler(RestRequest.Method, String, RestHandler, String) - Method in class org.elasticsearch.rest.RestController
-
Registers a REST handler to be executed when the provided
method
andpath
match the request. - registerAsDeprecatedHandler(RestRequest.Method, String, RestHandler, String, Level) - Method in class org.elasticsearch.rest.RestController
-
Registers a REST handler to be executed when the provided
method
andpath
match the request. - registerAsReplacedHandler(RestRequest.Method, String, RestHandler, RestRequest.Method, String) - Method in class org.elasticsearch.rest.RestController
-
Registers a REST handler to be executed when the provided
method
andpath
match the request, or when provided withreplacedMethod
andreplacedPath
. - registerAsyncAction(BiConsumer<Client, ActionListener<?>>) - Method in class org.elasticsearch.index.query.QueryRewriteContext
-
Registers an async action that must be executed before the next rewrite round in order to make progress.
- registerAsyncAction(BiConsumer<Client, ActionListener<?>>) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- registerBreaker(Consumer<Long>) - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
-
Registers a circuit breaker with the datastructure.
- registerChildConnection(long, Transport.Connection) - Method in class org.elasticsearch.tasks.TaskManager
-
Register a connection on which a child task will execute on the target connection.
- registerClusterSettingsListeners(ScriptService, ClusterSettings) - Method in class org.elasticsearch.script.ScriptModule
-
Allow the script service to register any settings update handlers on the cluster settings
- registerConnectionListener - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- registerErrorListener() - Static method in class org.elasticsearch.common.logging.LogConfigurator
-
Registers a listener for status logger errors.
- registerHandler(RestHandler) - Method in class org.elasticsearch.rest.RestController
-
Registers a REST handler with the controller.
- registerHandler(RestHandler.Route, RestHandler) - Method in class org.elasticsearch.rest.RestController
- registerHandler(RestRequest.Method, String, RestHandler) - Method in class org.elasticsearch.rest.RestController
-
Registers a REST handler to be executed when one of the provided methods and path match the request.
- registerInternalRepository(String, String) - Method in class org.elasticsearch.repositories.RepositoriesService
- registerProxyAction(TransportService, String, boolean, Writeable.Reader<? extends TransportResponse>) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Registers a proxy request handler that allows to forward requests for the given action to another node.
- registerProxyActionWithDynamicResponseType(TransportService, String, boolean, Function<TransportRequest, Writeable.Reader<? extends TransportResponse>>) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Registers a proxy request handler that allows to forward requests for the given action to another node.
- registerRepository(PutRepositoryRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.repositories.RepositoriesService
-
Registers new repository in the cluster
- registerRequestHandler(String, String, boolean, boolean, Writeable.Reader<Request>, TransportRequestHandler<Request>) - Method in class org.elasticsearch.transport.TransportService
-
Registers a new request handler
- registerRequestHandler(String, String, Writeable.Reader<Request>, TransportRequestHandler<Request>) - Method in class org.elasticsearch.transport.TransportService
-
Registers a new request handler
- registerRequestHandler(RequestHandlerRegistry<Request>) - Method in interface org.elasticsearch.transport.Transport
-
Registers a new request handler
- registerRequestHandler(TransportService, SearchService) - Static method in class org.elasticsearch.action.search.SearchTransportService
- registerSmoothingModels(List<NamedWriteableRegistry.Entry>) - Static method in class org.elasticsearch.search.SearchModule
- registerUsage(String) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry.Builder
- registerUsage(String, ValuesSourceType) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry.Builder
- registerUsage(ValuesSourceRegistry.Builder) - Static method in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.metrics.PercentileRanksAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
- REGISTRY_KEY - Static variable in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- RegistryKey(String, Class<T>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry.RegistryKey
- ReindexAction - Class in org.elasticsearch.index.reindex
- ReindexRequest - Class in org.elasticsearch.index.reindex
-
Request to reindex some documents from one index to another.
- ReindexRequest() - Constructor for class org.elasticsearch.index.reindex.ReindexRequest
- ReindexRequest(StreamInput) - Constructor for class org.elasticsearch.index.reindex.ReindexRequest
- ReindexRequestBuilder - Class in org.elasticsearch.index.reindex
- ReindexRequestBuilder(ElasticsearchClient, ActionType<BulkByScrollResponse>) - Constructor for class org.elasticsearch.index.reindex.ReindexRequestBuilder
- REINITIALIZED - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
When a shard moves from started back to initializing.
- reinitializeReplicaShard() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Reinitializes a replica shard, giving it a fresh allocation id
- RejectAwareActionListener<T> - Interface in org.elasticsearch.index.reindex
- rejected() - Method in class org.elasticsearch.common.util.concurrent.EsRejectedExecutionHandler
-
The number of rejected executions.
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.elasticsearch.common.util.concurrent.EsAbortPolicy
- rejoin(String) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- RejoinClusterRequest(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.ZenDiscovery.RejoinClusterRequest
- relation - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- relation - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- relation() - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- relation() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- relation(String) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
- relation(ShapeRelation) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Sets the relation of query shape and indexed shape.
- relation(ShapeRelation) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Sets the relation of query shape and indexed shape.
- RELATION_FIELD - Static variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- RelativeByteSizeValue - Class in org.elasticsearch.common.unit
-
A byte size value that allows specification using either of: 1.
- RelativeByteSizeValue(ByteSizeValue) - Constructor for class org.elasticsearch.common.unit.RelativeByteSizeValue
- RelativeByteSizeValue(RatioValue) - Constructor for class org.elasticsearch.common.unit.RelativeByteSizeValue
- relativeTimeInMillis() - Method in class org.elasticsearch.threadpool.ThreadPool
-
Returns a value of milliseconds that may be used for relative time calculations.
- relativeTimeInNanos() - Method in class org.elasticsearch.threadpool.ThreadPool
-
Returns a value of nanoseconds that may be used for relative time calculations.
- relativeTimeSupplier - Variable in class org.elasticsearch.ingest.Processor.Parameters
- ReleasableBytesReference - Class in org.elasticsearch.common.bytes
-
An extension to
BytesReference
that requires releasing its content. - ReleasableBytesReference(BytesReference, AbstractRefCounted) - Constructor for class org.elasticsearch.common.bytes.ReleasableBytesReference
- ReleasableBytesReference(BytesReference, Releasable) - Constructor for class org.elasticsearch.common.bytes.ReleasableBytesReference
- ReleasableBytesStreamOutput - Class in org.elasticsearch.common.io.stream
-
An bytes stream output that allows providing a
BigArrays
instance expecting it to require releasing its content (BytesStreamOutput.bytes()
) once done. - ReleasableBytesStreamOutput(int, BigArrays) - Constructor for class org.elasticsearch.common.io.stream.ReleasableBytesStreamOutput
- ReleasableBytesStreamOutput(BigArrays) - Constructor for class org.elasticsearch.common.io.stream.ReleasableBytesStreamOutput
- ReleasableLock - Class in org.elasticsearch.common.util.concurrent
-
Releasable lock used inside of Engine implementations
- ReleasableLock(Lock) - Constructor for class org.elasticsearch.common.util.concurrent.ReleasableLock
- releasables - Variable in class org.elasticsearch.search.internal.SearchContext
- release() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- release() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- release() - Method in class org.elasticsearch.http.HttpPipelinedRequest
- release() - Method in interface org.elasticsearch.http.HttpRequest
-
Release any resources associated with this request.
- releaseAggs() - Method in class org.elasticsearch.search.query.QuerySearchResult
- releaseAndCopy() - Method in class org.elasticsearch.http.HttpPipelinedRequest
- releaseAndCopy() - Method in interface org.elasticsearch.http.HttpRequest
-
If this instances uses any pooled resources, creates a copy of this instance that does not use any pooled resources and releases any resources associated with this instance.
- releaseOutputBuffer() - Method in class org.elasticsearch.rest.AbstractRestChannel
- releaseOutputBuffer() - Method in interface org.elasticsearch.rest.RestChannel
-
Releases the current output buffer for this channel.
- reload(String, Settings, Map<String, TokenizerFactory>, Map<String, CharFilterFactory>, Map<String, TokenFilterFactory>) - Method in class org.elasticsearch.index.analysis.ReloadableCustomAnalyzer
- reload(Settings) - Method in interface org.elasticsearch.plugins.ReloadablePlugin
-
Called to trigger the rebuilt of the plugin's internal members.
- RELOAD_INTERVAL_HIGH - Static variable in class org.elasticsearch.watcher.ResourceWatcherService
- RELOAD_INTERVAL_LOW - Static variable in class org.elasticsearch.watcher.ResourceWatcherService
- RELOAD_INTERVAL_MEDIUM - Static variable in class org.elasticsearch.watcher.ResourceWatcherService
- ReloadableCustomAnalyzer - Class in org.elasticsearch.index.analysis
- ReloadablePlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
s that can be reloaded. - reloadException() - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse.NodeResponse
- reloadSearchAnalyzers(AnalysisRegistry) - Method in class org.elasticsearch.index.mapper.MapperService
- relocate(String, long) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Relocate the shard to another node.
- relocated(String, BiConsumer<ReplicationTracker.PrimaryContext, ActionListener<Void>>, ActionListener<Void>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Completes the relocation.
- relocateShard(ShardRouting, String, long, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Relocate a shard to another node, adding the target initializing shard as well as assigning it.
- relocating() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Returns
true
iff the this shard is currently relocating to another node. - RELOCATING - Enum constant in enum class org.elasticsearch.cluster.routing.ShardRoutingState
-
The shard is in the process being relocated.
- relocatingNodeId() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The relocating node id the shard is either relocating to or relocating from.
- relocationCompleted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.IndexMetadataUpdater
- relocationCompleted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- relocationCompleted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- relocationCompleted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- relocationCompleted(ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called on relocation source when relocation completes after relocation target is started.
- relocationSourceRemoved(ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- relocationSourceRemoved(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- relocationSourceRemoved(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- relocationSourceRemoved(ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called on replica relocation target when replica relocation source fails.
- relocationStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- relocationStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- relocationStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- relocationStarted(ShardRouting, ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when relocation of a started shard is initiated.
- remaining() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- remaining() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
Return the number of shards remaining in this
ShardsIterator
- remaining() - Method in class org.elasticsearch.common.util.PlainIterator
- remainingCapacity() - Method in class org.elasticsearch.common.collect.EvictingQueue
- remainingCapacity() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- remainingNodesClusterState(ClusterState, DiscoveryNodes.Builder) - Method in class org.elasticsearch.cluster.coordination.NodeRemovalClusterStateTaskExecutor
- REMOTE_CLUSTER_CLIENT_ROLE - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeRole
- REMOTE_CLUSTER_CLIENT_ROLE_VERSION - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
The version that
DiscoveryNodeRole.REMOTE_CLUSTER_CLIENT_ROLE
is introduced. - REMOTE_CLUSTER_COMPRESS - Static variable in class org.elasticsearch.transport.RemoteClusterService
- REMOTE_CLUSTER_COMPRESSION_SCHEME - Static variable in class org.elasticsearch.transport.RemoteClusterService
- REMOTE_CLUSTER_INDEX_SEPARATOR - Static variable in class org.elasticsearch.transport.RemoteClusterAware
- REMOTE_CLUSTER_PING_SCHEDULE - Static variable in class org.elasticsearch.transport.RemoteClusterService
- REMOTE_CLUSTER_SEEDS - Static variable in class org.elasticsearch.transport.SniffConnectionStrategy
-
A list of initial seed nodes to discover eligible nodes from the remote cluster
- REMOTE_CLUSTER_SKIP_UNAVAILABLE - Static variable in class org.elasticsearch.transport.RemoteClusterService
- REMOTE_CLUSTERS_PROXY - Static variable in class org.elasticsearch.transport.SniffConnectionStrategy
-
A proxy address for the remote cluster.
- REMOTE_CONNECTION_MODE - Static variable in class org.elasticsearch.transport.RemoteConnectionStrategy
- REMOTE_CONNECTIONS_PER_CLUSTER - Static variable in class org.elasticsearch.transport.SniffConnectionStrategy
-
The maximum number of connections that will be established to a remote cluster.
- REMOTE_INITIAL_CONNECTION_TIMEOUT_SETTING - Static variable in class org.elasticsearch.transport.RemoteClusterService
-
The initial connect timeout for remote cluster connections
- REMOTE_MAX_PENDING_CONNECTION_LISTENERS - Static variable in class org.elasticsearch.transport.RemoteConnectionStrategy
- REMOTE_NODE_ATTRIBUTE - Static variable in class org.elasticsearch.transport.RemoteClusterService
-
The name of a node attribute to select nodes that should be connected to in the remote cluster.
- REMOTE_NODE_CONNECTIONS - Static variable in class org.elasticsearch.transport.SniffConnectionStrategy
-
The maximum number of node connections that will be established to a remote cluster.
- REMOTE_SOCKET_CONNECTIONS - Static variable in class org.elasticsearch.transport.ProxyConnectionStrategy
-
The maximum number of socket connections that will be established to a remote cluster.
- remoteAddress() - Method in class org.elasticsearch.transport.TransportMessage
- remoteAddress(TransportAddress) - Method in class org.elasticsearch.transport.TransportMessage
- RemoteClusterAware - Class in org.elasticsearch.transport
-
Base class for all services and components that need up-to-date information about the registered remote clusters
- RemoteClusterAware(Settings) - Constructor for class org.elasticsearch.transport.RemoteClusterAware
-
Creates a new
RemoteClusterAware
instance - RemoteClusterAwareRequest - Interface in org.elasticsearch.transport
- RemoteClusterService - Class in org.elasticsearch.transport
-
Basic service for accessing remote clusters via gateway nodes
- RemoteConnectionInfo - Class in org.elasticsearch.transport
-
This class encapsulates all remote cluster information to be rendered on
_remote/info
requests. - RemoteConnectionInfo(String, RemoteConnectionInfo.ModeInfo, TimeValue, boolean) - Constructor for class org.elasticsearch.transport.RemoteConnectionInfo
- RemoteConnectionInfo(StreamInput) - Constructor for class org.elasticsearch.transport.RemoteConnectionInfo
- RemoteConnectionInfo.ModeInfo - Interface in org.elasticsearch.transport
- RemoteConnectionManager - Class in org.elasticsearch.transport
- RemoteConnectionStrategy - Class in org.elasticsearch.transport
- RemoteInfo - Class in org.elasticsearch.index.reindex
- RemoteInfo(String, String, int, String, BytesReference, String, String, Map<String, String>, TimeValue, TimeValue) - Constructor for class org.elasticsearch.index.reindex.RemoteInfo
- RemoteInfo(StreamInput) - Constructor for class org.elasticsearch.index.reindex.RemoteInfo
-
Read from a stream.
- RemoteInfoAction - Class in org.elasticsearch.action.admin.cluster.remote
- RemoteInfoAction() - Constructor for class org.elasticsearch.action.admin.cluster.remote.RemoteInfoAction
- RemoteInfoRequest - Class in org.elasticsearch.action.admin.cluster.remote
- RemoteInfoRequest() - Constructor for class org.elasticsearch.action.admin.cluster.remote.RemoteInfoRequest
- RemoteInfoResponse - Class in org.elasticsearch.action.admin.cluster.remote
- RemoteInfoResponse(Collection<RemoteConnectionInfo>) - Constructor for class org.elasticsearch.action.admin.cluster.remote.RemoteInfoResponse
- RemoteRecoveryTargetHandler - Class in org.elasticsearch.indices.recovery
- RemoteRecoveryTargetHandler(long, ShardId, TransportService, DiscoveryNode, RecoverySettings, Consumer<Long>) - Constructor for class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- remoteShardFailed(ShardId, String, long, boolean, String, Exception, ActionListener<Void>) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
-
Send a shard failed request to the master node to update the cluster state with the failure of a shard on another node.
- RemoteTransportException - Exception in org.elasticsearch.transport
-
A remote exception for an action.
- RemoteTransportException(String, Throwable) - Constructor for exception org.elasticsearch.transport.RemoteTransportException
- RemoteTransportException(String, TransportAddress, String, Throwable) - Constructor for exception org.elasticsearch.transport.RemoteTransportException
- RemoteTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.RemoteTransportException
- removalListener(RemovalListener<K, V>) - Method in class org.elasticsearch.common.cache.CacheBuilder
- RemovalListener<K,
V> - Interface in org.elasticsearch.common.cache - RemovalNotification<K,
V> - Class in org.elasticsearch.common.cache - RemovalNotification(K, V, RemovalNotification.RemovalReason) - Constructor for class org.elasticsearch.common.cache.RemovalNotification
- RemovalNotification.RemovalReason - Enum Class in org.elasticsearch.common.cache
- remove() - Static method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Build a new
AliasAction
to remove aliases. - remove() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
-
Unsupported operation, just there for the interface.
- remove() - Method in class org.elasticsearch.common.collect.EvictingQueue
- remove() - Method in class org.elasticsearch.index.mapper.ContentPath
- remove() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks.Iter
- remove() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles.Iter
- remove() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks.Iter
- remove() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles.Iter
- remove() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket.Iter
- remove(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- remove(long) - Method in interface org.elasticsearch.common.util.concurrent.ConcurrentMapLong
- remove(long) - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
-
Remove the entry which has this key in the hash table and return the associated value or null if there was no entry associated with this key.
- remove(long) - Method in class org.elasticsearch.transport.Transport.ResponseHandlers
-
Removes and return the
Transport.ResponseContext
for the given request ID or returnsnull
if no context is associated with this request ID. - remove(Object) - Method in class org.elasticsearch.common.collect.EvictingQueue
- remove(Object) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- remove(Object) - Method in class org.elasticsearch.common.util.LazyMap
- remove(Object) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
- remove(Object) - Method in class org.elasticsearch.script.DynamicMap
- remove(Object) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- remove(Object) - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- remove(Object) - Method in class org.elasticsearch.search.lookup.SourceLookup
- remove(Object, Object) - Method in class org.elasticsearch.common.util.LazyMap
- remove(String) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- remove(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- remove(String) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- remove(String) - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Removes the provided setting from the internal map holding the current list of settings.
- remove(K) - Method in class org.elasticsearch.common.collect.MapBuilder
- remove(KType) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- remove(Listener) - Method in class org.elasticsearch.watcher.AbstractResourceWatcher
-
Unregisters a listener
- remove(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
- remove(Task) - Method in class org.elasticsearch.tasks.CancellableTasksTracker
-
Remove (and return) the item that corresponds with the given task.
- Remove(String, String, Boolean) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction.Remove
-
Build the operation.
- REMOVE - Enum constant in enum class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
- REMOVE - Enum constant in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Type
- REMOVE_BACKING_INDEX - Enum constant in enum class org.elasticsearch.cluster.metadata.DataStreamAction.Type
- REMOVE_INDEX - Enum constant in enum class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
- removeAlias(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- removeAlias(String[], String...) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Removes aliases from the index.
- removeAlias(String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Removes an alias from the index.
- removeAlias(String, String[]) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
-
Removes aliases from the index.
- removeAll(IntContainer) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- removeAll(ObjectContainer<? super KType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- removeAll(IntObjectPredicate<? super VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- removeAll(IntPredicate) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- removeAll(ObjectObjectPredicate<? super KType, ? super VType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- removeAll(ObjectPredicate<? super KType>) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- removeAll(Collection<?>) - Method in class org.elasticsearch.common.collect.EvictingQueue
- removeAllAliases() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- removeAllIndices() - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- removeAllInflightResponses() - Method in class org.elasticsearch.http.HttpPipeliningAggregator
- removeAllocationId(ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Remove the allocation id of the provided shard from the set of in-sync shard copies
- removeAndAdd(long) - Method in class org.elasticsearch.common.util.BytesRefHash
- removeAndAdd(long) - Method in class org.elasticsearch.common.util.LongHash
- removeAndAdd(long) - Method in class org.elasticsearch.common.util.LongLongHash
- removeAndAdd(long) - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
- removeAndIgnore(UnassignedInfo.AllocationStatus, RoutingChangesObserver) - Method in interface org.elasticsearch.cluster.routing.allocation.ExistingShardsAllocator.UnassignedAllocationHandler
-
Removes and ignores the unassigned shard (will be ignored for this run, but will be added back to unassigned once the metadata is constructed again).
- removeAndIgnore(UnassignedInfo.AllocationStatus, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
-
Removes and ignores the unassigned shard (will be ignored for this run, but will be added back to unassigned once the metadata is constructed again).
- removeAppender(Logger, Appender) - Static method in class org.elasticsearch.common.logging.Loggers
- removeApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Removes an applier of updated cluster states.
- removeApplier(ClusterStateApplier) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Removes an applier of updated cluster states.
- removeBackingIndex(String, String) - Static method in class org.elasticsearch.cluster.metadata.DataStreamAction
- removeBackingIndex(Index) - Method in class org.elasticsearch.cluster.metadata.DataStream
-
Removes the specified backing index and returns a new
DataStream
instance with the remaining backing indices. - removeBan(TaskId) - Method in class org.elasticsearch.tasks.TaskManager
-
Removes the ban for the specified parent task.
- removeComponentTemplate(String) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- removeComponentTemplate(String[], TimeValue, ClusterState, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Remove the given component template from the cluster state.
- removeConnectionListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.TransportService
- RemoveCorruptedLuceneSegmentsAction - Class in org.elasticsearch.index.shard
-
Removes corrupted Lucene index segments
- RemoveCorruptedLuceneSegmentsAction() - Constructor for class org.elasticsearch.index.shard.RemoveCorruptedLuceneSegmentsAction
- RemoveCorruptedShardDataCommand - Class in org.elasticsearch.index.shard
- RemoveCorruptedShardDataCommand() - Constructor for class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand
- RemoveCorruptedShardDataCommand.CleanStatus - Enum Class in org.elasticsearch.index.shard
- removeCorruptionMarker() - Method in class org.elasticsearch.index.store.Store
-
Deletes all corruption markers from this store.
- removeCurrentReference() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- removeCustom(String) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- removeCustom(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- removeCustom(String) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- RemoveCustomsCommand - Class in org.elasticsearch.cluster.coordination
- RemoveCustomsCommand() - Constructor for class org.elasticsearch.cluster.coordination.RemoveCustomsCommand
- removed() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- removeDataStream(String) - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
-
Returns a
DataStreamAlias
instance based on this instance but with the specified data stream no longer referenced. - removeDataStream(String) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- removeDataStreamAlias(String, String, boolean) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- RemoveDataStreamAlias(String, String, Boolean) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction.RemoveDataStreamAlias
- removedNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- removeField(String) - Method in class org.elasticsearch.ingest.IngestDocument
-
Removes the field identified by the provided path.
- removeField(TemplateScript.Factory) - Method in class org.elasticsearch.ingest.IngestDocument
-
Removes the field identified by the provided path.
- removeGlobalBlock(int) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- removeGlobalBlock(ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- removeHeader(String) - Method in class org.elasticsearch.http.HttpPipelinedRequest
- removeHeader(String) - Method in interface org.elasticsearch.http.HttpRequest
- removeIndex() - Static method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Build a new
AliasAction
to remove an index. - removeIndex(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder
- removeIndex(Index, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason, String) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
-
Removes the given index from this service and releases all associated resources.
- removeIndex(Index, IndicesClusterStateService.AllocatedIndices.IndexRemovalReason, String) - Method in class org.elasticsearch.indices.IndicesService
- RemoveIndex(String) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction.RemoveIndex
- removeIndexBlock(String, ClusterBlock) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- removeIndexBlocks(String) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- removeIndexBlockWithId(String, int) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- removeIndexTemplate(String) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- removeIndexTemplateV2(String[], TimeValue, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Remove the given index template from the cluster state.
- removeLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
- removeLifecycleListener(LifecycleListener) - Method in interface org.elasticsearch.common.component.LifecycleComponent
- removeLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.repositories.FilterRepository
- removeListener() - Method in enum class org.elasticsearch.action.ThreadingModel
- removeListener(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Removes a listener for updated cluster states.
- removeListener(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Removes a listener for updated cluster states.
- removeListener(MasterFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- removeListener(NodesFaultDetection.Listener) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
- removeListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.ClusterConnectionManager
- removeListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.ConnectionManager.DelegatingNodeConnectionListener
- removeListener(TransportConnectionListener) - Method in interface org.elasticsearch.transport.ConnectionManager
- removeListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.RemoteConnectionManager
- removeMessageListener(TransportMessageListener) - Method in class org.elasticsearch.transport.TransportService
- removeMetric(String) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Remove metric
- removeMetric(String) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Remove metric
- removeOpenIndexOutputs(String) - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
-
remove and
IndexOutput
for a given file. - removeOperation() - Method in enum class org.elasticsearch.action.ThreadingModel
- removePeerRecoveryRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
- removePeerRecoveryRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.shard.IndexShard
- removePersistentTask(String, ActionListener<PersistentTasksCustomMetadata.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksClusterService
-
Removes the persistent task
- RemovePersistentTaskAction - Class in org.elasticsearch.persistent
- RemovePersistentTaskAction.Request - Class in org.elasticsearch.persistent
- RemovePersistentTaskAction.RequestBuilder - Class in org.elasticsearch.persistent
- RemovePersistentTaskAction.TransportAction - Class in org.elasticsearch.persistent
- removeQueryCancellation(Runnable) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
-
Remove a
Runnable
that checks for query cancellation or timeout which is called while accessing documents in the DirectoryReader but also while collecting them. - removeReaderContext(long) - Method in class org.elasticsearch.search.SearchService
- removeRelocationSource() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Removes relocation source of a non-primary shard.
- removeReplica() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
- removeReplicationAction(String, RetryableAction<?>) - Method in class org.elasticsearch.action.support.replication.PendingReplicationActions
- RemoveRequest(String) - Constructor for class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.RemoveRequest
- RemoveRequest(ShardId, String) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.RemoveRequest
- removeRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Removes an existing retention lease.
- removeRetentionLease(String, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Removes an existing retention lease.
- RemoveSettingsCommand - Class in org.elasticsearch.cluster.coordination
- RemoveSettingsCommand() - Constructor for class org.elasticsearch.cluster.coordination.RemoveSettingsCommand
- removeShard(int, int) - Method in class org.elasticsearch.index.shard.IndexLongFieldRange
-
Remove the given shard from the set of known shards, possibly without adjusting the min and max.
- removeShard(int, String) - Method in class org.elasticsearch.index.IndexService
- removeShard(int, String) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndex
-
Removes shard with given id.
- removeShard(ShardRouting) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- removeSingleNodeMetadata(String) - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
-
Removes all shutdown metadata for a particular node ID.
- removeSnapshots(Collection<SnapshotId>, ShardGenerations) - Method in class org.elasticsearch.repositories.RepositoryData
-
Remove snapshots and remove any indices that no longer exist in the repository due to the deletion of the snapshots.
- removeStaleIdsWithoutRoutings(ClusterState, List<StaleShard>, Logger) - Static method in class org.elasticsearch.cluster.routing.allocation.IndexMetadataUpdater
-
Removes allocation ids from the in-sync set for shard copies for which there is no routing entries in the routing table.
- removeTask(String) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Builder
-
Removes the task
- removeTemplate(String) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- removeTemplates(MetadataIndexTemplateService.RemoveRequest, MetadataIndexTemplateService.RemoveListener) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
- removeThreadContext(ThreadContext) - Static method in class org.elasticsearch.common.logging.HeaderWarning
-
Remove the
ThreadContext
used to add warning headers to network responses. - removeTimeoutListener(TimeoutClusterStateListener) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Removes a timeout listener for updated cluster states.
- removeTransportAddress(TransportAddress) - Method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.Removes a transport address from the list of transport addresses that are used to connect to.
- removeType(IndexTemplateMetadata, XContentBuilder) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
-
Removes the nested type in the xContent representation of
IndexTemplateMetadata
. - renameAllTempFiles() - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
-
renames all temporary files to their true name, potentially overriding existing files
- renameDataStreams(String, String) - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
-
Returns a new instance with potentially renamed data stream names and write data stream name.
- renamePattern() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns rename pattern
- renamePattern(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets rename pattern that should be applied to restored indices.
- renameReplacement() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns rename replacement
- renameReplacement(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets rename replacement
- renameTempFilesSafe(Map<String, String>) - Method in class org.elasticsearch.index.store.Store
-
Renames all the given files from the key of the map to the value of the map.
- renderTemplate(TemplateScript.Factory) - Method in class org.elasticsearch.ingest.IngestDocument
- renewPeerRecoveryRetentionLeases() - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Advance the peer-recovery retention leases for all assigned shard copies to discard history below the corresponding global checkpoint, and renew any leases that are approaching expiry.
- RenewRequest(ShardId, String, long, String) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.RenewRequest
- renewRetentionLease(String, long, String) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Renews an existing retention lease.
- renewRetentionLease(String, long, String) - Method in class org.elasticsearch.index.shard.IndexShard
-
Renews an existing retention lease.
- REOPENED - Enum constant in enum class org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices.IndexRemovalReason
-
The index has been reopened.
- replace(String, String, String) - Static method in class org.elasticsearch.common.Strings
-
Replace all occurrences of a substring within a string with another string.
- replace(K, V) - Method in class org.elasticsearch.common.util.LazyMap
- replace(K, V, V) - Method in class org.elasticsearch.common.util.LazyMap
- REPLACE - Enum constant in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Type
- REPLACE - Enum constant in enum class org.elasticsearch.common.lucene.search.function.CombineFunction
- REPLACE_SHUTDOWN_TYPE_ADDED_VERSION - Static variable in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- replaceAliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- replaceAliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- replaceAliases(String...) - Method in interface org.elasticsearch.action.AliasesRequest
-
Replaces current aliases with the provided aliases.
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.elasticsearch.common.util.LazyMap
- replaceAll(UnaryOperator<T>) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
- replaceBackingIndex(Index, Index) - Method in class org.elasticsearch.cluster.metadata.DataStream
-
Replaces the specified backing index with a new index and returns a new
DataStream
instance with the modified backing indices. - REPLACED - Enum constant in enum class org.elasticsearch.common.cache.RemovalNotification.RemovalReason
- replaceHandler(RequestHandlerRegistry<R>, TransportRequestHandler<R>) - Static method in class org.elasticsearch.transport.RequestHandlerRegistry
- replacementTargetShutdowns() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Returns a map of target node name to replacement shutdown
- replaceMissing(NumericDocValues, long) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Return a
NumericDocValues
instance that has a value for every document, returns the same value asvalues
if there is a value for the current document andmissing
otherwise. - replaceMissing(NumericDoubleValues, double) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Return a
NumericDoubleValues
instance that has a value for every document, returns the same value asvalues
if there is a value for the current document andmissing
otherwise. - replaceMissing(SortedBinaryDocValues, BytesRef) - Static method in enum class org.elasticsearch.search.aggregations.support.MissingValues
- replaceMissing(ValuesSource.Bytes.WithOrdinals, BytesRef) - Static method in enum class org.elasticsearch.search.aggregations.support.MissingValues
- replaceMissing(ValuesSource.Bytes, BytesRef) - Static method in enum class org.elasticsearch.search.aggregations.support.MissingValues
- replaceMissing(ValuesSource.GeoPoint, GeoPoint) - Static method in enum class org.elasticsearch.search.aggregations.support.MissingValues
- replaceMissing(ValuesSource.Numeric, Number) - Static method in enum class org.elasticsearch.search.aggregations.support.MissingValues
- replaceMissing(ValuesSource, Object, DocValueFormat, AggregationContext) - Method in interface org.elasticsearch.search.aggregations.support.ValuesSourceType
-
Apply the given missing value to an already-constructed
ValuesSource
. - replacePropertyPlaceholders() - Method in class org.elasticsearch.common.settings.Settings.Builder
-
Runs across all the settings set on this builder and replaces
${...}
elements in each setting with another setting already set on this builder. - replaces(RestRequest.Method, String, RestApiVersion) - Method in class org.elasticsearch.rest.RestHandler.Route.RouteBuilder
-
Marks that the route being built replaces another route, and notes the major version in which that replacement occurred.
- REPLICA - Enum constant in enum class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus.AllocationStatus
-
Allocated as a replica
- REPLICA - Enum constant in enum class org.elasticsearch.index.engine.Engine.Operation.Origin
- REPLICA - Enum constant in enum class org.elasticsearch.index.mapper.SourceToParse.Origin
- REPLICA_ADDED - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of explicit addition of a replica.
- ReplicaAfterPrimaryActiveAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
An allocation strategy that only allows for a replica to be allocated when the primary is active.
- ReplicaAfterPrimaryActiveAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ReplicaAfterPrimaryActiveAllocationDecider
- replicaOperationSize(BulkShardRequest) - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- replicaOperationSize(ResyncReplicationRequest) - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- replicaOperationSize(ReplicaRequest) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
- replicaPromoted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- replicaPromoted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- replicaPromoted(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- replicaPromoted(ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when started replica is promoted to primary.
- replicaRequest - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryResult
- replicaRequest() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.PrimaryResult
- replicaRequest() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryResult
- ReplicaResponse(long, long) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResponse
- ReplicaResult() - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResult
- ReplicaResult(Exception) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResult
- REPLICAS - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
- ReplicaShardAllocator - Class in org.elasticsearch.gateway
- ReplicaShardAllocator() - Constructor for class org.elasticsearch.gateway.ReplicaShardAllocator
- replicaShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- replicaShardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- ReplicasProxy() - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicasProxy
- REPLICATED_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- ReplicatedWriteRequest<R extends ReplicatedWriteRequest<R>> - Class in org.elasticsearch.action.support.replication
-
Requests that are both ReplicationRequests (run on a shard's primary first, then the replica) and WriteRequest (modify documents on a shard), for example
BulkShardRequest
,IndexRequest
, andDeleteRequest
. - ReplicatedWriteRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.replication.ReplicatedWriteRequest
-
Constructor for deserialization.
- ReplicatedWriteRequest(ShardId) - Constructor for class org.elasticsearch.action.support.replication.ReplicatedWriteRequest
- ReplicatedWriteRequest(ShardId, StreamInput) - Constructor for class org.elasticsearch.action.support.replication.ReplicatedWriteRequest
-
Constructor for thin deserialization.
- REPLICATION_INITIAL_RETRY_BACKOFF_BOUND - Static variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
The maximum bound for the first retry backoff for failed replication operations.
- REPLICATION_RETRY_TIMEOUT - Static variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
The timeout for retrying replication requests.
- ReplicationGroup - Class in org.elasticsearch.index.shard
-
Replication group for a shard.
- ReplicationGroup(IndexShardRoutingTable, Set<String>, Set<String>, long) - Constructor for class org.elasticsearch.index.shard.ReplicationGroup
- ReplicationOperation<Request extends ReplicationRequest<Request>,
ReplicaRequest extends ReplicationRequest<ReplicaRequest>, PrimaryResultT extends ReplicationOperation.PrimaryResult<ReplicaRequest>> - Class in org.elasticsearch.action.support.replication - ReplicationOperation(Request, ReplicationOperation.Primary<Request, ReplicaRequest, PrimaryResultT>, ActionListener<PrimaryResultT>, ReplicationOperation.Replicas<ReplicaRequest>, Logger, ThreadPool, String, long, TimeValue, TimeValue) - Constructor for class org.elasticsearch.action.support.replication.ReplicationOperation
- ReplicationOperation.Primary<RequestT extends ReplicationRequest<RequestT>,
ReplicaRequestT extends ReplicationRequest<ReplicaRequestT>, PrimaryResultT extends ReplicationOperation.PrimaryResult<ReplicaRequestT>> - Interface in org.elasticsearch.action.support.replication -
An encapsulation of an operation that is to be performed on the primary shard
- ReplicationOperation.PrimaryResult<RequestT extends ReplicationRequest<RequestT>> - Interface in org.elasticsearch.action.support.replication
- ReplicationOperation.ReplicaResponse - Interface in org.elasticsearch.action.support.replication
-
An interface to encapsulate the metadata needed from replica shards when they respond to operations performed on them.
- ReplicationOperation.Replicas<RequestT extends ReplicationRequest<RequestT>> - Interface in org.elasticsearch.action.support.replication
-
An encapsulation of an operation that will be executed on the replica shards, if present.
- ReplicationOperation.RetryOnPrimaryException - Exception in org.elasticsearch.action.support.replication
- ReplicationRequest<Request extends ReplicationRequest<Request>> - Class in org.elasticsearch.action.support.replication
-
Requests that are run on a particular replica, first on the primary and then on the replicas like
IndexRequest
orTransportShardRefreshAction
. - ReplicationRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.replication.ReplicationRequest
- ReplicationRequest(ShardId) - Constructor for class org.elasticsearch.action.support.replication.ReplicationRequest
-
Creates a new request with resolved shard id
- ReplicationRequest(ShardId, StreamInput) - Constructor for class org.elasticsearch.action.support.replication.ReplicationRequest
- ReplicationRequestBuilder<Request extends ReplicationRequest<Request>,
Response extends ActionResponse, RequestBuilder extends ReplicationRequestBuilder<Request, Response, RequestBuilder>> - Class in org.elasticsearch.action.support.replication - ReplicationRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
- ReplicationResponse - Class in org.elasticsearch.action.support.replication
-
Base class for write action responses.
- ReplicationResponse() - Constructor for class org.elasticsearch.action.support.replication.ReplicationResponse
- ReplicationResponse(StreamInput) - Constructor for class org.elasticsearch.action.support.replication.ReplicationResponse
- ReplicationResponse.ShardInfo - Class in org.elasticsearch.action.support.replication
- ReplicationResponse.ShardInfo.Failure - Exception in org.elasticsearch.action.support.replication
- ReplicationTask - Class in org.elasticsearch.action.support.replication
-
Task that tracks replication actions.
- ReplicationTask(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.action.support.replication.ReplicationTask
- ReplicationTask.Status - Class in org.elasticsearch.action.support.replication
- ReplicationTracker - Class in org.elasticsearch.index.seqno
-
This class is responsible for tracking the replication group with its progress and safety markers (local and global checkpoints).
- ReplicationTracker(ShardId, String, IndexSettings, long, long, LongConsumer, LongSupplier, BiConsumer<RetentionLeases, ActionListener<ReplicationResponse>>, Supplier<SafeCommitInfo>) - Constructor for class org.elasticsearch.index.seqno.ReplicationTracker
- ReplicationTracker(ShardId, String, IndexSettings, long, long, LongConsumer, LongSupplier, BiConsumer<RetentionLeases, ActionListener<ReplicationResponse>>, Supplier<SafeCommitInfo>, Consumer<ReplicationGroup>) - Constructor for class org.elasticsearch.index.seqno.ReplicationTracker
-
Initialize the global checkpoint service.
- ReplicationTracker.CheckpointState - Class in org.elasticsearch.index.seqno
- ReplicationTracker.PrimaryContext - Class in org.elasticsearch.index.seqno
-
Represents the sequence number component of the primary context.
- REPO_GEN_IN_CS_VERSION - Static variable in class org.elasticsearch.cluster.metadata.RepositoryMetadata
- repoFiles() - Method in class org.elasticsearch.env.Environment
-
The shared filesystem repo locations.
- repoName() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.After
- ReportingService<I extends ReportingService.Info> - Interface in org.elasticsearch.node
- ReportingService.Info - Interface in org.elasticsearch.node
- repositories() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
-
The names of the repositories.
- repositories() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesResponse
-
List of repositories to return
- repositories() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Returns repository names
- repositories() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
-
Returns list of currently registered repositories
- repositories(String[]) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
-
Sets the list or repositories.
- repositories(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Sets repository names
- REPOSITORIES_CHUNK_SIZE_SETTING - Static variable in class org.elasticsearch.repositories.fs.FsRepository
- REPOSITORIES_COMPRESS_SETTING - Static variable in class org.elasticsearch.repositories.fs.FsRepository
- REPOSITORIES_LOCATION_SETTING - Static variable in class org.elasticsearch.repositories.fs.FsRepository
- REPOSITORIES_STATS_ARCHIVE_MAX_ARCHIVED_STATS - Static variable in class org.elasticsearch.repositories.RepositoriesService
- REPOSITORIES_STATS_ARCHIVE_RETENTION_PERIOD - Static variable in class org.elasticsearch.repositories.RepositoriesService
- RepositoriesMetadata - Class in org.elasticsearch.cluster.metadata
-
Contains metadata about registered snapshot repositories
- RepositoriesMetadata(List<RepositoryMetadata>) - Constructor for class org.elasticsearch.cluster.metadata.RepositoriesMetadata
-
Constructs new repository metadata
- RepositoriesMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.RepositoriesMetadata
- RepositoriesModule - Class in org.elasticsearch.repositories
-
Sets up classes for Snapshot/Restore.
- RepositoriesModule(Environment, List<RepositoryPlugin>, TransportService, ClusterService, BigArrays, NamedXContentRegistry, RecoverySettings) - Constructor for class org.elasticsearch.repositories.RepositoriesModule
- RepositoriesService - Class in org.elasticsearch.repositories
-
Service responsible for maintaining and providing access to snapshot repositories on nodes.
- RepositoriesService(Settings, ClusterService, TransportService, Map<String, Repository.Factory>, Map<String, Repository.Factory>, ThreadPool) - Constructor for class org.elasticsearch.repositories.RepositoriesService
- repositoriesStats() - Method in class org.elasticsearch.repositories.RepositoriesService
- RepositoriesStatsArchive - Class in org.elasticsearch.repositories
- RepositoriesStatsArchive(TimeValue, int, LongSupplier) - Constructor for class org.elasticsearch.repositories.RepositoriesStatsArchive
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns repository name
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
-
Returns repository name
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Returns repository name
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns repository name
- repository() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Returns repository name
- repository() - Method in class org.elasticsearch.cluster.RepositoryCleanupInProgress.Entry
- repository() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- repository() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- repository() - Method in exception org.elasticsearch.repositories.RepositoryException
-
Returns repository name
- repository() - Method in interface org.elasticsearch.repositories.RepositoryOperation
-
Name of the repository affected.
- repository() - Method in class org.elasticsearch.snapshots.SnapshotInfo
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets repository name
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Sets repository name
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets repository name
- repository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Sets repository name
- repository(String) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
-
Returns a repository with a given name or null if such repository doesn't exist
- repository(String) - Method in class org.elasticsearch.repositories.RepositoriesService
-
Returns registered repository
- Repository - Interface in org.elasticsearch.repositories
-
An interface for interacting with a repository in snapshot and restore.
- REPOSITORY - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.SortBy
- Repository.Factory - Interface in org.elasticsearch.repositories
-
An factory interface for constructing repositories.
- RepositoryCleanupInProgress - Class in org.elasticsearch.cluster
- RepositoryCleanupInProgress(List<RepositoryCleanupInProgress.Entry>) - Constructor for class org.elasticsearch.cluster.RepositoryCleanupInProgress
- RepositoryCleanupInProgress.Entry - Class in org.elasticsearch.cluster
- RepositoryCleanupResult - Class in org.elasticsearch.repositories
- RepositoryCleanupResult(DeleteResult) - Constructor for class org.elasticsearch.repositories.RepositoryCleanupResult
- RepositoryCleanupResult(StreamInput) - Constructor for class org.elasticsearch.repositories.RepositoryCleanupResult
- RepositoryData - Class in org.elasticsearch.repositories
-
A class that represents the data in a repository, as captured in the repository's index blob.
- RepositoryData(String, long, Map<String, SnapshotId>, Map<String, RepositoryData.SnapshotDetails>, Map<IndexId, List<SnapshotId>>, ShardGenerations, IndexMetaDataGenerations, String) - Constructor for class org.elasticsearch.repositories.RepositoryData
- RepositoryData.SnapshotDetails - Class in org.elasticsearch.repositories
-
A few details of an individual snapshot stored in the top-level index blob, so they are readily accessible without having to load the corresponding
SnapshotInfo
blob for each snapshot. - RepositoryException - Exception in org.elasticsearch.repositories
-
Generic repository exception
- RepositoryException(String, String) - Constructor for exception org.elasticsearch.repositories.RepositoryException
- RepositoryException(String, String, Throwable) - Constructor for exception org.elasticsearch.repositories.RepositoryException
- RepositoryException(StreamInput) - Constructor for exception org.elasticsearch.repositories.RepositoryException
- RepositoryInfo - Class in org.elasticsearch.repositories
- RepositoryInfo(String, String, String, Map<String, String>, long) - Constructor for class org.elasticsearch.repositories.RepositoryInfo
- RepositoryInfo(String, String, String, Map<String, String>, long, Long) - Constructor for class org.elasticsearch.repositories.RepositoryInfo
- RepositoryInfo(StreamInput) - Constructor for class org.elasticsearch.repositories.RepositoryInfo
- RepositoryMetadata - Class in org.elasticsearch.cluster.metadata
-
Metadata about registered repository
- RepositoryMetadata(String, String, String, Settings, long, long) - Constructor for class org.elasticsearch.cluster.metadata.RepositoryMetadata
- RepositoryMetadata(String, String, Settings) - Constructor for class org.elasticsearch.cluster.metadata.RepositoryMetadata
-
Constructs new repository metadata
- RepositoryMetadata(RepositoryMetadata, long, long) - Constructor for class org.elasticsearch.cluster.metadata.RepositoryMetadata
- RepositoryMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.RepositoryMetadata
- repositoryMetaVersion() - Method in class org.elasticsearch.repositories.FinalizeSnapshotContext
- RepositoryMissingException - Exception in org.elasticsearch.repositories
-
Repository missing exception
- RepositoryMissingException(String) - Constructor for exception org.elasticsearch.repositories.RepositoryMissingException
- RepositoryMissingException(StreamInput) - Constructor for exception org.elasticsearch.repositories.RepositoryMissingException
- repositoryName - Variable in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- RepositoryOperation - Interface in org.elasticsearch.repositories
-
Coordinates of an operation that modifies a repository, assuming that repository at a specific generation.
- RepositoryPlugin - Interface in org.elasticsearch.plugins
-
An extension point for
Plugin
implementations to add custom snapshot repositories. - RepositoryShardId - Class in org.elasticsearch.repositories
-
Represents a shard snapshot in a repository.
- RepositoryShardId(StreamInput) - Constructor for class org.elasticsearch.repositories.RepositoryShardId
- RepositoryShardId(IndexId, int) - Constructor for class org.elasticsearch.repositories.RepositoryShardId
- repositoryStateId() - Method in class org.elasticsearch.cluster.RepositoryCleanupInProgress.Entry
- repositoryStateId() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- repositoryStateId() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- repositoryStateId() - Method in class org.elasticsearch.repositories.FinalizeSnapshotContext
- repositoryStateId() - Method in interface org.elasticsearch.repositories.RepositoryOperation
-
The repository state id at the time the operation began.
- RepositoryStats - Class in org.elasticsearch.repositories
- RepositoryStats(Map<String, Long>) - Constructor for class org.elasticsearch.repositories.RepositoryStats
- RepositoryStats(StreamInput) - Constructor for class org.elasticsearch.repositories.RepositoryStats
- RepositoryStatsSnapshot - Class in org.elasticsearch.repositories
- RepositoryStatsSnapshot(StreamInput) - Constructor for class org.elasticsearch.repositories.RepositoryStatsSnapshot
- RepositoryStatsSnapshot(RepositoryInfo, RepositoryStats, long, boolean) - Constructor for class org.elasticsearch.repositories.RepositoryStatsSnapshot
- RepositoryVerificationException - Exception in org.elasticsearch.repositories
-
Repository verification exception
- RepositoryVerificationException(String, String) - Constructor for exception org.elasticsearch.repositories.RepositoryVerificationException
- RepositoryVerificationException(String, String, Throwable) - Constructor for exception org.elasticsearch.repositories.RepositoryVerificationException
- RepositoryVerificationException(StreamInput) - Constructor for exception org.elasticsearch.repositories.RepositoryVerificationException
- request - Variable in class org.elasticsearch.action.ActionRequestBuilder
- request - Variable in class org.elasticsearch.rest.AbstractRestChannel
- request() - Method in class org.elasticsearch.action.ActionRequestBuilder
- request() - Method in class org.elasticsearch.action.bulk.BulkItemRequest
- request() - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction.InternalRequest
- request() - Method in interface org.elasticsearch.action.support.WriteRequestBuilder
- request() - Method in class org.elasticsearch.rest.AbstractRestChannel
- request() - Method in interface org.elasticsearch.rest.RestChannel
- request() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- request() - Method in class org.elasticsearch.search.internal.SearchContext
- request(NamedXContentRegistry, HttpRequest, HttpChannel) - Static method in class org.elasticsearch.rest.RestRequest
-
Creates a new REST request.
- Request() - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- Request() - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Request
- Request() - Constructor for class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction.Request
- Request() - Constructor for class org.elasticsearch.persistent.CompletionPersistentTaskAction.Request
- Request() - Constructor for class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- Request() - Constructor for class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- Request() - Constructor for class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- Request(String) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
-
Constructs a new analyzer request for the provided index.
- Request(String) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Request
- Request(String) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Request
- Request(String) - Constructor for class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction.Request
- Request(String) - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction.Request
-
Constructs a new put component template request with the provided name.
- Request(String) - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
-
Constructs a new put index template request with the provided name.
- Request(String) - Constructor for class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- Request(String[]) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.Request
- Request(String[]) - Constructor for class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Request
- Request(String...) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.DeleteComponentTemplateAction.Request
-
Constructs a new delete index request for the specified name.
- Request(String...) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.DeleteComposableIndexTemplateAction.Request
-
Constructs a new delete template request for the specified name.
- Request(String...) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.Request
- Request(String[], IndicesOptions) - Constructor for class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Request
- Request(String, long, Exception, String) - Constructor for class org.elasticsearch.persistent.CompletionPersistentTaskAction.Request
- Request(String, long, PersistentTaskState) - Constructor for class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- Request(String, String, PersistentTaskParams) - Constructor for class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- Request(List<DataStreamAction>) - Constructor for class org.elasticsearch.action.datastreams.ModifyDataStreamsAction.Request
- Request(PutComposableIndexTemplateAction.Request) - Constructor for class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.DeleteComponentTemplateAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.DeleteComposableIndexTemplateAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.action.datastreams.ModifyDataStreamsAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.persistent.CompletionPersistentTaskAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- Request(StreamInput) - Constructor for class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- Request(ShardId) - Constructor for class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction.Request
- Request(ShardId, String, DiscoveryNode[]) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
- Request(ShardId, String, DiscoveryNode[]) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.Request
- Request(ShardId, RetentionLeases) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction.Request
- Request(ShardId, RetentionLeases) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Request
- REQUEST - Enum constant in enum class org.elasticsearch.index.translog.Translog.Durability
-
Request durability - translogs are synced for each high level request (bulk, index, delete)
- REQUEST - Static variable in interface org.elasticsearch.common.breaker.CircuitBreaker
-
The request breaker tracks memory used for particular requests.
- REQUEST_CIRCUIT_BREAKER_LIMIT_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- REQUEST_CIRCUIT_BREAKER_OVERHEAD_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- REQUEST_CIRCUIT_BREAKER_TYPE_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- REQUEST_ENTITY_TOO_LARGE - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server is refusing to process a request because the request entity is larger than the server is willing or able to process.
- REQUEST_ID_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- REQUEST_PEERS_ACTION_NAME - Static variable in class org.elasticsearch.discovery.PeerFinder
- REQUEST_PRE_VOTE_ACTION_NAME - Static variable in class org.elasticsearch.cluster.coordination.PreVoteCollector
- REQUEST_TIMEOUT - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The client did not produce a request within the time that the server was prepared to wait.
- REQUEST_URI_TOO_LONG - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server is refusing to service the request because the Request-URI is longer than the server is willing to interpret.
- RequestBuilder(ElasticsearchClient, CompletionPersistentTaskAction) - Constructor for class org.elasticsearch.persistent.CompletionPersistentTaskAction.RequestBuilder
- RequestBuilder(ElasticsearchClient, RemovePersistentTaskAction) - Constructor for class org.elasticsearch.persistent.RemovePersistentTaskAction.RequestBuilder
- RequestBuilder(ElasticsearchClient, StartPersistentTaskAction) - Constructor for class org.elasticsearch.persistent.StartPersistentTaskAction.RequestBuilder
- RequestBuilder(ElasticsearchClient, UpdatePersistentTaskStatusAction) - Constructor for class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.RequestBuilder
- requestCache - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- requestCache() - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- requestCache() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- requestCache() - Method in class org.elasticsearch.action.search.SearchRequest
- requestCache() - Method in class org.elasticsearch.index.shard.IndexShard
- requestCache() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- requestCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- requestCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- requestCache(Boolean) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets if this request should use the request cache or not, assuming that it can (for example, if "now" is used, it will never be cached).
- requestCache(Boolean) - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- RequestCache - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- RequestCacheStats - Class in org.elasticsearch.index.cache.request
- RequestCacheStats() - Constructor for class org.elasticsearch.index.cache.request.RequestCacheStats
- RequestCacheStats(long, long, long, long) - Constructor for class org.elasticsearch.index.cache.request.RequestCacheStats
- RequestCacheStats(StreamInput) - Constructor for class org.elasticsearch.index.cache.request.RequestCacheStats
- requestCounts - Variable in class org.elasticsearch.repositories.RepositoryStats
- REQUESTED_RANGE_NOT_SATISFIED - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
A server SHOULD return a response with this status code if a request included a Range request-header field (section 14.35), and none of the range-specifier values in this field overlap the current extent of the selected resource, and the request did not include an If-Range request-header field.
- requestedMetrics() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
-
Get the names of requested metrics
- requestedMetrics() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
-
Get the names of requested metrics, excluding indices, which are handled separately.
- RequestHandlerRegistry<Request extends TransportRequest> - Class in org.elasticsearch.transport
- RequestHandlerRegistry(String, Writeable.Reader<Request>, TaskManager, TransportRequestHandler<Request>, String, boolean, boolean) - Constructor for class org.elasticsearch.transport.RequestHandlerRegistry
- RequestHandlers() - Constructor for class org.elasticsearch.transport.Transport.RequestHandlers
- requestId - Variable in class org.elasticsearch.transport.NetworkMessage
- requestInjection(Object) - Method in class org.elasticsearch.common.inject.AbstractModule
- requestInjection(Object) - Method in interface org.elasticsearch.common.inject.Binder
-
Upon successful creation, the
Injector
will inject instance fields and methods of the given object. - requestInjection(TypeLiteral<T>, T) - Method in interface org.elasticsearch.common.inject.Binder
-
Upon successful creation, the
Injector
will inject instance fields and methods of the given object. - requestReader - Variable in class org.elasticsearch.action.support.tasks.TransportTasksAction
- requests() - Method in class org.elasticsearch.action.bulk.BulkRequest
-
The list of requests in this bulk request.
- requests() - Method in class org.elasticsearch.action.search.MultiSearchRequest
- Requests - Class in org.elasticsearch.client
-
A handy one stop shop for creating requests (make sure to import static this class).
- Requests() - Constructor for class org.elasticsearch.client.Requests
- REQUESTS_PER_SEC_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- requestSeqNo() - Method in class org.elasticsearch.indices.recovery.RecoveryTransportRequest
- requestStaticInjection(Class<?>...) - Method in class org.elasticsearch.common.inject.AbstractModule
- requestStaticInjection(Class<?>...) - Method in interface org.elasticsearch.common.inject.Binder
-
Upon successful creation, the
Injector
will inject static fields and methods in the given classes. - RequestValidators<T extends ActionRequest> - Class in org.elasticsearch.action
- RequestValidators(Collection<RequestValidators.RequestValidator<T>>) - Constructor for class org.elasticsearch.action.RequestValidators
- RequestValidators.RequestValidator<T extends ActionRequest> - Interface in org.elasticsearch.action
-
A validator that validates an request associated with indices before executing it.
- requestWithoutParameters(NamedXContentRegistry, HttpRequest, HttpChannel) - Static method in class org.elasticsearch.rest.RestRequest
-
Creates a new REST request.
- REQUIRE_ALIAS - Static variable in interface org.elasticsearch.action.DocWriteRequest
- REQUIRE_FIELD_MATCH_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- requireAlias() - Method in class org.elasticsearch.action.bulk.BulkRequest
- requireAlias(Boolean) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Note for internal callers (NOT high level rest client), the global parameter setting is ignored when used with: -
BulkRequest.add(IndexRequest)
-BulkRequest.add(UpdateRequest)
-BulkRequest.add(DocWriteRequest)
-BulkRequest.add(DocWriteRequest[])
)} -BulkRequest.add(Iterable)
- requireBinding(Class<?>) - Method in class org.elasticsearch.common.inject.AbstractModule
-
Adds a dependency from this module to
type
. - requireBinding(Key<?>) - Method in class org.elasticsearch.common.inject.AbstractModule
-
Adds a dependency from this module to
key
. - required() - Method in class org.elasticsearch.cluster.metadata.MappingMetadata.Routing
- required() - Method in class org.elasticsearch.index.mapper.RoutingFieldMapper
- REQUIRED - Static variable in class org.elasticsearch.index.mapper.RoutingFieldMapper.Defaults
- REQUIRED_SIZE_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- requiredContent() - Method in class org.elasticsearch.rest.RestRequest
- requiredSize - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- requiredSize - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregator
- requiredSize - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGrid
- requiredSize - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- requiredSize - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- requireFieldMatch - Variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- requireFieldMatch() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- requireFieldMatch() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- requireFieldMatch(Boolean) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
Set to true to cause a field to be highlighted only if a query matches that field.
- requireFilters() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- requireNonEmpty(String, String) - Static method in class org.elasticsearch.common.Strings
-
Checks that the supplied string is neither null nor empty, per
Strings.isNullOrEmpty(String)
. - REQUIRES_NAME_SETTING - Static variable in class org.elasticsearch.action.support.DestructiveOperations
-
Setting which controls whether wildcard usage (*, prefix*, _all) is allowed.
- requiresAnalysisSettings() - Method in interface org.elasticsearch.indices.analysis.AnalysisModule.AnalysisProvider
-
If
true
the analysis component created by this provider requires certain settings to be instantiated. - requiresAnalysisSettings(AnalysisModule.AnalysisProvider<T>) - Static method in interface org.elasticsearch.plugins.AnalysisPlugin
-
Mark an
AnalysisModule.AnalysisProvider
as requiring the index's settings. - requiresParameters(FieldMapper.Parameter<?>...) - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- requireValidHeader(String) - Static method in class org.elasticsearch.rest.DeprecationRestHandler
-
Throw an exception if the
value
is not avalid header
. - requireValue(T, String) - Static method in class org.elasticsearch.index.query.AbstractQueryBuilder
- reroute(String, Priority, ActionListener<ClusterState>) - Method in class org.elasticsearch.cluster.routing.BatchedRerouteService
-
Initiates a reroute.
- reroute(String, Priority, ActionListener<ClusterState>) - Method in interface org.elasticsearch.cluster.routing.RerouteService
-
Schedule a cluster reroute.
- reroute(ClusterRerouteRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Reroutes allocation of shards.
- reroute(ClusterRerouteRequest, ActionListener<ClusterRerouteResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Reroutes allocation of shards.
- reroute(ClusterState, String) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Computes the next step towards a fully allocated and balanced cluster and records this step in the routing table of the returned state.
- reroute(ClusterState, AllocationCommands, boolean, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
- reroute(ShardId, String) - Method in class org.elasticsearch.gateway.AsyncShardFetch
-
Implement this in order to scheduled another round that causes a call to fetch data.
- REROUTE_CANCELLED - Enum constant in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Unassigned as a result of explicit cancel reroute command.
- RerouteExplanation - Class in org.elasticsearch.cluster.routing.allocation
-
Class encapsulating the explanation for a single
AllocationCommand
taken from the Deciders - RerouteExplanation(AllocationCommand, Decision) - Constructor for class org.elasticsearch.cluster.routing.allocation.RerouteExplanation
- RerouteService - Interface in org.elasticsearch.cluster.routing
-
Asynchronously performs a cluster reroute, updating any shard states and rebalancing the cluster if appropriate.
- rescheduleIfNecessary() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
-
Schedule the task to run after the configured interval if it is not closed and any further conditions imposed by derived classes are met.
- rescore() - Method in class org.elasticsearch.search.fetch.FetchContext
-
The rescorers included in the original search, used for explain output
- rescore() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- rescore() - Method in class org.elasticsearch.search.internal.SearchContext
- rescore(TopDocs, IndexSearcher, RescoreContext) - Method in class org.elasticsearch.search.rescore.QueryRescorer
- rescore(TopDocs, IndexSearcher, RescoreContext) - Method in interface org.elasticsearch.search.rescore.Rescorer
-
Modifies the result of the previously executed search (
TopDocs
) in place based on the givenRescoreContext
. - RESCORE_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- RescoreContext - Class in org.elasticsearch.search.rescore
-
Context available to the rescore while it is running.
- RescoreContext(int, Rescorer) - Constructor for class org.elasticsearch.search.rescore.RescoreContext
-
Build the context.
- rescoreDocIds() - Method in class org.elasticsearch.search.internal.SearchContext
- RescoreDocIds - Class in org.elasticsearch.search
-
Since
SearchContext
no longer hold the states of search, the top K results (i.e., documents that will be rescored by query rescorers) need to be serialized/ deserialized between search phases. - RescoreDocIds(Map<Integer, Set<Integer>>) - Constructor for class org.elasticsearch.search.RescoreDocIds
- RescoreDocIds(StreamInput) - Constructor for class org.elasticsearch.search.RescoreDocIds
- RescorePhase - Class in org.elasticsearch.search.rescore
-
Rescore phase of a search request, used to run potentially expensive scoring models against the top matching documents.
- RescorePhase() - Constructor for class org.elasticsearch.search.rescore.RescorePhase
- rescoreQueryWeight() - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- rescorer() - Method in class org.elasticsearch.search.rescore.RescoreContext
-
The rescorer to actually apply.
- Rescorer - Interface in org.elasticsearch.search.rescore
-
A query rescorer interface used to re-rank the Top-K results of a previously executed search.
- RescorerBuilder<RB extends RescorerBuilder<RB>> - Class in org.elasticsearch.search.rescore
-
The abstract base builder for instances of
RescorerBuilder
. - RescorerBuilder() - Constructor for class org.elasticsearch.search.rescore.RescorerBuilder
-
Construct an empty RescoreBuilder.
- RescorerBuilder(StreamInput) - Constructor for class org.elasticsearch.search.rescore.RescorerBuilder
-
Read from a stream.
- RescorerSpec(String, Writeable.Reader<? extends T>, CheckedFunction<XContentParser, T, IOException>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.RescorerSpec
- RescorerSpec(ParseField, Writeable.Reader<? extends T>, CheckedFunction<XContentParser, T, IOException>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.RescorerSpec
- rescores() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the bytes representing the rescore builders for this request.
- RESERVED_BYTES_VERSION - Static variable in class org.elasticsearch.index.store.StoreStats
- reset() - Method in class org.elasticsearch.action.index.IndexRequest
-
Resets this
IndexRequest
class, so that in case this instance can be used by the bulk/index action if it was already used before. - reset() - Method in interface org.elasticsearch.cluster.routing.ShardIterator
-
Resets the iterator.
- reset() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
Resets the iterator to its initial state.
- reset() - Method in class org.elasticsearch.common.bytes.RecyclingBytesStreamOutput
- reset() - Method in class org.elasticsearch.common.hash.Murmur3Hasher
-
Clears all bytes previously passed to
Murmur3Hasher.update(byte[])
and prepares for the calculation of a new hash. - reset() - Method in class org.elasticsearch.common.inject.internal.Stopwatch
-
Resets and returns elapsed time in milliseconds.
- reset() - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- reset() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- reset() - Method in class org.elasticsearch.common.io.stream.DataOutputStreamOutput
- reset() - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- reset() - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- reset() - Method in class org.elasticsearch.common.io.stream.OutputStreamStreamOutput
- reset() - Method in class org.elasticsearch.common.io.stream.ReleasableBytesStreamOutput
- reset() - Method in class org.elasticsearch.common.io.stream.StreamOutput
- reset() - Method in class org.elasticsearch.common.io.UTF8StreamWriter
- reset() - Method in class org.elasticsearch.common.logging.RateLimitingFilter
-
Clears the cache of previously-seen keys.
- reset() - Method in class org.elasticsearch.common.lucene.store.InputStreamIndexInput
- reset() - Method in class org.elasticsearch.common.util.LazyInitializable
-
Clears the value, if it has been previously created by calling
#getOrCompute()
. - reset() - Method in class org.elasticsearch.common.util.PlainIterator
- reset() - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- reset() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- reset() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
- reset() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- reset() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- reset() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- reset() - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- reset() - Method in class org.elasticsearch.search.aggregations.MultiBucketConsumerService.MultiBucketConsumer
- reset(byte[]) - Method in class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- reset(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- reset(double, double) - Method in class org.elasticsearch.common.geo.GeoPoint
- reset(double, double) - Method in class org.elasticsearch.search.aggregations.metrics.CompensatedSum
-
Resets the internal state to use the new value and compensation delta
- reset(TokenStream) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- reset(FieldMapper.CopyTo) - Method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo.Builder
- reset(T, double, double) - Method in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.PointParser
- RESET_CONTENT - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server has fulfilled the request and the user agent SHOULD reset the document view which caused the request to be sent.
- resetAndLog(String) - Method in class org.elasticsearch.common.inject.internal.Stopwatch
-
Resets and logs elapsed time in milliseconds.
- resetDigest() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- resetDigest() - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
- ResetFeatureStateAction - Class in org.elasticsearch.action.admin.cluster.snapshots.features
-
Action for resetting feature states, mostly meaning system indices
- ResetFeatureStateRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.features
-
Request for resetting feature state
- ResetFeatureStateRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateRequest
- ResetFeatureStateResponse - Class in org.elasticsearch.action.admin.cluster.snapshots.features
-
Response to a feature state reset request.
- ResetFeatureStateResponse(List<ResetFeatureStateResponse.ResetFeatureStateStatus>) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse
-
Create a response showing which features have had state reset and success or failure status.
- ResetFeatureStateResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse
- ResetFeatureStateResponse.ResetFeatureStateStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.features
-
An object with the name of a feature and a message indicating success or failure.
- ResetFeatureStateResponse.ResetFeatureStateStatus.Status - Enum Class in org.elasticsearch.action.admin.cluster.snapshots.features
-
Success or failure enum.
- resetFromCoordinates(String, boolean) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetFromGeoHash(long) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetFromGeoHash(String) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetFromIndexableField(IndexableField) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetFromIndexHash(long) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetFromString(String) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetFromString(String, boolean, GeoUtils.EffectivePoint) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetLat(double) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetLon(double) - Method in class org.elasticsearch.common.geo.GeoPoint
- resetRecoveredBytesOfFile(String) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- resetRecoveredBytesOfFile(String) - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- resetRecovery(long, TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
Resets the recovery and performs a recovery restart on the currently recovering index shard
- resetRecoveryStage() - Method in class org.elasticsearch.index.shard.IndexShard
-
If a file-based recovery occurs, a recovery target calls this method to reset the recovery stage.
- resize(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.BytesRefs
-
Set the
List.size()
and ensure that theScriptDocValues.BinaryScriptDocValues.values
array can store at least that many entries. - resize(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
-
Set the
ScriptDocValues.Booleans.size()
and ensure that theScriptDocValues.Booleans.values
array can store at least that many entries. - resize(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
-
Set the
ScriptDocValues.Doubles.size()
and ensure that theScriptDocValues.Doubles.values
array can store at least that many entries. - resize(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
-
Set the
ScriptDocValues.GeoPoints.size()
and ensure that theScriptDocValues.GeoPoints.values
array can store at least that many entries. - resize(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
-
Set the
ScriptDocValues.Longs.size()
and ensure that theScriptDocValues.Longs.values
array can store at least that many entries. - resize(int) - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
-
Set the
SortingNumericDocValues.docValueCount()
and ensure that theSortingNumericDocValues.values
array can store at least that many entries. - resize(int) - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
-
Set the
SortingNumericDoubleValues.docValueCount()
and ensure that theSortingNumericDoubleValues.values
array can store at least that many entries. - resize(long) - Method in class org.elasticsearch.common.util.LongLongHash
- resize(long) - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
- resize(ByteArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Resize the array to the exact provided size.
- resize(DoubleArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Resize the array to the exact provided size.
- resize(FloatArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Resize the array to the exact provided size.
- resize(IntArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Resize the array to the exact provided size.
- resize(LongArray, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Resize the array to the exact provided size.
- resize(ObjectArray<T>, long) - Method in class org.elasticsearch.common.util.BigArrays
-
Resize the array to the exact provided size.
- ResizeAction - Class in org.elasticsearch.action.admin.indices.shrink
- ResizeAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
An allocation decider that ensures we allocate the shards of a target index for resize operations next to the source primaries
- ResizeAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ResizeAllocationDecider
- resizeIndex(ResizeRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Resize an index using an explicit request allowing to specify the settings, mappings and aliases of the target index of the index.
- resizeIndex(ResizeRequest, ActionListener<ResizeResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Shrinks an index using an explicit request allowing to specify the settings, mappings and aliases of the target index of the index.
- ResizeRequest - Class in org.elasticsearch.action.admin.indices.shrink
-
Request class to shrink an index into a single shard
- ResizeRequest(String, String) - Constructor for class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- ResizeRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- ResizeRequestBuilder - Class in org.elasticsearch.action.admin.indices.shrink
- ResizeRequestBuilder(ElasticsearchClient, ActionType<ResizeResponse>) - Constructor for class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
- ResizeResponse - Class in org.elasticsearch.action.admin.indices.shrink
-
A response for a resize index action, either shrink or split index.
- ResizeResponse(boolean, boolean, String) - Constructor for class org.elasticsearch.action.admin.indices.shrink.ResizeResponse
- resizeType() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
-
Returns the resize type or null if this is an ordinary create index request
- resizeType(ResizeType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- ResizeType - Enum Class in org.elasticsearch.action.admin.indices.shrink
-
The type of the resize operation
- resolution - Variable in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- resolution() - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- resolve(byte) - Static method in enum class org.elasticsearch.common.rounding.DateTimeUnit
- resolve(byte) - Static method in enum class org.elasticsearch.common.Rounding.DateTimeUnit
- resolve(String) - Static method in enum class org.elasticsearch.common.Rounding.DateTimeUnit
- resolve(String) - Static method in enum class org.elasticsearch.persistent.decider.AssignmentDecision.Type
- resolve(String) - Static method in enum class org.elasticsearch.search.suggest.SortBy
- resolve(String) - Static method in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
- resolve(String) - Static method in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
- resolve(IndexNameExpressionResolver.Context, List<String>) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.DateMathExpressionResolver
- resolve(Index) - Method in class org.elasticsearch.env.NodeEnvironment.DataPath
-
Resolves index directory against this DataPath ${data.paths}/nodes/{node.id}/indices/{index.uuid}
- resolve(ShardId) - Method in class org.elasticsearch.env.NodeEnvironment.DataPath
-
Resolves the given shards directory against this DataPath ${data.paths}/nodes/{node.id}/indices/{index.uuid}/{shard.id}
- resolve(AggregationContext, ValueType, String, Script, Object, ZoneId, String, ValuesSourceType) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
Given the query context and other information, decide on the input
ValuesSource
for this aggretation run, and construct a newValuesSourceConfig
based on thatValuesSourceType
- resolveAggregator(Aggregator) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
Resolves the Aggregator pointed to by this path against the given root Aggregator.
- resolveAliases(List<IndexTemplateMetadata>) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Resolve the given v1 templates into an ordered list of aliases
- resolveAliases(Metadata, String) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Resolve the given v2 template name into an ordered list of aliases
- resolveAndValidateAliases(String, Set<Alias>, List<Map<String, AliasMetadata>>, Metadata, AliasValidator, NamedXContentRegistry, SearchExecutionContext, Function<String, String>) - Static method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
-
Validate and resolve the aliases explicitly set for the index, together with the ones inherited from the specified templates.
- resolveAndValidateRouting(Metadata, String, UpdateRequest) - Static method in class org.elasticsearch.action.update.TransportUpdateAction
- resolveBaseCustomLocation(String, Path, int) - Static method in class org.elasticsearch.env.NodeEnvironment
-
Resolve the custom path for a index's shard.
- resolveBindHostAddresses(String[]) - Method in class org.elasticsearch.common.network.NetworkService
-
Resolves
bindHosts
to a list of internet addresses. - resolveBucketValue(MultiBucketsAggregation, InternalMultiBucketAggregation.InternalBucket, String, BucketHelpers.GapPolicy) - Static method in class org.elasticsearch.search.aggregations.pipeline.BucketHelpers
-
Given a path and a set of buckets, this method will return the value inside the agg at that path.
- resolveBucketValue(MultiBucketsAggregation, InternalMultiBucketAggregation.InternalBucket, List<String>, BucketHelpers.GapPolicy) - Static method in class org.elasticsearch.search.aggregations.pipeline.BucketHelpers
- resolveClusterNames(Set<String>, String) - Method in class org.elasticsearch.cluster.metadata.ClusterNameExpressionResolver
-
Resolves the provided cluster expression to matching cluster names.
- resolveConcreteIndexNames(ClusterState, Request) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Resolves a list of concrete index names.
- resolveConfig(AggregationContext) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Aggregations should override this if they need non-standard logic for resolving where to get values from.
- resolveConfiguredHosts(Consumer<List<TransportAddress>>) - Method in interface org.elasticsearch.discovery.ConfiguredHostsResolver
-
Attempt to resolve the configured hosts list to a list of transport addresses.
- resolveConfiguredHosts(Consumer<List<TransportAddress>>) - Method in class org.elasticsearch.discovery.SeedHostsResolver
- resolveConnectionProfile(ConnectionProfile, ConnectionProfile) - Static method in class org.elasticsearch.transport.ConnectionProfile
-
takes a
ConnectionProfile
resolves it to a fully specified (i.e., no nulls) profile - resolveCustomLocation(String, ShardId) - Method in class org.elasticsearch.env.NodeEnvironment
-
Resolve the custom path for a index's shard.
- resolveCustomLocation(String, ShardId, Path, int) - Static method in class org.elasticsearch.env.NodeEnvironment
- resolveDataPath(Path, int) - Static method in class org.elasticsearch.env.NodeEnvironment
-
Resolve a specific nodes/{node.id} path for the specified path and node lock id.
- resolveDateMathExpression(String) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- resolveDateMathExpression(String, long) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- resolveDefault() - Method in interface org.elasticsearch.common.network.NetworkService.CustomNameResolver
-
Resolves the default value if possible.
- resolveDocumentType(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
Resolves a type from a mapping-related request into the type that should be used when merging and updating mappings.
- resolveExpressions(ClusterState, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Resolve an array of expressions to the set of indices and aliases that these expressions match.
- resolveFieldOnly(MappedFieldType, AggregationContext) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
Special case factory method, intended to be used by aggregations which have some specialized logic for figuring out what field they are operating on, for example Parent and Child join aggregations, which use the join relation to find the field they are reading from rather than a user specified field.
- resolveFormat(String, ValueType, ValuesSourceType) - Static method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
- resolveHosts(List<String>) - Method in interface org.elasticsearch.discovery.SeedHostsProvider.HostsResolver
- resolveHostsLists(CancellableThreads, ExecutorService, Logger, List<String>, TransportService, TimeValue) - Static method in class org.elasticsearch.discovery.SeedHostsResolver
-
Resolves a list of hosts to a list of transport addresses.
- resolveIfPossible(String) - Method in interface org.elasticsearch.common.network.NetworkService.CustomNameResolver
-
Resolves a custom value handling, return
null
if can't handle it. - resolveIndex() - Method in class org.elasticsearch.index.shard.ShardPath
- resolveIndex(AnalyzeAction.Request) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- resolveIndex(GetFieldMappingsIndexRequest) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
- resolveIndex(ResolveIndexAction.Request) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Resolves names and wildcard expressions to indices, aliases, and data streams
- resolveIndex(ResolveIndexAction.Request, ActionListener<ResolveIndexAction.Response>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Resolves names and wildcard expressions to indices, aliases, and data streams
- resolveIndex(ExplainRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- resolveIndex(GetRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
- resolveIndex(MultiGetShardRequest) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- resolveIndex(MultiTermVectorsShardRequest) - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- resolveIndex(TermVectorsRequest) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- resolveIndex(Request) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- resolveIndex(RetentionLeaseActions.RemoveRequest) - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove.TransportAction
- resolveIndexAbstractions(Iterable<String>, IndicesOptions, Metadata, boolean) - Method in class org.elasticsearch.cluster.metadata.IndexAbstractionResolver
- resolveIndexAbstractions(Iterable<String>, IndicesOptions, Metadata, Collection<String>, boolean, boolean) - Method in class org.elasticsearch.cluster.metadata.IndexAbstractionResolver
- resolveIndexAbstractions(String[], IndicesOptions, Metadata, boolean) - Method in class org.elasticsearch.cluster.metadata.IndexAbstractionResolver
- ResolveIndexAction - Class in org.elasticsearch.action.admin.indices.resolve
- ResolveIndexAction.Request - Class in org.elasticsearch.action.admin.indices.resolve
- ResolveIndexAction.ResolvedAlias - Class in org.elasticsearch.action.admin.indices.resolve
- ResolveIndexAction.ResolvedDataStream - Class in org.elasticsearch.action.admin.indices.resolve
- ResolveIndexAction.ResolvedIndex - Class in org.elasticsearch.action.admin.indices.resolve
- ResolveIndexAction.ResolvedIndexAbstraction - Class in org.elasticsearch.action.admin.indices.resolve
- ResolveIndexAction.Response - Class in org.elasticsearch.action.admin.indices.resolve
- ResolveIndexAction.TransportAction - Class in org.elasticsearch.action.admin.indices.resolve
- resolveIndexFolder(String) - Method in class org.elasticsearch.env.NodeEnvironment
-
Resolves all existing paths to
indexFolderName
in ${data.paths}/nodes/{node.id}/indices - resolveIndexId(String) - Method in class org.elasticsearch.repositories.RepositoryData
-
Resolve the index name to the index id specific to the repository, throwing an exception if the index could not be resolved.
- resolveIndexRouting(String, String) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Returns indexing routing for the given index.
- resolveIndices(List<String>) - Method in class org.elasticsearch.repositories.RepositoryData
-
Resolve the given index names to index ids.
- resolveMappingFields(SearchExecutionContext, Map<String, Float>) - Static method in class org.elasticsearch.index.search.QueryParserHelper
- resolveNested(SearchExecutionContext, String, QueryBuilder) - Static method in class org.elasticsearch.search.sort.SortBuilder
- resolveNested(SearchExecutionContext, NestedSortBuilder) - Static method in class org.elasticsearch.search.sort.SortBuilder
- resolveNewIndices(List<String>, Map<String, IndexId>) - Method in class org.elasticsearch.repositories.RepositoryData
-
Resolve the given index names to index ids, creating new index ids for new indices in the repository.
- resolveNode(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Resolve a node with a given id
- resolveNodes(String...) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
-
Resolves a set of nodes according to the given sequence of node specifications.
- resolveNodes(TasksRequest, ClusterState) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
- resolvePipelines(DocWriteRequest<?>, IndexRequest, Metadata) - Static method in class org.elasticsearch.ingest.IngestService
- resolvePipelines(DocWriteRequest<?>, IndexRequest, Metadata, long) - Static method in class org.elasticsearch.ingest.IngestService
- resolvePublishHostAddresses(String[]) - Method in class org.elasticsearch.common.network.NetworkService
-
Resolves
publishHosts
to a single publish address. - ResolverContext() - Constructor for class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.ResolverContext
- ResolverContext(long) - Constructor for class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver.ResolverContext
- resolveRepoFile(String) - Method in class org.elasticsearch.env.Environment
-
Resolves the specified location against the list of configured repository roots If the specified location doesn't match any of the roots, returns null.
- resolveRepoURL(URL) - Method in class org.elasticsearch.env.Environment
-
Checks if the specified URL is pointing to the local file system and if it does, resolves the specified url against the list of configured repository roots If the specified url doesn't match any of the roots, returns null.
- resolveRequest(NodesRequest, ClusterState) - Method in class org.elasticsearch.action.support.nodes.TransportNodesAction
-
resolve node ids to concrete nodes of the incoming request
- resolveRequest(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- resolveRequest(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
- resolveRequest(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- resolveRequest(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- resolveRequest(ClusterState, UpdateRequest) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- resolveRequest(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
-
Resolves the request.
- resolveRequest(IndexMetadata, Request) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Resolves derived values in the request.
- resolveRolloverNames(ClusterState, String, String, CreateIndexRequest) - Method in class org.elasticsearch.action.admin.indices.rollover.MetadataRolloverService
-
Returns the names that rollover would use, but does not perform the actual rollover
- resolveRouting(Metadata) - Method in class org.elasticsearch.action.index.IndexRequest
- resolveSearchRouting(ClusterState, String, String...) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Resolves the search routing if in the expression aliases are used.
- resolveSearchRoutingAllIndices(Metadata, String) - Method in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
-
Sets the same routing for all indices
- resolveSettings(List<IndexTemplateMetadata>) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Resolve index settings for the given list of v1 templates, templates are apply in reverse order since they should be provided in order of priority/order
- resolveSettings(ComposableIndexTemplate, Map<String, ComponentTemplate>) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Resolve the provided v2 template and component templates into a collected
Settings
object - resolveSettings(Metadata, String) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
-
Resolve the given v2 template into a collected
Settings
object - resolveSimilarity(MappingParserContext, String, Object) - Static method in class org.elasticsearch.index.mapper.TypeParsers
- resolveSortPath(AggregationPath.PathElement, Iterator<AggregationPath.PathElement>) - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Resolve a sort path to the target.
- resolveSortPath(AggregationPath.PathElement, Iterator<AggregationPath.PathElement>) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
- resolveSortPath(AggregationPath.PathElement, Iterator<AggregationPath.PathElement>) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- resolveSortPath(AggregationPath.PathElement, Iterator<AggregationPath.PathElement>) - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- resolveSortPathOnValidAgg(AggregationPath.PathElement, Iterator<AggregationPath.PathElement>) - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Resolve the next step of the sort path as though this aggregation supported sorting.
- resolveTemplate(String, String, ClusterState, NamedXContentRegistry, IndicesService, AliasValidator) - Static method in class org.elasticsearch.action.admin.indices.template.post.TransportSimulateIndexTemplateAction
-
Take a template and index name as well as state where the template exists, and return a final
Template
that represents all the resolved Settings, Mappings, and Aliases - resolveTemporaryState(String, String, ClusterState) - Static method in class org.elasticsearch.action.admin.indices.template.post.TransportSimulateIndexTemplateAction
-
Return a temporary cluster state with an index that exists using the matched template's settings
- resolveTopmostAggregator(Aggregator) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
Resolves the Aggregator pointed to by the first element of this path against the given root Aggregator.
- resolveTrackTotalHitsUpTo() - Method in class org.elasticsearch.action.search.SearchRequest
- resolveTrackTotalHitsUpTo(Scroll, SearchSourceBuilder) - Static method in class org.elasticsearch.action.search.SearchRequest
- resolveTranslog() - Method in class org.elasticsearch.index.shard.ShardPath
- resolveTypeVariable(Type, Class<?>, TypeVariable<?>) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
- resolveUnmapped(ValuesSourceType, AggregationContext) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
Convenience method for creating unmapped configs
- resolveUnregistered(AggregationContext, ValueType, String, Script, Object, ZoneId, String, ValuesSourceType) - Static method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
AKA legacy resolve.
- resolveValue(String) - Static method in enum class org.elasticsearch.index.query.RegexpFlag
-
Resolves the combined OR'ed value for the given list of regular expression flags.
- resolveValue(InternalAggregations) - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
-
Looks up the value of this path against a set of aggregation results.
- resolveWriteIndexRouting(String, String) - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Returns indexing routing for the given
aliasOrIndex
. - ResourceAlreadyExistsException - Exception in org.elasticsearch
- ResourceAlreadyExistsException(String, Object...) - Constructor for exception org.elasticsearch.ResourceAlreadyExistsException
- ResourceAlreadyExistsException(StreamInput) - Constructor for exception org.elasticsearch.ResourceAlreadyExistsException
- ResourceAlreadyExistsException(Index) - Constructor for exception org.elasticsearch.ResourceAlreadyExistsException
- ResourceNotFoundException - Exception in org.elasticsearch
-
Generic ResourceNotFoundException corresponding to the
RestStatus.NOT_FOUND
status code - ResourceNotFoundException(String, Object...) - Constructor for exception org.elasticsearch.ResourceNotFoundException
- ResourceNotFoundException(String, Throwable, Object...) - Constructor for exception org.elasticsearch.ResourceNotFoundException
- ResourceNotFoundException(StreamInput) - Constructor for exception org.elasticsearch.ResourceNotFoundException
- ResourceWatcher - Interface in org.elasticsearch.watcher
-
Abstract resource watcher interface.
- ResourceWatcherService - Class in org.elasticsearch.watcher
-
Generic resource watcher service Other elasticsearch services can register their resource watchers with this service using
ResourceWatcherService.add(ResourceWatcher)
method. - ResourceWatcherService(Settings, ThreadPool) - Constructor for class org.elasticsearch.watcher.ResourceWatcherService
- ResourceWatcherService.Frequency - Enum Class in org.elasticsearch.watcher
- response() - Method in interface org.elasticsearch.index.reindex.ScrollableHitSource.AsyncResponse
-
The response data made available.
- Response() - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Response
- Response(boolean, List<ScrollableHitSource.SearchFailure>, long, List<? extends ScrollableHitSource.Hit>, String) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource.Response
- Response(List<AnalyzeAction.AnalyzeToken>, AnalyzeAction.DetailAnalyzeResponse) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Response
- Response(List<ResolveIndexAction.ResolvedIndex>, List<ResolveIndexAction.ResolvedAlias>, List<ResolveIndexAction.ResolvedDataStream>) - Constructor for class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Response
- Response(Map<String, ComponentTemplate>) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Response
- Response(Map<String, ComposableIndexTemplate>) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Response
- Response(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Response
- Response(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Response
- Response(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Response
- Response(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Response
- RESPONSE_PARAMS - Static variable in class org.elasticsearch.rest.action.search.RestSearchAction
- ResponseCollectorService - Class in org.elasticsearch.node
-
Collects statistics about queue size, response time, and service time of tasks executed on each node, making the EWMA of the values available to the coordinating node.
- ResponseCollectorService(ClusterService) - Constructor for class org.elasticsearch.node.ResponseCollectorService
- ResponseCollectorService.ComputedNodeStats - Class in org.elasticsearch.node
-
Struct-like class encapsulating a point-in-time snapshot of a particular node's statistics.
- ResponseHandlerFailureTransportException - Exception in org.elasticsearch.transport
-
A failure to handle the response of a transaction action.
- ResponseHandlerFailureTransportException(Throwable) - Constructor for exception org.elasticsearch.transport.ResponseHandlerFailureTransportException
- ResponseHandlerFailureTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.ResponseHandlerFailureTransportException
- ResponseHandlers() - Constructor for class org.elasticsearch.transport.Transport.ResponseHandlers
- ResponseOrFailure(Exception) - Constructor for class org.elasticsearch.action.search.CanMatchNodeResponse.ResponseOrFailure
- ResponseOrFailure(StreamInput) - Constructor for class org.elasticsearch.action.search.CanMatchNodeResponse.ResponseOrFailure
- ResponseOrFailure(CanMatchShardResponse) - Constructor for class org.elasticsearch.action.search.CanMatchNodeResponse.ResponseOrFailure
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterGetSettingsAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterHealthAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterRerouteAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStateAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterUpdateSettingsAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetRepositoriesAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetSnapshotsAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesInfoAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesStatsAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetComponentTemplateAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetComposableIndexTemplateAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndexTemplateAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndicesAction
-
Parameters used for controlling the response and thus might not be consumed during preparation of the request execution in
BaseRestHandler.prepareRequest(RestRequest, NodeClient)
. - responseParams() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesStatsAction
- responseParams() - Method in class org.elasticsearch.rest.action.admin.indices.RestUpdateSettingsAction
- responseParams() - Method in class org.elasticsearch.rest.action.cat.AbstractCatAction
- responseParams() - Method in class org.elasticsearch.rest.action.cat.RestIndicesAction
- responseParams() - Method in class org.elasticsearch.rest.action.cat.RestTasksAction
- responseParams() - Method in class org.elasticsearch.rest.action.cat.RestThreadPoolAction
- responseParams() - Method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
- responseParams() - Method in class org.elasticsearch.rest.action.search.RestSearchAction
- responseParams() - Method in class org.elasticsearch.rest.action.search.RestSearchScrollAction
- responseParams() - Method in class org.elasticsearch.rest.BaseRestHandler
-
Parameters used for controlling the response and thus might not be consumed during preparation of the request execution in
BaseRestHandler.prepareRequest(RestRequest, NodeClient)
. - responseParams() - Method in class org.elasticsearch.rest.BaseRestHandler.Wrapper
- responseReader - Variable in class org.elasticsearch.action.support.tasks.TransportTasksAction
- responsesDiscarded() - Method in class org.elasticsearch.action.support.NodeResponseTracker
- responsesReader - Variable in class org.elasticsearch.action.support.tasks.TransportTasksAction
- responseTime - Variable in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- REST_DECODER - Static variable in class org.elasticsearch.rest.RestUtils
- REST_EXCEPTION_SKIP_STACK_TRACE - Static variable in exception org.elasticsearch.ElasticsearchException
-
Passed in the
ToXContent.Params
ofElasticsearchException.generateThrowableXContent(XContentBuilder, Params, Throwable)
to control if thestack_trace
element should render. - REST_EXCEPTION_SKIP_STACK_TRACE_DEFAULT - Static variable in exception org.elasticsearch.ElasticsearchException
- RestActionListener<Response> - Class in org.elasticsearch.rest.action
-
An action listener that requires
RestActionListener.processResponse(Object)
to be implemented and will automatically handle failures. - RestActionListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.RestActionListener
- restActions() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
-
Should the node rest actions usage statistics be returned.
- restActions(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
-
Should the node rest actions usage statistics be returned.
- RestActions - Class in org.elasticsearch.rest.action
- RestActions() - Constructor for class org.elasticsearch.rest.action.RestActions
- RestActions.NodesResponseRestListener<NodesResponse extends BaseNodesResponse<?> & ToXContent> - Class in org.elasticsearch.rest.action
-
NodesResponseRestBuilderListener
automatically translates anyBaseNodesResponse
(multi-node) response that isToXContent
-compatible into aRestResponse
with the necessary header info (e.g., "cluster_name"). - RestAddIndexBlockAction - Class in org.elasticsearch.rest.action.admin.indices
- RestAddIndexBlockAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestAddIndexBlockAction
- RestAddVotingConfigExclusionAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestAddVotingConfigExclusionAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestAddVotingConfigExclusionAction
- RestAliasAction - Class in org.elasticsearch.rest.action.cat
- RestAliasAction() - Constructor for class org.elasticsearch.rest.action.cat.RestAliasAction
- RestAllocationAction - Class in org.elasticsearch.rest.action.cat
- RestAllocationAction() - Constructor for class org.elasticsearch.rest.action.cat.RestAllocationAction
- RestAnalyzeAction - Class in org.elasticsearch.rest.action.admin.indices
- RestAnalyzeAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction
- RestAnalyzeIndexDiskUsageAction - Class in org.elasticsearch.rest.action.admin.indices
- RestAnalyzeIndexDiskUsageAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestAnalyzeIndexDiskUsageAction
- restart(DiscoveryNode, String) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- RESTART - Enum constant in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Type
- RestBuilderListener<Response> - Class in org.elasticsearch.rest.action
-
A REST action listener that builds an
XContentBuilder
based response. - RestBuilderListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.RestBuilderListener
- RestBulkAction - Class in org.elasticsearch.rest.action.document
-
{ "index" : { "_index" : "test", "_type" : "type1", "_id" : "1" } { "type1" : { "field1" : "value1" } } { "delete" : { "_index" : "test", "_type" : "type1", "_id" : "2" } } { "create" : { "_index" : "test", "_type" : "type1", "_id" : "1" } { "type1" : { "field1" : "value1" } }
- RestBulkAction(Settings) - Constructor for class org.elasticsearch.rest.action.document.RestBulkAction
- RestCancellableNodeClient - Class in org.elasticsearch.rest.action
-
A Client that cancels tasks executed locally when the provided
HttpChannel
is closed before completion. - RestCancellableNodeClient(NodeClient, HttpChannel) - Constructor for class org.elasticsearch.rest.action.RestCancellableNodeClient
- RestCancelTasksAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestCancelTasksAction(Supplier<DiscoveryNodes>) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestCancelTasksAction
- RestCatAction - Class in org.elasticsearch.rest.action.cat
- RestCatAction(List<AbstractCatAction>) - Constructor for class org.elasticsearch.rest.action.cat.RestCatAction
- RestCatRecoveryAction - Class in org.elasticsearch.rest.action.cat
-
RestRecoveryAction provides information about the status of replica recovery in a string format, designed to be used at the command line.
- RestCatRecoveryAction() - Constructor for class org.elasticsearch.rest.action.cat.RestCatRecoveryAction
- RestChannel - Interface in org.elasticsearch.rest
-
A channel used to construct bytes / builder based outputs, and send responses.
- RestCleanupRepositoryAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Cleans up a repository
- RestCleanupRepositoryAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestCleanupRepositoryAction
- RestClearIndicesCacheAction - Class in org.elasticsearch.rest.action.admin.indices
- RestClearIndicesCacheAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestClearIndicesCacheAction
- RestClearScrollAction - Class in org.elasticsearch.rest.action.search
- RestClearScrollAction() - Constructor for class org.elasticsearch.rest.action.search.RestClearScrollAction
- RestClearVotingConfigExclusionsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClearVotingConfigExclusionsAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClearVotingConfigExclusionsAction
- RestCloneIndexAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestCloneIndexAction
- RestCloneSnapshotAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Clones indices from one snapshot into another snapshot in the same repository
- RestCloneSnapshotAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestCloneSnapshotAction
- RestCloseIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestCloseIndexAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestCloseIndexAction
- RestClosePointInTimeAction - Class in org.elasticsearch.action.search
- RestClosePointInTimeAction() - Constructor for class org.elasticsearch.action.search.RestClosePointInTimeAction
- RestClusterAllocationExplainAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Class handling cluster allocation explanation at the REST level
- RestClusterAllocationExplainAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterAllocationExplainAction
- RestClusterGetSettingsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterGetSettingsAction(Settings, ClusterSettings, SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterGetSettingsAction
- RestClusterHealthAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterHealthAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterHealthAction
- RestClusterRerouteAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterRerouteAction(SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterRerouteAction
- RestClusterSearchShardsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterSearchShardsAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterSearchShardsAction
- RestClusterStateAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterStateAction(SettingsFilter, ThreadPool) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterStateAction
- RestClusterStatsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterStatsAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterStatsAction
- RestClusterUpdateSettingsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestClusterUpdateSettingsAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestClusterUpdateSettingsAction
- RestController - Class in org.elasticsearch.rest
- RestController(Set<RestHeaderDefinition>, UnaryOperator<RestHandler>, NodeClient, CircuitBreakerService, UsageService) - Constructor for class org.elasticsearch.rest.RestController
- RestCountAction - Class in org.elasticsearch.rest.action.cat
- RestCountAction - Class in org.elasticsearch.rest.action.search
- RestCountAction() - Constructor for class org.elasticsearch.rest.action.cat.RestCountAction
- RestCountAction() - Constructor for class org.elasticsearch.rest.action.search.RestCountAction
- RestCreateIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestCreateIndexAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestCreateIndexAction
- RestCreateSnapshotAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Creates a new snapshot
- RestCreateSnapshotAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestCreateSnapshotAction
- RestDeleteAction - Class in org.elasticsearch.rest.action.document
- RestDeleteAction() - Constructor for class org.elasticsearch.rest.action.document.RestDeleteAction
- RestDeleteComponentTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
- RestDeleteComponentTemplateAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestDeleteComponentTemplateAction
- RestDeleteComposableIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
- RestDeleteComposableIndexTemplateAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestDeleteComposableIndexTemplateAction
- RestDeleteDanglingIndexAction - Class in org.elasticsearch.rest.action.admin.cluster.dangling
- RestDeleteDanglingIndexAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.dangling.RestDeleteDanglingIndexAction
- RestDeleteIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestDeleteIndexAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexAction
- RestDeleteIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
- RestDeleteIndexTemplateAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexTemplateAction
- RestDeletePipelineAction - Class in org.elasticsearch.rest.action.ingest
- RestDeletePipelineAction() - Constructor for class org.elasticsearch.rest.action.ingest.RestDeletePipelineAction
- RestDeleteRepositoryAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Unregisters a repository
- RestDeleteRepositoryAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestDeleteRepositoryAction
- RestDeleteSnapshotAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Deletes a snapshot
- RestDeleteSnapshotAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestDeleteSnapshotAction
- RestDeleteStoredScriptAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestDeleteStoredScriptAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestDeleteStoredScriptAction
- RestExplainAction - Class in org.elasticsearch.rest.action.search
-
Rest action for computing a score explanation for specific documents.
- RestExplainAction() - Constructor for class org.elasticsearch.rest.action.search.RestExplainAction
- RestFieldCapabilitiesAction - Class in org.elasticsearch.rest.action
- RestFieldCapabilitiesAction() - Constructor for class org.elasticsearch.rest.action.RestFieldCapabilitiesAction
- RestFielddataAction - Class in org.elasticsearch.rest.action.cat
-
Cat API class to display information about the size of fielddata fields per node
- RestFielddataAction() - Constructor for class org.elasticsearch.rest.action.cat.RestFielddataAction
- RestFieldUsageStatsAction - Class in org.elasticsearch.rest.action.admin.indices
- RestFieldUsageStatsAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestFieldUsageStatsAction
- RestFlushAction - Class in org.elasticsearch.rest.action.admin.indices
- RestFlushAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestFlushAction
- RestForceMergeAction - Class in org.elasticsearch.rest.action.admin.indices
- RestForceMergeAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestForceMergeAction
- RestGetAction - Class in org.elasticsearch.rest.action.document
- RestGetAction() - Constructor for class org.elasticsearch.rest.action.document.RestGetAction
- RestGetAliasesAction - Class in org.elasticsearch.rest.action.admin.indices
-
The REST handler for get alias and head alias APIs.
- RestGetAliasesAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetAliasesAction
- RestGetComponentTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
- RestGetComponentTemplateAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetComponentTemplateAction
- RestGetComposableIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
- RestGetComposableIndexTemplateAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetComposableIndexTemplateAction
- RestGetFeatureUpgradeStatusAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Endpoint for getting the system feature upgrade status
- RestGetFeatureUpgradeStatusAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestGetFeatureUpgradeStatusAction
- RestGetFieldMappingAction - Class in org.elasticsearch.rest.action.admin.indices
- RestGetFieldMappingAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetFieldMappingAction
- RestGetIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
-
The REST handler for get template and head template APIs.
- RestGetIndexTemplateAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetIndexTemplateAction
- RestGetIndicesAction - Class in org.elasticsearch.rest.action.admin.indices
-
The REST handler for get index and head index APIs.
- RestGetIndicesAction(ThreadPool) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetIndicesAction
- RestGetMappingAction - Class in org.elasticsearch.rest.action.admin.indices
- RestGetMappingAction(ThreadPool) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetMappingAction
- RestGetPipelineAction - Class in org.elasticsearch.rest.action.ingest
- RestGetPipelineAction() - Constructor for class org.elasticsearch.rest.action.ingest.RestGetPipelineAction
- RestGetRepositoriesAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Returns repository information
- RestGetRepositoriesAction(SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestGetRepositoriesAction
- RestGetScriptContextAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestGetScriptContextAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestGetScriptContextAction
- RestGetScriptLanguageAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestGetScriptLanguageAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestGetScriptLanguageAction
- RestGetSettingsAction - Class in org.elasticsearch.rest.action.admin.indices
- RestGetSettingsAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestGetSettingsAction
- RestGetSnapshotsAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Returns information about snapshot
- RestGetSnapshotsAction(ThreadPool) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestGetSnapshotsAction
- RestGetSourceAction - Class in org.elasticsearch.rest.action.document
-
The REST handler for get source and head source APIs.
- RestGetSourceAction() - Constructor for class org.elasticsearch.rest.action.document.RestGetSourceAction
- RestGetStoredScriptAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestGetStoredScriptAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestGetStoredScriptAction
- RestGetTaskAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestGetTaskAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestGetTaskAction
- RestHandler - Interface in org.elasticsearch.rest
-
Handler for REST requests
- RestHandler.Route - Class in org.elasticsearch.rest
- RestHandler.Route.RouteBuilder - Class in org.elasticsearch.rest
- RestHeaderDefinition - Class in org.elasticsearch.rest
-
A definition for an http header that should be copied to the
ThreadContext
when reading the request on the rest layer. - RestHeaderDefinition(String, boolean) - Constructor for class org.elasticsearch.rest.RestHeaderDefinition
- RestHealthAction - Class in org.elasticsearch.rest.action.cat
- RestHealthAction() - Constructor for class org.elasticsearch.rest.action.cat.RestHealthAction
- RestImportDanglingIndexAction - Class in org.elasticsearch.rest.action.admin.cluster.dangling
- RestImportDanglingIndexAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.dangling.RestImportDanglingIndexAction
- RestIndexAction - Class in org.elasticsearch.rest.action.document
- RestIndexAction() - Constructor for class org.elasticsearch.rest.action.document.RestIndexAction
- RestIndexAction.AutoIdHandler - Class in org.elasticsearch.rest.action.document
- RestIndexAction.CreateHandler - Class in org.elasticsearch.rest.action.document
- RestIndexDeleteAliasesAction - Class in org.elasticsearch.rest.action.admin.indices
- RestIndexDeleteAliasesAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestIndexDeleteAliasesAction
- RestIndexPutAliasAction - Class in org.elasticsearch.rest.action.admin.indices
- RestIndexPutAliasAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestIndexPutAliasAction
- RestIndicesAction - Class in org.elasticsearch.rest.action.cat
- RestIndicesAction() - Constructor for class org.elasticsearch.rest.action.cat.RestIndicesAction
- RestIndicesAliasesAction - Class in org.elasticsearch.rest.action.admin.indices
- RestIndicesAliasesAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestIndicesAliasesAction
- RestIndicesSegmentsAction - Class in org.elasticsearch.rest.action.admin.indices
- RestIndicesSegmentsAction(ThreadPool) - Constructor for class org.elasticsearch.rest.action.admin.indices.RestIndicesSegmentsAction
- RestIndicesShardStoresAction - Class in org.elasticsearch.rest.action.admin.indices
-
Rest action for
IndicesShardStoresAction
- RestIndicesShardStoresAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestIndicesShardStoresAction
- RestIndicesStatsAction - Class in org.elasticsearch.rest.action.admin.indices
- RestIndicesStatsAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestIndicesStatsAction
- RestListDanglingIndicesAction - Class in org.elasticsearch.rest.action.admin.cluster.dangling
- RestListDanglingIndicesAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.dangling.RestListDanglingIndicesAction
- RestListTasksAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestListTasksAction(Supplier<DiscoveryNodes>) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestListTasksAction
- RestMainAction - Class in org.elasticsearch.rest.action
- RestMainAction() - Constructor for class org.elasticsearch.rest.action.RestMainAction
- RestMasterAction - Class in org.elasticsearch.rest.action.cat
- RestMasterAction() - Constructor for class org.elasticsearch.rest.action.cat.RestMasterAction
- RestModifyDataStreamsAction - Class in org.elasticsearch.rest.action.datastreams
- RestModifyDataStreamsAction() - Constructor for class org.elasticsearch.rest.action.datastreams.RestModifyDataStreamsAction
- RestMultiGetAction - Class in org.elasticsearch.rest.action.document
- RestMultiGetAction(Settings) - Constructor for class org.elasticsearch.rest.action.document.RestMultiGetAction
- RestMultiSearchAction - Class in org.elasticsearch.rest.action.search
- RestMultiSearchAction(Settings) - Constructor for class org.elasticsearch.rest.action.search.RestMultiSearchAction
- RestMultiTermVectorsAction - Class in org.elasticsearch.rest.action.document
- RestMultiTermVectorsAction() - Constructor for class org.elasticsearch.rest.action.document.RestMultiTermVectorsAction
- RestNodeAttrsAction - Class in org.elasticsearch.rest.action.cat
- RestNodeAttrsAction() - Constructor for class org.elasticsearch.rest.action.cat.RestNodeAttrsAction
- RestNodesAction - Class in org.elasticsearch.rest.action.cat
- RestNodesAction() - Constructor for class org.elasticsearch.rest.action.cat.RestNodesAction
- RestNodesHotThreadsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestNodesHotThreadsAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestNodesHotThreadsAction
- RestNodesInfoAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestNodesInfoAction(SettingsFilter) - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestNodesInfoAction
- RestNodesStatsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestNodesStatsAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestNodesStatsAction
- RestNodesUsageAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestNodesUsageAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestNodesUsageAction
- RestOpenIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestOpenIndexAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestOpenIndexAction
- RestOpenPointInTimeAction - Class in org.elasticsearch.action.search
- RestOpenPointInTimeAction() - Constructor for class org.elasticsearch.action.search.RestOpenPointInTimeAction
- restorable() - Method in enum class org.elasticsearch.snapshots.SnapshotState
-
Returns true if snapshot can be restored (at least partially)
- restore() - Method in interface org.elasticsearch.common.util.concurrent.ThreadContext.StoredContext
- restore(SnapshotFiles, Store, ActionListener<Void>) - Method in class org.elasticsearch.repositories.blobstore.FileRestoreContext
-
Performs restore operation
- RESTORE_FILE_FROM_SNAPSHOT - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- RestoreClusterStateListener - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
- restoreFileFromSnapshot(String, IndexId, BlobStoreIndexShardSnapshot.FileInfo, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- restoreFileFromSnapshot(String, IndexId, BlobStoreIndexShardSnapshot.FileInfo, ActionListener<Void>) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
Restores a snapshot file in the target store
- restoreFileFromSnapshot(String, IndexId, BlobStoreIndexShardSnapshot.FileInfo, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- restoreFiles(List<BlobStoreIndexShardSnapshot.FileInfo>, Store, ActionListener<Void>) - Method in class org.elasticsearch.repositories.blobstore.FileRestoreContext
-
Restores given list of
BlobStoreIndexShardSnapshot.FileInfo
to the givenStore
. - restoreFromRepository(Repository, ActionListener<Boolean>) - Method in class org.elasticsearch.index.shard.IndexShard
- RestoreInfo - Class in org.elasticsearch.snapshots
-
Information about successfully completed restore operation.
- RestoreInfo(String, List<String>, int, int) - Constructor for class org.elasticsearch.snapshots.RestoreInfo
- RestoreInfo(StreamInput) - Constructor for class org.elasticsearch.snapshots.RestoreInfo
- restoreInProgress(ClusterState, String) - Static method in class org.elasticsearch.snapshots.RestoreService
- RestoreInProgress - Class in org.elasticsearch.cluster
-
Meta data about restore processes that are currently executing
- RestoreInProgress(StreamInput) - Constructor for class org.elasticsearch.cluster.RestoreInProgress
- RestoreInProgress.Builder - Class in org.elasticsearch.cluster
- RestoreInProgress.Entry - Class in org.elasticsearch.cluster
-
Restore metadata
- RestoreInProgress.ShardRestoreStatus - Class in org.elasticsearch.cluster
-
Represents status of a restored shard
- RestoreInProgress.State - Enum Class in org.elasticsearch.cluster
-
Shard restore process state
- RestoreInProgressAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This
AllocationDecider
prevents shards that have failed to be restored from a snapshot to be allocated. - RestoreInProgressAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.RestoreInProgressAllocationDecider
- RestoreInProgressUpdater() - Constructor for class org.elasticsearch.snapshots.RestoreService.RestoreInProgressUpdater
- restoreLocalHistoryFromTranslog(Engine.TranslogRecoveryRunner) - Method in class org.elasticsearch.index.engine.Engine
-
This method replays translog to restore the Lucene index which might be reverted previously.
- restoreLocalHistoryFromTranslog(Engine.TranslogRecoveryRunner) - Method in class org.elasticsearch.index.engine.InternalEngine
- restoreLocalHistoryFromTranslog(Engine.TranslogRecoveryRunner) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- RestoreService - Class in org.elasticsearch.snapshots
-
Service responsible for restoring snapshots
- RestoreService(ClusterService, RepositoriesService, AllocationService, MetadataCreateIndexService, MetadataDeleteIndexService, IndexMetadataVerifier, ShardLimitValidator, SystemIndices) - Constructor for class org.elasticsearch.snapshots.RestoreService
- RestoreService.RestoreCompletionResponse - Class in org.elasticsearch.snapshots
- RestoreService.RestoreInProgressUpdater - Class in org.elasticsearch.snapshots
- restoreShard(Store, SnapshotId, IndexId, ShardId, RecoveryState, ActionListener<Void>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- restoreShard(Store, SnapshotId, IndexId, ShardId, RecoveryState, ActionListener<Void>) - Method in class org.elasticsearch.repositories.FilterRepository
- restoreShard(Store, SnapshotId, IndexId, ShardId, RecoveryState, ActionListener<Void>) - Method in interface org.elasticsearch.repositories.Repository
-
Restores snapshot of the shard.
- restoreSnapshot(RestoreSnapshotRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Restores a snapshot.
- restoreSnapshot(RestoreSnapshotRequest, ActionListener<RestoreSnapshotResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Restores a snapshot.
- restoreSnapshot(RestoreSnapshotRequest, ActionListener<RestoreService.RestoreCompletionResponse>) - Method in class org.elasticsearch.snapshots.RestoreService
-
Restores snapshot specified in the restore request.
- restoreSnapshot(RestoreSnapshotRequest, ActionListener<RestoreService.RestoreCompletionResponse>, BiConsumer<ClusterState, Metadata.Builder>) - Method in class org.elasticsearch.snapshots.RestoreService
-
Restores snapshot specified in the restore request.
- RestoreSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
-
Restore snapshot action
- restoreSnapshotRequest(String, String) - Static method in class org.elasticsearch.client.Requests
-
Restores new snapshot
- RestoreSnapshotRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
-
Restore snapshot request
- RestoreSnapshotRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- RestoreSnapshotRequest(String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Constructs a new put repository request with the provided repository and snapshot names.
- RestoreSnapshotRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- RestoreSnapshotRequestBuilder - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
-
Restore snapshot request builder
- RestoreSnapshotRequestBuilder(ElasticsearchClient, RestoreSnapshotAction) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Constructs new restore snapshot request builder
- RestoreSnapshotRequestBuilder(ElasticsearchClient, RestoreSnapshotAction, String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Constructs new restore snapshot request builder with specified repository and snapshot names
- RestoreSnapshotResponse - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
-
Contains information about restores snapshot
- RestoreSnapshotResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- RestoreSnapshotResponse(RestoreInfo) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- restoreUUID() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- restoringIndices(ClusterState, Set<Index>) - Static method in class org.elasticsearch.snapshots.RestoreService
-
Returns the indices that are currently being restored and that are contained in the indices-to-check set.
- RestPendingClusterTasksAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestPendingClusterTasksAction - Class in org.elasticsearch.rest.action.cat
- RestPendingClusterTasksAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestPendingClusterTasksAction
- RestPendingClusterTasksAction() - Constructor for class org.elasticsearch.rest.action.cat.RestPendingClusterTasksAction
- RestPluginsAction - Class in org.elasticsearch.rest.action.cat
- RestPluginsAction() - Constructor for class org.elasticsearch.rest.action.cat.RestPluginsAction
- RestPostFeatureUpgradeAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Endpoint for triggering a system feature upgrade
- RestPostFeatureUpgradeAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestPostFeatureUpgradeAction
- RestPutComponentTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
- RestPutComponentTemplateAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestPutComponentTemplateAction
- RestPutComposableIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
- RestPutComposableIndexTemplateAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestPutComposableIndexTemplateAction
- RestPutIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
- RestPutIndexTemplateAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestPutIndexTemplateAction
- RestPutMappingAction - Class in org.elasticsearch.rest.action.admin.indices
- RestPutMappingAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestPutMappingAction
- RestPutPipelineAction - Class in org.elasticsearch.rest.action.ingest
- RestPutPipelineAction() - Constructor for class org.elasticsearch.rest.action.ingest.RestPutPipelineAction
- RestPutRepositoryAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Registers repositories
- RestPutRepositoryAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestPutRepositoryAction
- RestPutStoredScriptAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestPutStoredScriptAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestPutStoredScriptAction
- RestRecoveryAction - Class in org.elasticsearch.rest.action.admin.indices
-
REST handler to report on index recoveries.
- RestRecoveryAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestRecoveryAction
- RestRefreshAction - Class in org.elasticsearch.rest.action.admin.indices
- RestRefreshAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestRefreshAction
- RestReloadSecureSettingsAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestReloadSecureSettingsAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestReloadSecureSettingsAction
- RestRemoteClusterInfoAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestRemoteClusterInfoAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestRemoteClusterInfoAction
- RestRepositoriesAction - Class in org.elasticsearch.rest.action.cat
-
Cat API class to display information about snapshot repositories
- RestRepositoriesAction() - Constructor for class org.elasticsearch.rest.action.cat.RestRepositoriesAction
- RestRequest - Class in org.elasticsearch.rest
- RestRequest(RestRequest) - Constructor for class org.elasticsearch.rest.RestRequest
- RestRequest(NamedXContentRegistry, Map<String, String>, String, Map<String, List<String>>, HttpRequest, HttpChannel) - Constructor for class org.elasticsearch.rest.RestRequest
- RestRequest.BadParameterException - Exception in org.elasticsearch.rest
- RestRequest.ContentTypeHeaderException - Exception in org.elasticsearch.rest
- RestRequest.Method - Enum Class in org.elasticsearch.rest
- RestRequestFilter - Interface in org.elasticsearch.rest
-
Identifies an object that supplies a filter for the content of a
RestRequest
. - RestResetFeatureStateAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Rest handler for feature state reset requests
- RestResetFeatureStateAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestResetFeatureStateAction
- RestResizeHandler - Class in org.elasticsearch.rest.action.admin.indices
- RestResizeHandler.RestCloneIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestResizeHandler.RestShrinkIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestResizeHandler.RestSplitIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestResolveIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestResolveIndexAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestResolveIndexAction
- RestResponse - Class in org.elasticsearch.rest
- RestResponse() - Constructor for class org.elasticsearch.rest.RestResponse
- RestResponseListener<Response> - Class in org.elasticsearch.rest.action
-
A REST enabled action listener that has a basic onFailure implementation, and requires sub classes to only implement
RestResponseListener.buildResponse(Object)
. - RestResponseListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.RestResponseListener
- RestRestoreSnapshotAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Restores a snapshot
- RestRestoreSnapshotAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestRestoreSnapshotAction
- RESTRICTED - Enum constant in enum class org.elasticsearch.indices.SystemIndices.SystemIndexAccessLevel
- restrictedEnumParam(String, boolean, Function<FieldMapper, T>, T, Class<T>, Set<T>) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Defines a parameter that takes one of a restricted set of values from an enumeration.
- restrictedStringParam(String, boolean, Function<FieldMapper, String>, String...) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Defines a parameter that takes one of a restricted set of string values
- RestRolloverIndexAction - Class in org.elasticsearch.rest.action.admin.indices
- RestRolloverIndexAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestRolloverIndexAction
- RestSearchAction - Class in org.elasticsearch.rest.action.search
- RestSearchAction() - Constructor for class org.elasticsearch.rest.action.search.RestSearchAction
- RestSearchScrollAction - Class in org.elasticsearch.rest.action.search
- RestSearchScrollAction() - Constructor for class org.elasticsearch.rest.action.search.RestSearchScrollAction
- RestSegmentsAction - Class in org.elasticsearch.rest.action.cat
- RestSegmentsAction() - Constructor for class org.elasticsearch.rest.action.cat.RestSegmentsAction
- RestShardsAction - Class in org.elasticsearch.rest.action.cat
- RestShardsAction() - Constructor for class org.elasticsearch.rest.action.cat.RestShardsAction
- RestShrinkIndexAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestShrinkIndexAction
- RestSimulateIndexTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
- RestSimulateIndexTemplateAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestSimulateIndexTemplateAction
- RestSimulatePipelineAction - Class in org.elasticsearch.rest.action.ingest
- RestSimulatePipelineAction() - Constructor for class org.elasticsearch.rest.action.ingest.RestSimulatePipelineAction
- RestSimulateTemplateAction - Class in org.elasticsearch.rest.action.admin.indices
- RestSimulateTemplateAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestSimulateTemplateAction
- RestSnapshotAction - Class in org.elasticsearch.rest.action.cat
-
Cat API class to display information about snapshots
- RestSnapshotAction() - Constructor for class org.elasticsearch.rest.action.cat.RestSnapshotAction
- RestSnapshotsStatusAction - Class in org.elasticsearch.rest.action.admin.cluster
-
Returns status of currently running snapshot
- RestSnapshotsStatusAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestSnapshotsStatusAction
- RestSnapshottableFeaturesAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestSnapshottableFeaturesAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestSnapshottableFeaturesAction
- RestSplitIndexAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestSplitIndexAction
- restStatus() - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
- RestStatus - Enum Class in org.elasticsearch.rest
- RestStatusToXContentListener<Response extends StatusToXContentObject> - Class in org.elasticsearch.rest.action
-
Content listener that extracts that
RestStatus
from the response. - RestStatusToXContentListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.RestStatusToXContentListener
-
Build an instance that doesn't support responses with the status
201 CREATED
. - RestStatusToXContentListener(RestChannel, Function<Response, String>) - Constructor for class org.elasticsearch.rest.action.RestStatusToXContentListener
-
Build an instance that does support responses with the status
201 CREATED
. - RestSyncedFlushAction - Class in org.elasticsearch.rest.action.admin.indices
- RestSyncedFlushAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestSyncedFlushAction
- RestTable - Class in org.elasticsearch.rest.action.cat
- RestTable() - Constructor for class org.elasticsearch.rest.action.cat.RestTable
- RestTasksAction - Class in org.elasticsearch.rest.action.cat
- RestTasksAction(Supplier<DiscoveryNodes>) - Constructor for class org.elasticsearch.rest.action.cat.RestTasksAction
- RestTemplatesAction - Class in org.elasticsearch.rest.action.cat
- RestTemplatesAction() - Constructor for class org.elasticsearch.rest.action.cat.RestTemplatesAction
- RestTermVectorsAction - Class in org.elasticsearch.rest.action.document
-
This class parses the json request and translates it into a TermVectorsRequest.
- RestTermVectorsAction() - Constructor for class org.elasticsearch.rest.action.document.RestTermVectorsAction
- RestThreadPoolAction - Class in org.elasticsearch.rest.action.cat
- RestThreadPoolAction() - Constructor for class org.elasticsearch.rest.action.cat.RestThreadPoolAction
- RestToXContentListener<Response extends ToXContentObject> - Class in org.elasticsearch.rest.action
-
A REST based action listener that requires the response to implement
ToXContentObject
and automatically builds an XContent based response. - RestToXContentListener(RestChannel) - Constructor for class org.elasticsearch.rest.action.RestToXContentListener
- RestUpdateAction - Class in org.elasticsearch.rest.action.document
- RestUpdateAction() - Constructor for class org.elasticsearch.rest.action.document.RestUpdateAction
- RestUpdateSettingsAction - Class in org.elasticsearch.rest.action.admin.indices
- RestUpdateSettingsAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestUpdateSettingsAction
- RestUpgradeActionDeprecated - Class in org.elasticsearch.rest.action.admin.indices
- RestUpgradeActionDeprecated() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestUpgradeActionDeprecated
- RestUpgradeStatusActionDeprecated - Class in org.elasticsearch.rest.action.admin.indices
- RestUpgradeStatusActionDeprecated() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestUpgradeStatusActionDeprecated
- RestUtils - Class in org.elasticsearch.rest
- RestUtils() - Constructor for class org.elasticsearch.rest.RestUtils
- RestValidateQueryAction - Class in org.elasticsearch.rest.action.admin.indices
- RestValidateQueryAction() - Constructor for class org.elasticsearch.rest.action.admin.indices.RestValidateQueryAction
- RestVerifyRepositoryAction - Class in org.elasticsearch.rest.action.admin.cluster
- RestVerifyRepositoryAction() - Constructor for class org.elasticsearch.rest.action.admin.cluster.RestVerifyRepositoryAction
- result - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- result - Variable in class org.elasticsearch.action.DocWriteResponse
- result() - Method in class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryResponse
- result() - Method in class org.elasticsearch.action.StepListener
-
Gets the result of this step.
- result() - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- result(DiscoveryNode, Exception) - Method in class org.elasticsearch.tasks.Task
- result(DiscoveryNode, ActionResponse) - Method in class org.elasticsearch.tasks.Task
- Result(Condition<?>, boolean) - Constructor for class org.elasticsearch.action.admin.indices.rollover.Condition.Result
- Result(Writeable, DocWriteResponse.Result, Map<String, Object>, XContentType) - Constructor for class org.elasticsearch.action.update.UpdateHelper.Result
- Result(Engine.Operation.TYPE, long, long, long) - Constructor for class org.elasticsearch.index.engine.Engine.Result
- Result(Engine.Operation.TYPE, Exception, long, long, long) - Constructor for class org.elasticsearch.index.engine.Engine.Result
- Result(Engine.Operation.TYPE, Mapping) - Constructor for class org.elasticsearch.index.engine.Engine.Result
- ResultDeduplicator<T,
R> - Class in org.elasticsearch.action -
Deduplicator for arbitrary keys and results that can be used to ensure a given action is only executed once at a time for a given request.
- ResultDeduplicator() - Constructor for class org.elasticsearch.action.ResultDeduplicator
- resultingState - Variable in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult
- ResultsDiff(StreamInput) - Constructor for class org.elasticsearch.upgrades.FeatureMigrationResults.ResultsDiff
- ResultsDiff(FeatureMigrationResults, FeatureMigrationResults) - Constructor for class org.elasticsearch.upgrades.FeatureMigrationResults.ResultsDiff
- resultsForDoc(int) - Method in class org.elasticsearch.script.StringFieldScript
-
Execute the script for the provided
docId
. - resultStrategy - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- resume() - Method in class org.elasticsearch.watcher.WatcherHandle
- resync(IndexShard, ActionListener<PrimaryReplicaSyncer.ResyncTask>) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer
- ResyncReplicationRequest - Class in org.elasticsearch.action.resync
-
Represents a batch of operations sent from the primary to its replicas during the primary-replica resync.
- ResyncReplicationRequest(ShardId, long, long, Translog.Operation[]) - Constructor for class org.elasticsearch.action.resync.ResyncReplicationRequest
- ResyncReplicationResponse - Class in org.elasticsearch.action.resync
- ResyncReplicationResponse() - Constructor for class org.elasticsearch.action.resync.ResyncReplicationResponse
- ResyncReplicationResponse(StreamInput) - Constructor for class org.elasticsearch.action.resync.ResyncReplicationResponse
- ResyncRequest(ShardId, String) - Constructor for class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncRequest
- ResyncTask(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
- retain() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- RETAIN_ALL - Static variable in class org.elasticsearch.index.seqno.RetentionLeaseActions
- retainAll(Collection<?>) - Method in class org.elasticsearch.common.collect.EvictingQueue
- retainedSlice(int, int) - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- retainIndicesAndPruneDeletes(Set<IndexId>) - Method in class org.elasticsearch.repositories.ShardGenerations.Builder
-
Filters out all generations that don't belong to any of the supplied
indices
and prunes allShardGenerations.DELETED_SHARD_GEN
entries from the builder. - retainingSequenceNumber() - Method in class org.elasticsearch.index.seqno.RetentionLease
-
The retaining sequence number of this retention lease.
- RETENTION_LEASE_SYNC_INTERVAL_SETTING - Static variable in class org.elasticsearch.index.IndexService
- RetentionLease - Class in org.elasticsearch.index.seqno
-
A "shard history retention lease" (or "retention lease" for short) is conceptually a marker containing a retaining sequence number such that all operations with sequence number at least that retaining sequence number will be retained during merge operations (which could otherwise merge away operations that have been soft deleted).
- RetentionLease(String, long, long, String) - Constructor for class org.elasticsearch.index.seqno.RetentionLease
-
Constructs a new retention lease.
- RetentionLease(StreamInput) - Constructor for class org.elasticsearch.index.seqno.RetentionLease
-
Constructs a new retention lease from a stream.
- RetentionLeaseActions - Class in org.elasticsearch.index.seqno
-
This class holds all actions related to retention leases.
- RetentionLeaseActions() - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions
- RetentionLeaseActions.Add - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.Add.TransportAction - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.AddRequest - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.Remove - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.Remove.TransportAction - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.RemoveRequest - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.Renew - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.Renew.TransportAction - Class in org.elasticsearch.index.seqno
- RetentionLeaseActions.RenewRequest - Class in org.elasticsearch.index.seqno
- RetentionLeaseAlreadyExistsException - Exception in org.elasticsearch.index.seqno
- RetentionLeaseAlreadyExistsException(String) - Constructor for exception org.elasticsearch.index.seqno.RetentionLeaseAlreadyExistsException
- RetentionLeaseAlreadyExistsException(StreamInput) - Constructor for exception org.elasticsearch.index.seqno.RetentionLeaseAlreadyExistsException
- RetentionLeaseBackgroundSyncAction - Class in org.elasticsearch.index.seqno
-
Replication action responsible for background syncing retention leases to replicas.
- RetentionLeaseBackgroundSyncAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- RetentionLeaseBackgroundSyncAction.Request - Class in org.elasticsearch.index.seqno
- RetentionLeaseInvalidRetainingSeqNoException - Exception in org.elasticsearch.index.seqno
- RetentionLeaseInvalidRetainingSeqNoException(StreamInput) - Constructor for exception org.elasticsearch.index.seqno.RetentionLeaseInvalidRetainingSeqNoException
- RetentionLeaseNotFoundException - Exception in org.elasticsearch.index.seqno
- RetentionLeaseNotFoundException(String) - Constructor for exception org.elasticsearch.index.seqno.RetentionLeaseNotFoundException
- RetentionLeaseNotFoundException(StreamInput) - Constructor for exception org.elasticsearch.index.seqno.RetentionLeaseNotFoundException
- retentionLeases() - Method in class org.elasticsearch.index.seqno.RetentionLeaseStats
-
The underlying retention lease collection backing this stats object.
- retentionLeases() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- RetentionLeases - Class in org.elasticsearch.index.seqno
-
Represents a versioned collection of retention leases.
- RetentionLeases(long, long, Collection<RetentionLease>) - Constructor for class org.elasticsearch.index.seqno.RetentionLeases
-
Constructs a new retention lease collection with the specified version and underlying collection of retention leases.
- RetentionLeases(StreamInput) - Constructor for class org.elasticsearch.index.seqno.RetentionLeases
-
Constructs a new retention lease collection from a stream.
- retentionLeasesSupplier() - Method in class org.elasticsearch.index.engine.EngineConfig
-
A supplier of the outstanding retention leases.
- RetentionLeaseStats - Class in org.elasticsearch.index.seqno
-
Represents retention lease stats.
- RetentionLeaseStats(StreamInput) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseStats
-
Constructs a new retention lease stats object from a stream.
- RetentionLeaseStats(RetentionLeases) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseStats
-
Constructs a new retention lease stats object from the specified retention lease collection.
- RetentionLeaseSyncAction - Class in org.elasticsearch.index.seqno
-
Write action responsible for syncing retention leases to replicas.
- RetentionLeaseSyncAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexingPressure, SystemIndices) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseSyncAction
- RetentionLeaseSyncAction.Request - Class in org.elasticsearch.index.seqno
- RetentionLeaseSyncAction.Response - Class in org.elasticsearch.index.seqno
- RetentionLeaseSyncer - Class in org.elasticsearch.index.seqno
- RetentionLeaseSyncer(RetentionLeaseSyncAction, RetentionLeaseBackgroundSyncAction) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseSyncer
- RetentionLeaseSyncer(RetentionLeaseSyncer.SyncAction, RetentionLeaseSyncer.BackgroundSyncAction) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseSyncer
- RetentionLeaseSyncer.BackgroundSyncAction - Interface in org.elasticsearch.index.seqno
-
Represents an action that is invoked periodically to sync retention leases to replica shards after some retention lease has been renewed or expired.
- RetentionLeaseSyncer.SyncAction - Interface in org.elasticsearch.index.seqno
-
Represents an action that is invoked to sync retention leases to replica shards after a retention lease is added or removed on the primary.
- rethrottle(float) - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
-
Apply
newRequestsPerSecond
as the new rate limit for this task's search requests - rethrowAndSuppress(List<T>) - Static method in class org.elasticsearch.ExceptionsHelper
-
Rethrows the first exception in the list and adds all remaining to the suppressed list.
- rethrowAsErrorOrUncheckedException() - Method in exception org.elasticsearch.gateway.WriteStateException
-
Rethrows this
WriteStateException
asIOError
if dirty flag is set, which will lead to JVM shutdown. - rethrowErrors(Runnable) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
-
Checks if the runnable arose from asynchronous submission of a task to an executor.
- rethrowExecutionException(ExecutionException) - Static method in class org.elasticsearch.common.util.concurrent.FutureUtils
- rethrowFailures(String) - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
-
Rethrow task failures if there are any.
- reThrowIfNotNull(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
-
Throws the specified exception.
- RETRIES_BULK_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- RETRIES_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- RETRIES_SEARCH_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- retrieve(String) - Method in class org.elasticsearch.common.path.PathTrie
- retrieve(String[], int, Map<String, String>, PathTrie.TrieMatchingMode) - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
- retrieve(String, Map<String, String>) - Method in class org.elasticsearch.common.path.PathTrie
- retrieve(String, Map<String, String>, PathTrie.TrieMatchingMode) - Method in class org.elasticsearch.common.path.PathTrie
- retrieveAll(String, Supplier<Map<String, String>>) - Method in class org.elasticsearch.common.path.PathTrie
-
Returns an iterator of the objects stored in the
PathTrie
, using all possibleTrieMatchingMode
modes. - retrieveInterestingTerms(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
- retrieveInterestingTerms(Reader, String) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Convenience routine to make it easy to return the most interesting words in a document.
- Retry - Class in org.elasticsearch.action.bulk
-
Encapsulates synchronous and asynchronous retry logic.
- Retry(BackoffPolicy, Scheduler) - Constructor for class org.elasticsearch.action.bulk.Retry
- retryable() - Method in class org.elasticsearch.cluster.block.ClusterBlock
-
Should operations get into retry state if this block is present.
- retryable() - Method in exception org.elasticsearch.cluster.block.ClusterBlockException
- RetryableAction<Response> - Class in org.elasticsearch.action.support
-
A action that will be retried on failure if
RetryableAction.shouldRetry(Exception)
returns true. - RetryableAction(Logger, ThreadPool, TimeValue, TimeValue, ActionListener<Response>) - Constructor for class org.elasticsearch.action.support.RetryableAction
- RetryableAction(Logger, ThreadPool, TimeValue, TimeValue, ActionListener<Response>, String) - Constructor for class org.elasticsearch.action.support.RetryableAction
- retryCopy() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
Returns a fresh recovery target to retry recovery from the same source node onto the same shard and using the same listener.
- retryDelayNetwork() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- retryDelayStateSync() - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- retryOnConflict() - Method in class org.elasticsearch.action.update.UpdateRequest
- retryOnConflict(int) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the number of retries of a version conflict occurs because the document was updated between getting it and updating it.
- retryOnFailure(Exception) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- retryOnFailure(Exception) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- RetryOnPrimaryException(StreamInput) - Constructor for exception org.elasticsearch.action.support.replication.ReplicationOperation.RetryOnPrimaryException
- RetryOnReplicaException(StreamInput) - Constructor for exception org.elasticsearch.action.support.replication.TransportReplicationAction.RetryOnReplicaException
- RetryOnReplicaException(ShardId, String) - Constructor for exception org.elasticsearch.action.support.replication.TransportReplicationAction.RetryOnReplicaException
- retryPrimaryException(Throwable) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- retryRecovery(long, String, TimeValue, TimeValue) - Method in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
- retryRecovery(long, Throwable, TimeValue, TimeValue) - Method in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
- returns(Matcher<? super Class<?>>) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches methods with matching return types.
- returnType - Variable in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo
- reuseAddress - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- ReuseBuffersLZ4BlockOutputStream - Class in org.elasticsearch.transport
-
This file is forked from https://github.com/lz4/lz4-java.
- ReuseBuffersLZ4BlockOutputStream(OutputStream, int, LZ4Compressor) - Constructor for class org.elasticsearch.transport.ReuseBuffersLZ4BlockOutputStream
-
Creates a new
OutputStream
with configurable block size. - reused() - Method in class org.elasticsearch.indices.recovery.RecoveryState.FileDetail
-
returns true if the file is reused from a local copy
- reusedBytes() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- reusedFileCount() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- reverseMul - Variable in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSource
- reverseMul() - Method in enum class org.elasticsearch.search.sort.SortOrder
-
-1 if the sort is reversed from the standard comparators, 1 otherwise.
- reverseNested(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
ReverseNested
aggregation with the given name. - ReverseNested - Interface in org.elasticsearch.search.aggregations.bucket.nested
-
A
reverse nested
aggregation. - ReverseNestedAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.nested
- ReverseNestedAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- ReverseNestedAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
-
Read from a stream.
- ReverseNestedAggregationBuilder(ReverseNestedAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- ReverseNestedAggregator - Class in org.elasticsearch.search.aggregations.bucket.nested
- ReverseNestedAggregator(String, AggregatorFactories, NestedObjectMapper, AggregationContext, Aggregator, CardinalityUpperBound, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregator
- ReverseNestedAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.nested
- ReverseNestedAggregatorFactory(String, boolean, NestedObjectMapper, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregatorFactory
- revision - Variable in class org.elasticsearch.Version
- rewrite() - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- rewrite() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Indicates whether the query should be rewritten into primitive queries
- rewrite() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- rewrite() - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- rewrite() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- rewrite() - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- rewrite() - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- rewrite(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Indicates whether the query should be rewritten into primitive queries
- rewrite(String) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- rewrite(String) - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- rewrite(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- rewrite(String) - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
- rewrite(String) - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- rewrite(List<T>, QueryRewriteContext) - Static method in interface org.elasticsearch.index.query.Rewriteable
-
Rewrites each element of the list until it doesn't change and returns a new list iff there is at least one element of the list that changed during it's rewrite.
- rewrite(IndexReader) - Method in class org.apache.lucene.queries.BlendedTermQuery
- rewrite(IndexReader) - Method in class org.apache.lucene.queries.MinDocQuery
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.FilterScoreFunction
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.function.ScoreFunction
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreQuery
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- rewrite(IndexReader) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
- rewrite(IndexReader) - Method in class org.elasticsearch.index.query.DateRangeIncludingNowQuery
- rewrite(IndexReader) - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
- rewrite(IndexReader, MultiTermQuery) - Method in class org.elasticsearch.common.lucene.search.SpanBooleanQueryRewriteWithMaxClause
- rewrite(Query) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.action.search.SearchRequest
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- rewrite(QueryRewriteContext) - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Rewrites this query builder into its primitive form.
- rewrite(QueryRewriteContext) - Method in interface org.elasticsearch.index.query.Rewriteable
-
Rewrites this instance based on the provided context.
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
-
Rewrites the underlying aggregation builders into their primitive form.
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
-
Rewrites this instance based on the provided context.
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Rewrites this search source builder into its primitive form.
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Field
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.internal.AliasFilter
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- rewrite(QueryRewriteContext) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- rewrite(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic
- rewrite(InternalAggregation.ReduceContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.SignificanceHeuristic
-
Provides a hook for subclasses to provide a version of the heuristic prepared for execution on data on the coordinating node.
- rewrite(AggregationContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic
- rewrite(AggregationContext) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.SignificanceHeuristic
-
Provides a hook for subclasses to provide a version of the heuristic prepared for execution on data on a shard.
- rewrite(T, QueryRewriteContext) - Static method in interface org.elasticsearch.index.query.Rewriteable
-
Rewrites the given
Rewriteable
into its primitive form. - rewrite(T, QueryRewriteContext, boolean) - Static method in interface org.elasticsearch.index.query.Rewriteable
-
Rewrites the given
Rewriteable
into its primitive form. - REWRITE_TIME - Static variable in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- Rewriteable<T> - Interface in org.elasticsearch.index.query
-
A basic interface for rewriteable classes.
- rewriteAndFetch(T, QueryRewriteContext, ActionListener<T>) - Static method in interface org.elasticsearch.index.query.Rewriteable
-
Rewrites the given rewriteable and fetches pending async tasks for each round before rewriting again.
- rewriteAndFetch(T, QueryRewriteContext, ActionListener<T>, int) - Static method in interface org.elasticsearch.index.query.Rewriteable
-
Rewrites the given rewriteable and fetches pending async tasks for each round before rewriting again.
- rewriteBuckets(long, LongUnaryOperator) - Method in class org.elasticsearch.search.aggregations.bucket.BucketsAggregator
-
Merge doc counts.
- rewriteBuckets(LongUnaryOperator) - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
-
Merge or prune the selected buckets.
- rewrittenQuery() - Method in class org.elasticsearch.search.fetch.FetchContext
-
The original query in its rewritten form.
- rewrittenQuery() - Method in class org.elasticsearch.search.internal.SearchContext
-
The query to execute in its rewritten form.
- right() - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- RIGHT - Enum constant in enum class org.elasticsearch.common.geo.Orientation
- roleName() - Method in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
The name of the role.
- roleNameAbbreviation() - Method in class org.elasticsearch.cluster.node.DiscoveryNodeRole
-
The abbreviation of the name of the role.
- rollGeneration() - Method in class org.elasticsearch.index.translog.Translog
-
Roll the current translog generation into a new generation if it's not empty.
- rollover(Index, long) - Method in class org.elasticsearch.cluster.metadata.DataStream
-
Performs a rollover on a
DataStream
instance and returns a new instance containing the updated list of backing indices and incremented generation. - RolloverAction - Class in org.elasticsearch.action.admin.indices.rollover
- rolloverClusterState(ClusterState, String, String, CreateIndexRequest, List<Condition<?>>, boolean, boolean) - Method in class org.elasticsearch.action.admin.indices.rollover.MetadataRolloverService
- rolloverIndex(RolloverRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Swaps the index pointed to by an alias given all provided conditions are satisfied
- rolloverIndex(RolloverRequest, ActionListener<RolloverResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Swaps the index pointed to by an alias given all provided conditions are satisfied
- rolloverIndexName - Variable in class org.elasticsearch.action.admin.indices.rollover.MetadataRolloverService.RolloverResult
- RolloverInfo - Class in org.elasticsearch.action.admin.indices.rollover
-
Class for holding Rollover related information within an index
- RolloverInfo(String, List<Condition<?>>, long) - Constructor for class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- RolloverInfo(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- RolloverRequest - Class in org.elasticsearch.action.admin.indices.rollover
-
Request class to swap index under an alias or increment data stream generation upon satisfying conditions Note: there is a new class with the same name for the Java HLRC that uses a typeless format.
- RolloverRequest(String, String) - Constructor for class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- RolloverRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- RolloverRequestBuilder - Class in org.elasticsearch.action.admin.indices.rollover
- RolloverRequestBuilder(ElasticsearchClient, RolloverAction) - Constructor for class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- RolloverResponse - Class in org.elasticsearch.action.admin.indices.rollover
-
Response object for
RolloverRequest
API Note: there is a new class with the same name for the Java HLRC that uses a typeless format. - RolloverResponse(String, String, Map<String, Boolean>, boolean, boolean, boolean, boolean) - Constructor for class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
- rollTranslogGeneration() - Method in class org.elasticsearch.index.engine.Engine
-
Rolls the translog generation and cleans unneeded.
- rollTranslogGeneration() - Method in class org.elasticsearch.index.engine.InternalEngine
- rollTranslogGeneration() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- rollTranslogGeneration() - Method in class org.elasticsearch.index.shard.IndexShard
-
Rolls the tranlog generation and cleans unneeded.
- ROLLUP_V2_FEATURE_FLAG_ENABLED - Static variable in class org.elasticsearch.rollup.RollupV2
- RollupV2 - Class in org.elasticsearch.rollup
- RollupV2() - Constructor for class org.elasticsearch.rollup.RollupV2
- root() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- ROOT - Static variable in class org.elasticsearch.index.mapper.MapperBuilderContext
-
The root context, to be used when building a tree of mappers
- rootDoc() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- rootDoc() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- rootDoc() - Method in interface org.elasticsearch.search.LeafNestedDocuments
-
The ultimate parent of the current doc
- rootDocs(LeafReaderContext) - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested
-
Get a
BitDocIdSet
that matches the root documents. - RootFlattenedFieldType(String, boolean, boolean, Map<String, String>, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.RootFlattenedFieldType
- RootObjectMapper - Class in org.elasticsearch.index.mapper
- RootObjectMapper.Builder - Class in org.elasticsearch.index.mapper
- RootObjectMapper.Defaults - Class in org.elasticsearch.index.mapper
- roots - Variable in class org.elasticsearch.search.profile.AbstractInternalProfileTree
-
A list of top-level "roots".
- rotate(List<T>, int) - Static method in class org.elasticsearch.common.util.CollectionUtils
-
Return a rotated view of the given list with the given distance.
- RotationShardShuffler - Class in org.elasticsearch.cluster.routing
-
Basic
ShardShuffler
implementation that uses anAtomicInteger
to generate seeds and uses a rotation to permute shards. - RotationShardShuffler(int) - Constructor for class org.elasticsearch.cluster.routing.RotationShardShuffler
- round(long) - Method in interface org.elasticsearch.common.Rounding.Prepared
-
Rounds the given value.
- round(long) - Method in class org.elasticsearch.common.Rounding
-
Deprecated.Prefer
Rounding.prepare(long, long)
and thenRounding.Prepared.round(long)
- round(long) - Method in class org.elasticsearch.common.rounding.Rounding
-
Deprecated.Rounds the given value.
- roundDownToMillis(long) - Method in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
-
Round the given raw value down to a number of milliseconds since the epoch.
- roundFloor(long, long) - Static method in class org.elasticsearch.common.time.DateUtils
-
Rounds the given utc milliseconds sicne the epoch down to the next unit millis Note: This does not check for correctness of the result, as this only works with units smaller or equal than a day In order to ensure the performance of this methods, there are no guards or checks in it
- Rounding - Class in org.elasticsearch.common
-
A strategy for rounding milliseconds since epoch.
- Rounding - Class in org.elasticsearch.common.rounding
-
Deprecated.
- Rounding() - Constructor for class org.elasticsearch.common.Rounding
- Rounding() - Constructor for class org.elasticsearch.common.rounding.Rounding
-
Deprecated.
- Rounding.Builder - Class in org.elasticsearch.common
- Rounding.Builder - Class in org.elasticsearch.common.rounding
-
Deprecated.
- Rounding.DateTimeUnit - Enum Class in org.elasticsearch.common
- Rounding.Prepared - Interface in org.elasticsearch.common
-
A strategy for rounding milliseconds since epoch.
- Rounding.Streams - Class in org.elasticsearch.common.rounding
-
Deprecated.
- RoundingInfo(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- RoundingInfo(Rounding.DateTimeUnit, ZoneId, long, String, int...) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- roundingPreparer() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes
- roundingPreparer() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.GeoPoint
- roundingPreparer() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric
- roundingPreparer() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Range
- roundingPreparer() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource
-
Build a function to prepare
Rounding
s. - roundingPreparer() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
-
Build a function prepares rounding values to be called many times.
- roundingSize(long, Rounding.DateTimeUnit) - Method in interface org.elasticsearch.common.Rounding.Prepared
-
Given the rounded value, returns the size between this value and the next rounded value in specified units if possible.
- roundingSize(Rounding.DateTimeUnit) - Method in interface org.elasticsearch.common.Rounding.Prepared
-
Returns the size of each rounding bucket in timeUnits.
- roundMonthOfYear(long) - Static method in class org.elasticsearch.common.time.DateUtils
-
Round down to the beginning of the month of the year of the specified time
- roundQuarterOfYear(long) - Static method in class org.elasticsearch.common.time.DateUtils
-
Round down to the beginning of the quarter of the year of the specified time
- roundUpToMillis(long) - Method in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
-
Round the given raw value up to a number of milliseconds since the epoch.
- roundWeekOfWeekYear(long) - Static method in class org.elasticsearch.common.time.DateUtils
-
Round down to the beginning of the week based on week year of the specified time
- roundYear(long) - Static method in class org.elasticsearch.common.time.DateUtils
-
Round down to the beginning of the year of the specified time
- Route(RestRequest.Method, String) - Constructor for class org.elasticsearch.rest.RestHandler.Route
-
Constructs a Route that pairs an HTTP method with an associated path.
- routedBasedOnClusterVersion(long) - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- routedBasedOnClusterVersion(long) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
Sets the minimum version of the cluster state that is required on the next node before we redirect to another primary.
- routes() - Method in class org.elasticsearch.action.search.RestClosePointInTimeAction
- routes() - Method in class org.elasticsearch.action.search.RestOpenPointInTimeAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.dangling.RestDeleteDanglingIndexAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.dangling.RestImportDanglingIndexAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.dangling.RestListDanglingIndicesAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestAddVotingConfigExclusionAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestCancelTasksAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestCleanupRepositoryAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClearVotingConfigExclusionsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestCloneSnapshotAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterAllocationExplainAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterGetSettingsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterHealthAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterRerouteAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterSearchShardsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStateAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterStatsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestClusterUpdateSettingsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestCreateSnapshotAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteRepositoryAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteSnapshotAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestDeleteStoredScriptAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetFeatureUpgradeStatusAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetRepositoriesAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetScriptContextAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetScriptLanguageAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetSnapshotsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetStoredScriptAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestGetTaskAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestListTasksAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesHotThreadsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesInfoAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesStatsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestNodesUsageAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestPendingClusterTasksAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestPostFeatureUpgradeAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestPutRepositoryAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestPutStoredScriptAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestReloadSecureSettingsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestRemoteClusterInfoAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestResetFeatureStateAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestRestoreSnapshotAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestSnapshotsStatusAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestSnapshottableFeaturesAction
- routes() - Method in class org.elasticsearch.rest.action.admin.cluster.RestVerifyRepositoryAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestAddIndexBlockAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestAnalyzeIndexDiskUsageAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestClearIndicesCacheAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestCloseIndexAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestCreateIndexAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteComponentTemplateAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteComposableIndexTemplateAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestDeleteIndexTemplateAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestFieldUsageStatsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestFlushAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestForceMergeAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetAliasesAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetComponentTemplateAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetComposableIndexTemplateAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetFieldMappingAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndexTemplateAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetIndicesAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetMappingAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestGetSettingsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndexDeleteAliasesAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndexPutAliasAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesAliasesAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesSegmentsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesShardStoresAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestIndicesStatsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestOpenIndexAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestPutComponentTemplateAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestPutComposableIndexTemplateAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestPutIndexTemplateAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestPutMappingAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestRecoveryAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestRefreshAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestCloneIndexAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestShrinkIndexAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestResizeHandler.RestSplitIndexAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestResolveIndexAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestRolloverIndexAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestSimulateIndexTemplateAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestSimulateTemplateAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestSyncedFlushAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestUpdateSettingsAction
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestUpgradeActionDeprecated
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestUpgradeStatusActionDeprecated
- routes() - Method in class org.elasticsearch.rest.action.admin.indices.RestValidateQueryAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestAliasAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestAllocationAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestCatAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestCatRecoveryAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestCountAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestFielddataAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestHealthAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestIndicesAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestMasterAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestNodeAttrsAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestNodesAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestPendingClusterTasksAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestPluginsAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestRepositoriesAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestSegmentsAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestShardsAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestSnapshotAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestTasksAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestTemplatesAction
- routes() - Method in class org.elasticsearch.rest.action.cat.RestThreadPoolAction
- routes() - Method in class org.elasticsearch.rest.action.datastreams.RestModifyDataStreamsAction
- routes() - Method in class org.elasticsearch.rest.action.document.RestBulkAction
- routes() - Method in class org.elasticsearch.rest.action.document.RestDeleteAction
- routes() - Method in class org.elasticsearch.rest.action.document.RestGetAction
- routes() - Method in class org.elasticsearch.rest.action.document.RestGetSourceAction
- routes() - Method in class org.elasticsearch.rest.action.document.RestIndexAction.AutoIdHandler
- routes() - Method in class org.elasticsearch.rest.action.document.RestIndexAction.CreateHandler
- routes() - Method in class org.elasticsearch.rest.action.document.RestIndexAction
- routes() - Method in class org.elasticsearch.rest.action.document.RestMultiGetAction
- routes() - Method in class org.elasticsearch.rest.action.document.RestMultiTermVectorsAction
- routes() - Method in class org.elasticsearch.rest.action.document.RestTermVectorsAction
- routes() - Method in class org.elasticsearch.rest.action.document.RestUpdateAction
- routes() - Method in class org.elasticsearch.rest.action.ingest.RestDeletePipelineAction
- routes() - Method in class org.elasticsearch.rest.action.ingest.RestGetPipelineAction
- routes() - Method in class org.elasticsearch.rest.action.ingest.RestPutPipelineAction
- routes() - Method in class org.elasticsearch.rest.action.ingest.RestSimulatePipelineAction
- routes() - Method in class org.elasticsearch.rest.action.RestFieldCapabilitiesAction
- routes() - Method in class org.elasticsearch.rest.action.RestMainAction
- routes() - Method in class org.elasticsearch.rest.action.search.RestClearScrollAction
- routes() - Method in class org.elasticsearch.rest.action.search.RestCountAction
- routes() - Method in class org.elasticsearch.rest.action.search.RestExplainAction
- routes() - Method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
- routes() - Method in class org.elasticsearch.rest.action.search.RestSearchAction
- routes() - Method in class org.elasticsearch.rest.action.search.RestSearchScrollAction
- routes() - Method in class org.elasticsearch.rest.BaseRestHandler
-
The list of
RestHandler.Route
s that this RestHandler is responsible for handling. - routes() - Method in class org.elasticsearch.rest.BaseRestHandler.Wrapper
- routes() - Method in interface org.elasticsearch.rest.RestHandler
-
The list of
RestHandler.Route
s that this RestHandler is responsible for handling. - routing - Variable in class org.elasticsearch.index.shard.IndexShard.ShardFailure
- routing - Variable in class org.elasticsearch.index.translog.Translog.Source
- routing() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
A comma separated list of routing values to control the shards the search will be executed on.
- routing() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- routing() - Method in class org.elasticsearch.action.bulk.BulkRequest
- routing() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Controls the shard routing of the delete request.
- routing() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the routing for this request
- routing() - Method in class org.elasticsearch.action.explain.ExplainRequest
- routing() - Method in class org.elasticsearch.action.get.GetRequest
- routing() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- routing() - Method in class org.elasticsearch.action.index.IndexRequest
-
Controls the shard routing of the request.
- routing() - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- routing() - Method in class org.elasticsearch.action.search.SearchRequest
-
A comma separated list of routing values to control the shards the search will be executed on.
- routing() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- routing() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Controls the shard routing of the request.
- routing() - Method in class org.elasticsearch.cluster.metadata.MappingMetadata
- routing() - Method in class org.elasticsearch.index.engine.Engine.Index
- routing() - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- routing() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- routing() - Method in class org.elasticsearch.index.mapper.SourceToParse
- routing() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- routing() - Method in class org.elasticsearch.index.translog.Translog.Index
- routing() - Method in class org.elasticsearch.indices.TermsLookup
- routing(String) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
A comma separated list of routing values to control the shards the search will be executed on.
- routing(String) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Associates a routing value to the alias
- routing(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
-
Set the default routing.
- routing(String) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Note for internal callers (NOT high level rest client), the global parameter setting is ignored when used with: -
BulkRequest.add(IndexRequest)
-BulkRequest.add(UpdateRequest)
-BulkRequest.add(DocWriteRequest)
-BulkRequest.add(DocWriteRequest[])
)} -BulkRequest.add(Iterable)
- routing(String) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
- routing(String) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Controls the shard routing of the request.
- routing(String) - Method in interface org.elasticsearch.action.DocWriteRequest
-
Set the routing for this request
- routing(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
- routing(String) - Method in class org.elasticsearch.action.get.GetRequest
-
Controls the shard routing of the request.
- routing(String) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
-
The routing associated with this document.
- routing(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Controls the shard routing of the request.
- routing(String) - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- routing(String) - Method in class org.elasticsearch.action.search.SearchRequest
-
A comma separated list of routing values to control the shards the search will be executed on.
- routing(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- routing(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Controls the shard routing of the request.
- routing(String) - Method in class org.elasticsearch.cluster.metadata.AliasMetadata.Builder
- routing(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- routing(String) - Method in class org.elasticsearch.indices.TermsLookup
- routing(String...) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
-
The routing values to control the shards that the search will be executed on.
- routing(String...) - Method in class org.elasticsearch.action.search.SearchRequest
-
The routing values to control the shards that the search will be executed on.
- Routing(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MappingMetadata.Routing
- ROUTING - Enum constant in enum class org.elasticsearch.ingest.IngestDocument.Metadata
- ROUTING - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- ROUTING_NODES - Enum constant in enum class org.elasticsearch.cluster.ClusterState.Metric
- ROUTING_TABLE - Enum constant in enum class org.elasticsearch.cluster.ClusterState.Metric
- RoutingAllocation - Class in org.elasticsearch.cluster.routing.allocation
-
The
RoutingAllocation
keep the state of the current allocation of shards and holds theAllocationDeciders
which are responsible for the current routing state. - RoutingAllocation(AllocationDeciders, RoutingNodes, ClusterState, ClusterInfo, SnapshotShardSizeInfo, long) - Constructor for class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Creates a new
RoutingAllocation
- RoutingAllocation.DebugMode - Enum Class in org.elasticsearch.cluster.routing.allocation
- RoutingChangesObserver - Interface in org.elasticsearch.cluster.routing
-
Records changes made to
RoutingNodes
during an allocation round. - RoutingChangesObserver.AbstractRoutingChangesObserver - Class in org.elasticsearch.cluster.routing
-
Abstract implementation of
RoutingChangesObserver
that does not take any action. - RoutingChangesObserver.DelegatingRoutingChangesObserver - Class in org.elasticsearch.cluster.routing
- routingEntry() - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
routing entry for this primary
- routingEntry() - Method in class org.elasticsearch.index.shard.IndexShard
-
Returns the latest cluster routing entry received with this shard.
- routingEntry() - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.Shard
-
Returns the latest cluster routing entry received with this shard.
- RoutingException - Exception in org.elasticsearch.cluster.routing
-
A base
Exception
s for all exceptions thrown by routing related operations. - RoutingException(String, Throwable) - Constructor for exception org.elasticsearch.cluster.routing.RoutingException
- RoutingException(StreamInput) - Constructor for exception org.elasticsearch.cluster.routing.RoutingException
- RoutingExplanations - Class in org.elasticsearch.cluster.routing.allocation
-
Class used to encapsulate a number of
RerouteExplanation
explanations. - RoutingExplanations() - Constructor for class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
- routingFieldMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- RoutingFieldMapper - Class in org.elasticsearch.index.mapper
- RoutingFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- RoutingFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- RoutingMissingException - Exception in org.elasticsearch.action
- RoutingMissingException(String, String, String) - Constructor for exception org.elasticsearch.action.RoutingMissingException
- RoutingMissingException(StreamInput) - Constructor for exception org.elasticsearch.action.RoutingMissingException
- RoutingNode - Class in org.elasticsearch.cluster.routing
-
A
RoutingNode
represents a cluster node associated with a singleDiscoveryNode
including all shards that are hosted on that nodes. - RoutingNode(String, DiscoveryNode, ShardRouting...) - Constructor for class org.elasticsearch.cluster.routing.RoutingNode
- routingNodes() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Get current routing nodes
- RoutingNodes - Class in org.elasticsearch.cluster.routing
-
RoutingNodes
represents a copy the routing information contained in thecluster state
. - RoutingNodes(ClusterState) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes
- RoutingNodes(ClusterState, boolean) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes
- RoutingNodes.UnassignedShards - Class in org.elasticsearch.cluster.routing
- RoutingNodes.UnassignedShards.UnassignedIterator - Class in org.elasticsearch.cluster.routing
- routingNodesChanged() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Returns true iff changes were made to the routing nodes
- RoutingNodesChangedObserver - Class in org.elasticsearch.cluster.routing.allocation
-
Records if changes were made to
RoutingNodes
during an allocation round. - RoutingNodesChangedObserver() - Constructor for class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- routingPartitionSize(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- routingRequired(String) - Method in class org.elasticsearch.cluster.metadata.Metadata
- routingTable() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- routingTable() - Method in class org.elasticsearch.cluster.ClusterState
- routingTable() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Get routing table of current nodes
- routingTable(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- routingTable(RoutingTable) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- RoutingTable - Class in org.elasticsearch.cluster.routing
-
Represents a global cluster-wide routing table for all indices including the version of the current routing state.
- RoutingTable.Builder - Class in org.elasticsearch.cluster.routing
-
Builder for the routing table.
- routingTableChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
Returns
true
if the routing tables (for all indices) have changed between the previous cluster state and the current cluster state. - RPM - Enum constant in enum class org.elasticsearch.Build.Type
- run() - Method in class org.elasticsearch.action.search.ClearScrollController
- run() - Method in class org.elasticsearch.action.support.RetryableAction
- run() - Method in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
- run() - Method in interface org.elasticsearch.common.util.CancellableThreads.Interruptible
- run() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- run() - Method in class org.elasticsearch.common.util.concurrent.AbstractRunnable
- run() - Method in class org.elasticsearch.common.util.concurrent.RunOnce
- run(Object, List<? extends TaskBatcher.BatchedTask>, String) - Method in class org.elasticsearch.cluster.service.TaskBatcher
-
Action to be implemented by the specific batching implementation All tasks have the given batching key.
- run(ActionListener<T>, CheckedRunnable<Exception>) - Static method in class org.elasticsearch.action.ActionRunnable
-
Creates a
Runnable
that invokes the given listener withnull
after the given runnable has executed. - run(Engine, Translog.Snapshot) - Method in interface org.elasticsearch.index.engine.Engine.TranslogRecoveryRunner
- run(SystemIndexMigrationTaskState) - Method in class org.elasticsearch.upgrades.SystemIndexMigrator
- runAfter(ActionListener<Response>, Runnable) - Static method in interface org.elasticsearch.action.ActionListener
-
Wraps a given listener and returns a new listener which executes the provided
runAfter
callback when the listener is notified via either#onResponse
or#onFailure
. - RunAfterActionListener(ActionListener<T>, Runnable) - Constructor for class org.elasticsearch.action.ActionListener.RunAfterActionListener
- runAsDouble() - Method in class org.elasticsearch.script.AggregationScript
- runAsLong() - Method in class org.elasticsearch.script.AggregationScript
-
Return the result as a long.
- runAsLong() - Method in class org.elasticsearch.script.TermsSetQueryScript
-
Return the result as a long.
- runBefore(ActionListener<Response>, CheckedRunnable<?>) - Static method in interface org.elasticsearch.action.ActionListener
-
Wraps a given listener and returns a new listener which executes the provided
runBefore
callback before the listener is notified via either#onResponse
or#onFailure
. - RunBeforeActionListener(ActionListener<T>, CheckedRunnable<?>) - Constructor for class org.elasticsearch.action.ActionListener.RunBeforeActionListener
- runForDoc(int) - Method in class org.elasticsearch.script.AbstractLongFieldScript
-
Execute the script for the provided
docId
. - runForDoc(int) - Method in class org.elasticsearch.script.BooleanFieldScript
-
Execute the script for the provided
docId
. - runForDoc(int) - Method in class org.elasticsearch.script.CompositeFieldScript
- runForDoc(int) - Method in class org.elasticsearch.script.DoubleFieldScript
-
Execute the script for the provided
docId
. - runForDoc(int) - Method in class org.elasticsearch.script.IpFieldScript
-
Execute the script for the provided
docId
. - runForDoc(int, Consumer<Boolean>) - Method in class org.elasticsearch.script.BooleanFieldScript
- runForDoc(int, Consumer<String>) - Method in class org.elasticsearch.script.StringFieldScript
- runForDoc(int, Consumer<InetAddress>) - Method in class org.elasticsearch.script.IpFieldScript
- runForDoc(int, DoubleConsumer) - Method in class org.elasticsearch.script.DoubleFieldScript
-
Execute the script for the provided
docId
, passing results to theconsumer
- runForDoc(int, LongConsumer) - Method in class org.elasticsearch.script.AbstractLongFieldScript
-
Execute the script for the provided
docId
, passing results to theconsumer
- runGeoPointForDoc(int, Consumer<GeoPoint>) - Method in class org.elasticsearch.script.GeoPointFieldScript
-
Consumers must copy the emitted GeoPoint(s) if stored.
- runInternal() - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
- runningSliceSubTasks() - Method in class org.elasticsearch.index.reindex.LeaderBulkByScrollTaskState
-
The number of sliced subtasks that are still running
- runOnApplierThread(String, Priority, Consumer<ClusterState>, ActionListener<Void>) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
Run the given clusterStateConsumer on the applier thread.
- RunOnce - Class in org.elasticsearch.common.util.concurrent
-
Runnable that can only be run one time.
- RunOnce(Runnable) - Constructor for class org.elasticsearch.common.util.concurrent.RunOnce
- runOnlyOnMaster() - Method in interface org.elasticsearch.cluster.ClusterStateTaskExecutor
-
indicates whether this executor should only run if the current node is master
- runOnlyOnMaster() - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
-
Marked as final as cluster state update tasks should only run on master.
- runOnlyOnMaster() - Method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor
- runOnlyOnMaster() - Method in class org.elasticsearch.cluster.LocalClusterUpdateTask
- runPostReplicaActions(ActionListener<Void>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResult
- runPostReplicaActions(ActionListener<Void>) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction.WriteReplicaResult
- runPostReplicationActions(ActionListener<Void>) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.PrimaryResult
-
Run actions to be triggered post replication
- runPostReplicationActions(ActionListener<Void>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryResult
- runPostReplicationActions(ActionListener<Void>) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction.WritePrimaryResult
- RUNTIME - Enum constant in enum class org.elasticsearch.index.mapper.ObjectMapper.Dynamic
- RUNTIME_FIELDS_CONTEXTS - Static variable in class org.elasticsearch.script.ScriptModule
- RUNTIME_MAPPINGS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- RuntimeField - Interface in org.elasticsearch.index.mapper
-
Definition of a runtime field that can be defined as part of the runtime section of the index mappings
- RuntimeField.Builder - Class in org.elasticsearch.index.mapper
- RuntimeField.Parser - Class in org.elasticsearch.index.mapper
-
Parser for a runtime field.
- runtimeFieldParser(String) - Method in class org.elasticsearch.index.mapper.MappingParserContext
- runtimeFields - Variable in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- runtimeFields() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- runtimeFields() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- runtimeFields(Map<String, Object>) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
-
Allows adding search runtime fields if provided.
- RuntimeFieldStats - Class in org.elasticsearch.action.admin.cluster.stats
- RuntimeFieldStats(String) - Constructor for class org.elasticsearch.action.admin.cluster.stats.RuntimeFieldStats
- RuntimeFieldStats(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.stats.RuntimeFieldStats
- runtimeMappings() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Mappings specified on this search request that override built in mappings.
- runtimeMappings(Map<String, Object>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Specify the mappings specified on this search request that override built in mappings.
- runUnderPrimaryPermit(Runnable, Consumer<Exception>, String, Object) - Method in class org.elasticsearch.index.shard.IndexShard
-
Runs the specified runnable under a permit and otherwise calling back the specified failure callback.
- RWE_LIKELIHOOD_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- rwl - Variable in class org.elasticsearch.index.engine.Engine
- rxCount() - Method in class org.elasticsearch.transport.TransportStats
- rxSize() - Method in class org.elasticsearch.transport.TransportStats
S
- s() - Method in class org.elasticsearch.common.lucene.RegExp
-
String expression.
- SafeCommitInfo - Class in org.elasticsearch.index.engine
-
Information about the safe commit, for making decisions about recoveries.
- SafeCommitInfo(long, int) - Constructor for class org.elasticsearch.index.engine.SafeCommitInfo
- SafeScheduledThreadPoolExecutor(int) - Constructor for class org.elasticsearch.threadpool.Scheduler.SafeScheduledThreadPoolExecutor
- SafeScheduledThreadPoolExecutor(int, ThreadFactory) - Constructor for class org.elasticsearch.threadpool.Scheduler.SafeScheduledThreadPoolExecutor
- SafeScheduledThreadPoolExecutor(int, ThreadFactory, RejectedExecutionHandler) - Constructor for class org.elasticsearch.threadpool.Scheduler.SafeScheduledThreadPoolExecutor
- safeToShutdown(String, SingleNodeShutdownMetadata.Type) - Method in interface org.elasticsearch.plugins.ShutdownAwarePlugin
-
Whether the plugin is considered safe to shut down.
- same(Settings, Settings) - Static method in class org.elasticsearch.index.IndexSettings
-
Compare the specified settings for equality.
- SAME - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- sameOrAfter(Priority) - Method in enum class org.elasticsearch.common.Priority
- SameShardAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
An allocation decider that prevents multiple instances of the same shard to be allocated on the same
node
. - SameShardAllocationDecider(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.SameShardAllocationDecider
- sampler(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Sampler
aggregation with the given name. - Sampler - Interface in org.elasticsearch.search.aggregations.bucket.sampler
-
A
filter
aggregation that defines a single bucket to hold a sample of top-matching documents. - SamplerAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.sampler
- SamplerAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- SamplerAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
-
Read from a stream.
- SamplerAggregationBuilder(SamplerAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- SamplerAggregator - Class in org.elasticsearch.search.aggregations.bucket.sampler
-
Aggregate on only the top-scoring docs on a shard.
- SamplerAggregator.ExecutionMode - Enum Class in org.elasticsearch.search.aggregations.bucket.sampler
- SamplerAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.sampler
- satisfiesAdditionalQuorumConstraints(DiscoveryNode, long, long, long, CoordinationMetadata.VotingConfiguration, CoordinationMetadata.VotingConfiguration, CoordinationState.VoteCollection) - Method in class org.elasticsearch.cluster.coordination.ElectionStrategy
-
The extension point to be overridden by plugins.
- saturation(double, double) - Static method in class org.elasticsearch.script.ScoreScriptUtils
-
STATIC FUNCTIONS that can be used by users for score calculations
- save(Path, char[]) - Method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Write the keystore to the given config directory.
- SCALE - Static variable in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- SCALING - Enum constant in enum class org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
- ScalingExecutorBuilder - Class in org.elasticsearch.threadpool
-
A builder for scaling executors.
- ScalingExecutorBuilder(String, int, int, TimeValue, boolean) - Constructor for class org.elasticsearch.threadpool.ScalingExecutorBuilder
-
Construct a scaling executor builder; the settings will have the key prefix "thread_pool." followed by the executor name.
- ScalingExecutorBuilder(String, int, int, TimeValue, boolean, String) - Constructor for class org.elasticsearch.threadpool.ScalingExecutorBuilder
-
Construct a scaling executor builder; the settings will have the specified key prefix.
- schedule(Runnable, TimeValue, String) - Method in interface org.elasticsearch.threadpool.Scheduler
-
Schedules a one-shot command to be run after a given delay.
- schedule(Runnable, TimeValue, String) - Method in class org.elasticsearch.threadpool.ThreadPool
-
Schedules a one-shot command to run after a given delay.
- scheduledRefresh() - Method in class org.elasticsearch.index.shard.IndexShard
-
Executes a scheduled refresh if necessary.
- scheduler - Variable in class org.elasticsearch.ingest.Processor.Parameters
-
Provides scheduler support
- scheduler() - Method in class org.elasticsearch.threadpool.ThreadPool
- Scheduler - Interface in org.elasticsearch.threadpool
-
Scheduler that allows to schedule one-shot and periodic commands.
- Scheduler.Cancellable - Interface in org.elasticsearch.threadpool
-
This interface represents an object whose execution may be cancelled during runtime.
- Scheduler.ReschedulingRunnable - Class in org.elasticsearch.threadpool
-
This class encapsulates the scheduling of a
Runnable
that needs to be repeated on a interval. - Scheduler.SafeScheduledThreadPoolExecutor - Class in org.elasticsearch.threadpool
-
This subclass ensures to properly bubble up Throwable instances of both type Error and Exception thrown in submitted/scheduled tasks to the uncaught exception handler
- Scheduler.ScheduledCancellable - Interface in org.elasticsearch.threadpool
-
A scheduled cancellable allow cancelling and reading the remaining delay of a scheduled task.
- scheduleTask(ThreadPool) - Method in class org.elasticsearch.indices.IndexingMemoryController
- scheduleUnlessShuttingDown(TimeValue, String, Runnable) - Method in class org.elasticsearch.threadpool.ThreadPool
- scheduleWithFixedDelay(Runnable, TimeValue, String) - Method in interface org.elasticsearch.threadpool.Scheduler
-
Schedules a periodic action that runs on scheduler thread.
- scheduleWithFixedDelay(Runnable, TimeValue, String) - Method in class org.elasticsearch.threadpool.ThreadPool
- scope() - Method in class org.elasticsearch.index.analysis.AbstractIndexAnalyzerProvider
- scope() - Method in interface org.elasticsearch.index.analysis.AnalyzerProvider
- scope() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
-
The scope of the analyzer.
- scope() - Method in class org.elasticsearch.index.analysis.PreBuiltAnalyzerProvider
- scope(Key<T>, Provider<T>) - Method in interface org.elasticsearch.common.inject.Scope
-
Scopes a provider.
- Scope - Interface in org.elasticsearch.common.inject
-
A scope is a level of visibility that instances provided by Guice may have.
- SCOPE_ALREADY_SET - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- ScopeAnnotation - Annotation Interface in org.elasticsearch.common.inject
-
Annotates annotations which are used for scoping.
- scopeAnnotationOnAbstractType(Class<? extends Annotation>, Class<?>, Object) - Method in class org.elasticsearch.common.inject.internal.Errors
- ScopeBinding - Class in org.elasticsearch.common.inject.spi
-
Registration of a scope annotation with the scope that implements it.
- ScopedBindingBuilder - Interface in org.elasticsearch.common.inject.binder
-
See the EDSL examples at
Binder
. - scopeNotFound(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.internal.Errors
- Scopes - Class in org.elasticsearch.common.inject
-
Built-in scope implementations.
- Scoping - Class in org.elasticsearch.common.inject.internal
-
References a scope, either directly (as a scope instance), or indirectly (as a scope annotation).
- score - Variable in class org.elasticsearch.action.termvectors.TermVectorsFilter.ScoreTerm
- score - Variable in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- score - Variable in class org.elasticsearch.search.suggest.phrase.Correction
- score - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- score(float) - Method in class org.elasticsearch.search.SearchHit
- score(int, float) - Method in class org.elasticsearch.common.lucene.search.function.LeafScoreFunction
- score(DirectCandidateGenerator.Candidate[], DirectCandidateGenerator.CandidateSet[], int, int) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
- Score() - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion.Score
- SCORE - Enum constant in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
- SCORE - Enum constant in enum class org.elasticsearch.search.profile.query.QueryTimingType
- SCORE - Enum constant in enum class org.elasticsearch.search.suggest.SortBy
-
Sort should first be based on score, then document frequency and then the term itself.
- SCORE - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- SCORE - Static variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- SCORE - Static variable in class org.elasticsearch.search.suggest.term.TermSuggestion
- SCORE_ERROR_MESSAGE - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
- SCORE_MODE_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- scoreBigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolatingScorer
- scoreBigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
- ScoreFunction - Class in org.elasticsearch.common.lucene.search.function
- ScoreFunction(CombineFunction) - Constructor for class org.elasticsearch.common.lucene.search.function.ScoreFunction
- ScoreFunctionBuilder<FB extends ScoreFunctionBuilder<FB>> - Class in org.elasticsearch.index.query.functionscore
- ScoreFunctionBuilder() - Constructor for class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Standard empty constructor.
- ScoreFunctionBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Read from a stream.
- ScoreFunctionBuilders - Class in org.elasticsearch.index.query.functionscore
-
Static method aliases for constructors of known
ScoreFunctionBuilder
s. - ScoreFunctionBuilders() - Constructor for class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- ScoreFunctionParser<FB extends ScoreFunctionBuilder<FB>> - Interface in org.elasticsearch.index.query.functionscore
-
Parses XContent into a
ScoreFunctionBuilder
. - ScoreFunctionSpec(String, Writeable.Reader<T>, ScoreFunctionParser<T>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.ScoreFunctionSpec
- ScoreFunctionSpec(ParseField, Writeable.Reader<T>, ScoreFunctionParser<T>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.ScoreFunctionSpec
- scoreMode() - Method in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
- scoreMode() - Method in class org.elasticsearch.action.search.MaxScoreCollector
- scoreMode() - Method in class org.elasticsearch.common.lucene.MinimumScoreCollector
- scoreMode() - Method in class org.elasticsearch.common.lucene.search.FilteredCollector
- scoreMode() - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Returns the score mode, meaning how results of individual score functions will be aggregated.
- scoreMode() - Method in class org.elasticsearch.index.query.NestedQueryBuilder
-
Returns how the scores from the matching child documents are mapped into the nested parent document.
- scoreMode() - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
Most aggregators don't need scores, make sure to extend this method if your aggregator needs them.
- scoreMode() - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
- scoreMode() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.NumericHistogramAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.bucket.range.BinaryRangeAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
- scoreMode() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.bucket.terms.NumericTermsAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.metrics.GlobalOrdCardinalityAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.metrics.MinAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.metrics.SumAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregator
- scoreMode() - Method in class org.elasticsearch.search.aggregations.MultiBucketCollector
- scoreMode() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- scoreMode() - Method in class org.elasticsearch.search.profile.query.InternalProfileCollector
- scoreMode() - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- scoreMode(FunctionScoreQuery.ScoreMode) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
-
Score mode defines how results of individual score functions will be aggregated.
- scoreModeAsString(ScoreMode) - Static method in class org.elasticsearch.index.query.NestedQueryBuilder
- scoreOrdered() - Method in class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext.FieldOptions
- scorer - Variable in class org.elasticsearch.script.AggregationScript
-
A scorer that will return the score for the current document when the script is run.
- scorer(float, CollectionStatistics, TermStatistics...) - Method in class org.elasticsearch.index.similarity.NonNegativeScoresSimilarity
- scorer(float, CollectionStatistics, TermStatistics...) - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity
- scorer(LeafReaderContext) - Method in class org.elasticsearch.search.profile.query.ProfileWeight
- ScorerAware - Interface in org.elasticsearch.common.lucene
- scorerSupplier(LeafReaderContext) - Method in class org.elasticsearch.search.profile.query.ProfileWeight
- ScoreScript - Class in org.elasticsearch.script
-
A script used for adjusting the score on a per document basis.
- ScoreScript(Map<String, Object>, SearchLookup, DocReader) - Constructor for class org.elasticsearch.script.ScoreScript
- ScoreScript.ExplanationHolder - Class in org.elasticsearch.script
-
A helper to take in an explanation from a script and turn it into an
Explanation
- ScoreScript.Factory - Interface in org.elasticsearch.script
-
A factory to construct stateful
ScoreScript
factories for a specific index. - ScoreScript.LeafFactory - Interface in org.elasticsearch.script
-
A factory to construct
ScoreScript
instances. - ScoreScriptUtils - Class in org.elasticsearch.script
- ScoreScriptUtils() - Constructor for class org.elasticsearch.script.ScoreScriptUtils
- ScoreScriptUtils.DecayDateExp - Class in org.elasticsearch.script
- ScoreScriptUtils.DecayDateGauss - Class in org.elasticsearch.script
- ScoreScriptUtils.DecayDateLinear - Class in org.elasticsearch.script
- ScoreScriptUtils.DecayGeoExp - Class in org.elasticsearch.script
- ScoreScriptUtils.DecayGeoGauss - Class in org.elasticsearch.script
- ScoreScriptUtils.DecayGeoLinear - Class in org.elasticsearch.script
- ScoreScriptUtils.DecayNumericExp - Class in org.elasticsearch.script
- ScoreScriptUtils.DecayNumericGauss - Class in org.elasticsearch.script
- ScoreScriptUtils.DecayNumericLinear - Class in org.elasticsearch.script
- ScoreScriptUtils.RandomScoreDoc - Class in org.elasticsearch.script
- ScoreScriptUtils.RandomScoreField - Class in org.elasticsearch.script
- scoreSort() - Static method in class org.elasticsearch.search.sort.SortBuilders
-
Constructs a new score sort.
- ScoreSortBuilder - Class in org.elasticsearch.search.sort
-
A sort builder allowing to sort by score.
- ScoreSortBuilder() - Constructor for class org.elasticsearch.search.sort.ScoreSortBuilder
-
Build a ScoreSortBuilder default to descending sort order.
- ScoreSortBuilder(StreamInput) - Constructor for class org.elasticsearch.search.sort.ScoreSortBuilder
-
Read from a stream.
- scoreTrigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolatingScorer
- scoreTrigram(DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate, DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
- scoreUnigram(DirectCandidateGenerator.Candidate) - Method in class org.elasticsearch.search.suggest.phrase.WordScorer
- SCORING_BOOLEAN - Static variable in class org.elasticsearch.index.query.support.QueryParsers
- script - Variable in class org.elasticsearch.index.mapper.LongScriptFieldType
- script() - Method in class org.elasticsearch.action.update.UpdateRequest
- script() - Method in class org.elasticsearch.index.query.ScriptQueryBuilder
- script() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Gets the script to use for this source
- script() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Gets the script to use for this aggregation.
- script() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- script() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- script() - Method in class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext.ScriptField
- script() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Get the script used in this sort.
- script(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - script(String, String, ScriptType, Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - script(String, ScriptType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - script(String, ScriptType, Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - script(Script) - Method in class org.elasticsearch.action.update.UpdateRequest
-
The script to execute.
- script(Script) - Method in class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequestBuilder
-
Script to modify the documents before they are processed.
- script(Script) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Sets the script to use for this source
- script(Script) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- script(Script) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Sets the script to use for this aggregation.
- Script - Class in org.elasticsearch.script
-
Script
represents used-defined input that can be used to compile and execute a script from theScriptService
based on theScriptType
. - Script(String) - Constructor for class org.elasticsearch.script.Script
-
Constructor for simple script using the default language and default type.
- Script(StreamInput) - Constructor for class org.elasticsearch.script.Script
-
Creates a
Script
read from an input stream. - Script(AggregationScript.LeafFactory) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.Script
- Script(AggregationScript.LeafFactory, ValueType) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.Script
- Script(ScriptType, String, String, Map<String, Object>) - Constructor for class org.elasticsearch.script.Script
-
Constructor for a script that does not need to use compiler options.
- Script(ScriptType, String, String, Map<String, String>, Map<String, Object>) - Constructor for class org.elasticsearch.script.Script
-
Constructor for a script that requires the use of compiler options.
- SCRIPT - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- SCRIPT - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- SCRIPT_CACHE - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- SCRIPT_CACHE_EXPIRE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
- SCRIPT_CACHE_SIZE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
- SCRIPT_DISABLE_MAX_COMPILATIONS_RATE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
- SCRIPT_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- SCRIPT_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- SCRIPT_FIELD - Static variable in class org.elasticsearch.search.sort.ScriptSortBuilder
- SCRIPT_FIELDS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- SCRIPT_GENERAL_CACHE_EXPIRE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
- SCRIPT_GENERAL_CACHE_SIZE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
- SCRIPT_GENERAL_MAX_COMPILATIONS_RATE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
- SCRIPT_MAX_COMPILATIONS_RATE_SETTING - Static variable in class org.elasticsearch.script.ScriptService
- SCRIPT_MAX_SIZE_IN_BYTES - Static variable in class org.elasticsearch.script.ScriptService
- SCRIPT_PARSE_FIELD - Static variable in class org.elasticsearch.script.Script
-
Standard
ParseField
for outer level of script queries. - SCRIPT_PARSE_FIELD - Static variable in class org.elasticsearch.script.StoredScriptSource
-
Standard
ParseField
for outer level of stored script source. - ScriptBytesValues - Class in org.elasticsearch.search.aggregations.support.values
-
SortedBinaryDocValues
implementation that reads values from a script. - ScriptBytesValues(AggregationScript) - Constructor for class org.elasticsearch.search.aggregations.support.values.ScriptBytesValues
- ScriptCache - Class in org.elasticsearch.script
-
Script cache and compilation rate limiter.
- ScriptCache.CompilationRate - Class in org.elasticsearch.script
- ScriptCacheStats - Class in org.elasticsearch.script
- ScriptCacheStats(Map<String, ScriptStats>) - Constructor for class org.elasticsearch.script.ScriptCacheStats
- ScriptCacheStats(StreamInput) - Constructor for class org.elasticsearch.script.ScriptCacheStats
- ScriptCacheStats(ScriptStats) - Constructor for class org.elasticsearch.script.ScriptCacheStats
- scriptCompiler() - Method in class org.elasticsearch.index.mapper.MappingParserContext
-
The ScriptCompiler to compile scripts needed by the Mapper.
- ScriptCompiler - Interface in org.elasticsearch.script
-
Takes a Script definition and returns a compiled script factory
- ScriptContext<FactoryType> - Class in org.elasticsearch.script
-
The information necessary to compile and run a script.
- ScriptContext(String, Class<FactoryType>) - Constructor for class org.elasticsearch.script.ScriptContext
-
Construct a context with the related instance and compiled classes with defaults for cacheSizeDefault, cacheExpireDefault and compilationRateLimited and allow scripts of this context to be stored scripts
- ScriptContext(String, Class<FactoryType>, int, TimeValue, boolean, boolean) - Constructor for class org.elasticsearch.script.ScriptContext
-
Construct a context with the related instance and compiled classes with caller provided cache defaults
- ScriptContextInfo - Class in org.elasticsearch.script
- ScriptContextInfo(String, ScriptContextInfo.ScriptMethodInfo, Set<ScriptContextInfo.ScriptMethodInfo>) - Constructor for class org.elasticsearch.script.ScriptContextInfo
- ScriptContextInfo(StreamInput) - Constructor for class org.elasticsearch.script.ScriptContextInfo
- ScriptContextInfo.ScriptMethodInfo - Class in org.elasticsearch.script
- ScriptContextInfo.ScriptMethodInfo.ParameterInfo - Class in org.elasticsearch.script
- ScriptContextStats - Class in org.elasticsearch.script
- ScriptContextStats(String, long, long, long, ScriptContextStats.TimeSeries, ScriptContextStats.TimeSeries) - Constructor for class org.elasticsearch.script.ScriptContextStats
- ScriptContextStats(StreamInput) - Constructor for class org.elasticsearch.script.ScriptContextStats
- ScriptContextStats.TimeSeries - Class in org.elasticsearch.script
- ScriptDocValues<T> - Class in org.elasticsearch.index.fielddata
-
Script level doc values, the assumption is that any implementation will implement a
getValue
method. - ScriptDocValues() - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues
- ScriptDocValues.Booleans - Class in org.elasticsearch.index.fielddata
- ScriptDocValues.BytesRefs - Class in org.elasticsearch.index.fielddata
- ScriptDocValues.Dates - Class in org.elasticsearch.index.fielddata
- ScriptDocValues.Doubles - Class in org.elasticsearch.index.fielddata
- ScriptDocValues.Geometry<T> - Class in org.elasticsearch.index.fielddata
- ScriptDocValues.GeoPoints - Class in org.elasticsearch.index.fielddata
- ScriptDocValues.Longs - Class in org.elasticsearch.index.fielddata
- ScriptDocValues.Strings - Class in org.elasticsearch.index.fielddata
- ScriptDoubleValues - Class in org.elasticsearch.search.aggregations.support.values
-
SortingNumericDoubleValues
implementation which is based on a script - ScriptDoubleValues(AggregationScript) - Constructor for class org.elasticsearch.search.aggregations.support.values.ScriptDoubleValues
- scriptedMetric(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
ScriptedMetric
aggregation with the given name. - ScriptedMetric - Interface in org.elasticsearch.search.aggregations.metrics
-
A metric aggregation that computes both its final and intermediate states using scripts.
- ScriptedMetricAggContexts - Class in org.elasticsearch.script
- ScriptedMetricAggContexts() - Constructor for class org.elasticsearch.script.ScriptedMetricAggContexts
- ScriptedMetricAggContexts.CombineScript - Class in org.elasticsearch.script
- ScriptedMetricAggContexts.CombineScript.Factory - Interface in org.elasticsearch.script
- ScriptedMetricAggContexts.InitScript - Class in org.elasticsearch.script
- ScriptedMetricAggContexts.InitScript.Factory - Interface in org.elasticsearch.script
- ScriptedMetricAggContexts.MapScript - Class in org.elasticsearch.script
- ScriptedMetricAggContexts.MapScript.Factory - Interface in org.elasticsearch.script
- ScriptedMetricAggContexts.MapScript.LeafFactory - Interface in org.elasticsearch.script
- ScriptedMetricAggContexts.ReduceScript - Class in org.elasticsearch.script
- ScriptedMetricAggContexts.ReduceScript.Factory - Interface in org.elasticsearch.script
- ScriptedMetricAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- ScriptedMetricAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
- ScriptedMetricAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
-
Read from a stream.
- ScriptedMetricAggregationBuilder(ScriptedMetricAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
- ScriptedSimilarity - Class in org.elasticsearch.index.similarity
-
A
Similarity
implementation that allows scores to be scripted. - ScriptedSimilarity(String, SimilarityWeightScript.Factory, String, SimilarityScript.Factory, boolean) - Constructor for class org.elasticsearch.index.similarity.ScriptedSimilarity
-
Sole constructor.
- ScriptedSimilarity.Doc - Class in org.elasticsearch.index.similarity
-
Statistics that are specific to a document.
- ScriptedSimilarity.Field - Class in org.elasticsearch.index.similarity
-
Statistics that are specific to a given field.
- ScriptedSimilarity.Query - Class in org.elasticsearch.index.similarity
-
Scoring factors that come from the query.
- ScriptedSimilarity.Term - Class in org.elasticsearch.index.similarity
-
Statistics that are specific to a given term.
- scriptedUpsert() - Method in class org.elasticsearch.action.update.UpdateRequest
- scriptedUpsert(boolean) - Method in class org.elasticsearch.action.update.UpdateRequest
- ScriptEngine - Interface in org.elasticsearch.script
-
A script language implementation.
- ScriptException - Exception in org.elasticsearch.script
-
Exception from a scripting engine.
- ScriptException(String, Throwable, List<String>, String, String) - Constructor for exception org.elasticsearch.script.ScriptException
-
Create a new ScriptException with null Position.
- ScriptException(String, Throwable, List<String>, String, String, ScriptException.Position) - Constructor for exception org.elasticsearch.script.ScriptException
-
Create a new ScriptException.
- ScriptException(StreamInput) - Constructor for exception org.elasticsearch.script.ScriptException
-
Deserializes a ScriptException from a
StreamInput
- ScriptException.Position - Class in org.elasticsearch.script
- ScriptFactory - Interface in org.elasticsearch.script
-
Contains utility methods for compiled scripts without impacting concrete script signatures
- scriptField(String, Script) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Adds a script field under the given name with the provided script.
- scriptField(String, Script) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a script field under the given name with the provided script.
- scriptField(String, Script, boolean) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Adds a script field under the given name with the provided script.
- scriptField(String, Script, boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a script field under the given name with the provided script.
- ScriptField(String, FieldScript.LeafFactory, boolean) - Constructor for class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext.ScriptField
- ScriptField(String, Script, boolean) - Constructor for class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- ScriptField(StreamInput) - Constructor for class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
-
Read from a stream.
- ScriptField(XContentParser) - Constructor for class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- scriptFields() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Gets the script fields.
- scriptFields() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the script fields.
- scriptFields() - Method in class org.elasticsearch.search.fetch.FetchContext
-
Configuration for script fields
- scriptFields() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- scriptFields() - Method in class org.elasticsearch.search.internal.SearchContext
- scriptFields() - Method in class org.elasticsearch.search.internal.SubSearchContext
- scriptFields(List<SearchSourceBuilder.ScriptField>) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- ScriptFieldsContext - Class in org.elasticsearch.search.fetch.subphase
- ScriptFieldsContext() - Constructor for class org.elasticsearch.search.fetch.subphase.ScriptFieldsContext
- ScriptFieldsContext.ScriptField - Class in org.elasticsearch.search.fetch.subphase
- ScriptFieldsPhase - Class in org.elasticsearch.search.fetch.subphase
- ScriptFieldsPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.ScriptFieldsPhase
- scriptFunction - Variable in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- scriptFunction(String) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- scriptFunction(Script) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- ScriptHeuristic - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- ScriptHeuristic(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic
-
Read from a stream.
- ScriptHeuristic(Script) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic
- ScriptHeuristic.LongAccessor - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- SCRIPTING - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- scriptLang() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script()
instead - scriptLang(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - ScriptLanguagesInfo - Class in org.elasticsearch.script
-
The allowable types, languages and their corresponding contexts.
- ScriptLanguagesInfo(Set<String>, Map<String, Set<String>>) - Constructor for class org.elasticsearch.script.ScriptLanguagesInfo
- ScriptLanguagesInfo(StreamInput) - Constructor for class org.elasticsearch.script.ScriptLanguagesInfo
- ScriptLongValues - Class in org.elasticsearch.search.aggregations.support.values
-
LongValues
implementation which is based on a script - ScriptLongValues(AggregationScript) - Constructor for class org.elasticsearch.search.aggregations.support.values.ScriptLongValues
- ScriptMetadata - Class in org.elasticsearch.script
-
ScriptMetadata
is used to store user-defined scripts as part of theClusterState
using only an id as the key. - ScriptMetadata(StreamInput) - Constructor for class org.elasticsearch.script.ScriptMetadata
- ScriptMetadata.Builder - Class in org.elasticsearch.script
-
A builder used to modify the currently stored scripts data held within the
ClusterState
. - ScriptMethodInfo(String, String, List<ScriptContextInfo.ScriptMethodInfo.ParameterInfo>) - Constructor for class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo
- ScriptMethodInfo(StreamInput) - Constructor for class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo
- ScriptMetrics - Class in org.elasticsearch.script
- ScriptMetrics() - Constructor for class org.elasticsearch.script.ScriptMetrics
- ScriptModule - Class in org.elasticsearch.script
-
Manages building
ScriptService
. - ScriptModule(Settings, List<ScriptPlugin>) - Constructor for class org.elasticsearch.script.ScriptModule
- scriptParam(Function<FieldMapper, Script>) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Defines a script parameter
- scriptParams() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script()
instead - scriptParams(Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script(Script)
instead - ScriptPlugin - Interface in org.elasticsearch.plugins
-
An additional extension point for
Plugin
s that extends Elasticsearch's scripting functionality. - scriptQuery(Script) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A builder for filter based on a script.
- ScriptQueryBuilder - Class in org.elasticsearch.index.query
- ScriptQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.ScriptQueryBuilder
-
Read from a stream.
- ScriptQueryBuilder(Script) - Constructor for class org.elasticsearch.index.query.ScriptQueryBuilder
- ScriptScoreFunction - Class in org.elasticsearch.common.lucene.search.function
- ScriptScoreFunction(Script, ScoreScript.LeafFactory, SearchLookup, String, int) - Constructor for class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
- ScriptScoreFunctionBuilder - Class in org.elasticsearch.index.query.functionscore
-
A function that uses a script to compute or influence the score of documents that match with the inner query or filter.
- ScriptScoreFunctionBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
-
Read from a stream.
- ScriptScoreFunctionBuilder(Script) - Constructor for class org.elasticsearch.index.query.functionscore.ScriptScoreFunctionBuilder
- scriptScoreQuery(QueryBuilder, Script) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that allows to define a custom scoring function through script.
- ScriptScoreQuery - Class in org.elasticsearch.common.lucene.search.function
-
A query that uses a script to compute documents' scores.
- ScriptScoreQuery(Query, Script, ScoreScript.LeafFactory, SearchLookup, Float, String, int, Version) - Constructor for class org.elasticsearch.common.lucene.search.function.ScriptScoreQuery
- ScriptScoreQueryBuilder - Class in org.elasticsearch.index.query.functionscore
-
A query that computes a document score based on the provided script
- ScriptScoreQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
-
Read from a stream.
- ScriptScoreQueryBuilder(QueryBuilder, Script) - Constructor for class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
-
Creates a script_score query that executes the provided script function on documents that match a query.
- scriptService - Variable in class org.elasticsearch.ingest.Processor.Parameters
-
Provides processors script support.
- scriptService() - Method in class org.elasticsearch.search.aggregations.InternalAggregation.ReduceContext
- ScriptService - Class in org.elasticsearch.script
- ScriptService(Settings, Map<String, ScriptEngine>, Map<String, ScriptContext<?>>) - Constructor for class org.elasticsearch.script.ScriptService
- ScriptService.ContextSettings - Class in org.elasticsearch.script
-
Collect settings related to script context and general caches.
- scriptSort(Script, ScriptSortBuilder.ScriptSortType) - Static method in class org.elasticsearch.search.sort.SortBuilders
-
Constructs a new script based sort.
- ScriptSortBuilder - Class in org.elasticsearch.search.sort
-
Script sort builder allows to sort based on a custom script expression.
- ScriptSortBuilder(StreamInput) - Constructor for class org.elasticsearch.search.sort.ScriptSortBuilder
-
Read from a stream.
- ScriptSortBuilder(Script, ScriptSortBuilder.ScriptSortType) - Constructor for class org.elasticsearch.search.sort.ScriptSortBuilder
-
Constructs a script sort builder with the given script.
- ScriptSortBuilder.ScriptSortType - Enum Class in org.elasticsearch.search.sort
- ScriptStats - Class in org.elasticsearch.script
- ScriptStats(long, long, long) - Constructor for class org.elasticsearch.script.ScriptStats
- ScriptStats(List<ScriptContextStats>) - Constructor for class org.elasticsearch.script.ScriptStats
- ScriptStats(StreamInput) - Constructor for class org.elasticsearch.script.ScriptStats
- ScriptStats(ScriptContextStats) - Constructor for class org.elasticsearch.script.ScriptStats
- scriptString() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script()
instead - scriptType() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Use
UpdateRequest.script()
instead - ScriptType - Enum Class in org.elasticsearch.script
-
ScriptType represents the way a script is stored and retrieved from the
ScriptService
. - scriptValues - Variable in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- scriptValueType() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- scroll - Variable in class org.elasticsearch.search.internal.ScrollContext
- scroll() - Method in class org.elasticsearch.action.search.SearchRequest
-
If set, will enable scrolling of the search request.
- scroll() - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
If set, will enable scrolling of the search request.
- scroll() - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
- scroll() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- scroll(String) - Method in class org.elasticsearch.action.search.SearchRequest
-
If set, will enable scrolling of the search request for the specified timeout.
- scroll(String) - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
If set, will enable scrolling of the search request for the specified timeout.
- scroll(TimeValue) - Method in class org.elasticsearch.action.search.SearchRequest
-
If set, will enable scrolling of the search request for the specified timeout.
- scroll(TimeValue) - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
If set, will enable scrolling of the search request for the specified timeout.
- scroll(Scroll) - Method in class org.elasticsearch.action.search.SearchRequest
-
If set, will enable scrolling of the search request.
- scroll(Scroll) - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
If set, will enable scrolling of the search request.
- scroll(Scroll) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
- Scroll - Class in org.elasticsearch.search
-
A scroll enables scrolling of search request.
- Scroll(StreamInput) - Constructor for class org.elasticsearch.search.Scroll
- Scroll(TimeValue) - Constructor for class org.elasticsearch.search.Scroll
-
Constructs a new scroll of the provided keep alive.
- ScrollableHitSource - Class in org.elasticsearch.index.reindex
-
A scrollable source of results.
- ScrollableHitSource(Logger, BackoffPolicy, ThreadPool, Runnable, Consumer<ScrollableHitSource.AsyncResponse>, Consumer<Exception>) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource
- ScrollableHitSource.AsyncResponse - Interface in org.elasticsearch.index.reindex
- ScrollableHitSource.BasicHit - Class in org.elasticsearch.index.reindex
-
An implementation of ScrollableHitSource.Hit that uses getters and setters.
- ScrollableHitSource.Hit - Interface in org.elasticsearch.index.reindex
-
A document returned as part of the response.
- ScrollableHitSource.Response - Class in org.elasticsearch.index.reindex
-
Response from each scroll batch.
- ScrollableHitSource.SearchFailure - Class in org.elasticsearch.index.reindex
-
A failure during search.
- scrollContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- scrollContext() - Method in class org.elasticsearch.search.internal.LegacyReaderContext
- scrollContext() - Method in class org.elasticsearch.search.internal.ReaderContext
- scrollContext() - Method in class org.elasticsearch.search.internal.SearchContext
- ScrollContext - Class in org.elasticsearch.search.internal
-
Wrapper around information that needs to stay around when scrolling.
- ScrollContext() - Constructor for class org.elasticsearch.search.internal.ScrollContext
- scrollId() - Method in class org.elasticsearch.action.search.SearchScrollRequest
-
The scroll id used to scroll the search.
- scrollId(String) - Method in class org.elasticsearch.action.search.SearchScrollRequest
- scrollIds() - Method in class org.elasticsearch.action.search.ClearScrollRequest
- scrollIds(List<String>) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- ScrollQueryFetchSearchResult - Class in org.elasticsearch.search.fetch
- ScrollQueryFetchSearchResult(StreamInput) - Constructor for class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- ScrollQueryFetchSearchResult(QueryFetchSearchResult, SearchShardTarget) - Constructor for class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- ScrollQuerySearchResult - Class in org.elasticsearch.search.query
- ScrollQuerySearchResult(StreamInput) - Constructor for class org.elasticsearch.search.query.ScrollQuerySearchResult
- ScrollQuerySearchResult(QuerySearchResult, SearchShardTarget) - Constructor for class org.elasticsearch.search.query.ScrollQuerySearchResult
- search - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- search - Variable in class org.elasticsearch.index.engine.Segment
- search() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- search(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- search(int, int) - Method in class org.elasticsearch.common.util.BinarySearcher
-
Uses a binary search to determine the index of the element within the index range {from, ...
- search(int, int, double) - Method in class org.elasticsearch.common.util.BigArrays.DoubleBinarySearcher
- search(List<LeafReaderContext>, Weight, Collector) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- search(SearchRequest) - Method in interface org.elasticsearch.client.Client
-
Search across one or more indices and one or more types with a query.
- search(SearchRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- search(SearchRequest, ActionListener<SearchResponse>) - Method in interface org.elasticsearch.client.Client
-
Search across one or more indices and one or more types with a query.
- search(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- Search - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- SEARCH - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- SEARCH_AFTER - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- SEARCH_AFTER - Static variable in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- SEARCH_COORDINATION - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- SEARCH_ENABLE_REMOTE_CLUSTERS - Static variable in class org.elasticsearch.transport.RemoteClusterService
- SEARCH_REMOTE_CLUSTER_SEEDS_UPGRADER - Static variable in class org.elasticsearch.transport.SniffConnectionStrategy
- SEARCH_REMOTE_CLUSTER_SKIP_UNAVAILABLE - Static variable in class org.elasticsearch.transport.RemoteClusterService
- SEARCH_REMOTE_CLUSTER_SKIP_UNAVAILABLE_UPGRADER - Static variable in class org.elasticsearch.transport.RemoteClusterService
- SEARCH_REMOTE_CLUSTERS_PROXY - Static variable in class org.elasticsearch.transport.SniffConnectionStrategy
- SEARCH_REMOTE_CLUSTERS_PROXY_UPGRADER - Static variable in class org.elasticsearch.transport.SniffConnectionStrategy
- SEARCH_REMOTE_CLUSTERS_SEEDS - Static variable in class org.elasticsearch.transport.SniffConnectionStrategy
- SEARCH_REMOTE_CONNECTIONS_PER_CLUSTER - Static variable in class org.elasticsearch.transport.SniffConnectionStrategy
- SEARCH_REMOTE_INITIAL_CONNECTION_TIMEOUT_SETTING - Static variable in class org.elasticsearch.transport.RemoteClusterService
- SEARCH_REMOTE_NODE_ATTRIBUTE - Static variable in class org.elasticsearch.transport.RemoteClusterService
- SEARCH_SOURCE - Static variable in class org.elasticsearch.index.engine.Engine
- SEARCH_THROTTLED - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- SEARCH_TIME - Enum constant in enum class org.elasticsearch.index.analysis.AnalysisMode
-
AnalysisMode representing analysis components that can be used only at search time
- SEARCHABLE_SNAPSHOT_PARTIAL_SETTING_KEY - Static variable in class org.elasticsearch.snapshots.SearchableSnapshotsSettings
- SEARCHABLE_SNAPSHOT_STORE_TYPE - Static variable in class org.elasticsearch.snapshots.SearchableSnapshotsSettings
- SEARCHABLE_SNAPSHOTS_REPOSITORY_NAME_SETTING_KEY - Static variable in class org.elasticsearch.snapshots.SearchableSnapshotsSettings
- SEARCHABLE_SNAPSHOTS_REPOSITORY_UUID_SETTING_KEY - Static variable in class org.elasticsearch.snapshots.SearchableSnapshotsSettings
- SearchableSnapshotsSettings - Class in org.elasticsearch.snapshots
- SearchAction - Class in org.elasticsearch.action.search
- searchAfter() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
The sort values that indicates which docs this request should "search after".
- searchAfter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- searchAfter() - Method in class org.elasticsearch.search.internal.SearchContext
- searchAfter(Object[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Set the sort values that indicates which docs this request should "search after".
- searchAfter(Object[]) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Set the sort values that indicates which docs this request should "search after".
- searchAfter(FieldDoc) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- searchAfter(FieldDoc) - Method in class org.elasticsearch.search.internal.SearchContext
- SearchAfterBuilder - Class in org.elasticsearch.search.searchafter
- SearchAfterBuilder() - Constructor for class org.elasticsearch.search.searchafter.SearchAfterBuilder
- SearchAfterBuilder(StreamInput) - Constructor for class org.elasticsearch.search.searchafter.SearchAfterBuilder
-
Read from a stream.
- SearchAfterSortedDocQuery - Class in org.apache.lucene.queries
-
A
Query
that only matches documents that are greater than the providedFieldDoc
. - SearchAfterSortedDocQuery(Sort, FieldDoc) - Constructor for class org.apache.lucene.queries.SearchAfterSortedDocQuery
- searchAnalyzer - Variable in class org.elasticsearch.index.mapper.TextParams.Analyzers
- SearchContext - Class in org.elasticsearch.search.internal
-
This class encapsulates the state needed to execute a search.
- SearchContext() - Constructor for class org.elasticsearch.search.internal.SearchContext
- SearchContextAggregations - Class in org.elasticsearch.search.aggregations
-
The aggregation context that is part of the search context.
- SearchContextAggregations(AggregatorFactories) - Constructor for class org.elasticsearch.search.aggregations.SearchContextAggregations
-
Creates a new aggregation context with the parsed aggregator factories
- SearchContextId - Class in org.elasticsearch.action.search
- SearchContextIdForNode - Class in org.elasticsearch.action.search
- SearchContextMissingException - Exception in org.elasticsearch.search
- SearchContextMissingException(StreamInput) - Constructor for exception org.elasticsearch.search.SearchContextMissingException
- SearchContextMissingException(ShardSearchContextId) - Constructor for exception org.elasticsearch.search.SearchContextMissingException
- SearchContextSourcePrinter - Class in org.elasticsearch.search
- SearchContextSourcePrinter(SearchContext) - Constructor for class org.elasticsearch.search.SearchContextSourcePrinter
- searcher() - Method in class org.elasticsearch.index.engine.Engine.GetResult
- searcher() - Method in class org.elasticsearch.index.query.SearchExecutionContext
-
Return the current
IndexSearcher
, ornull
if no index reader is available, for instance if this rewrite context is used to index queries (percolation). - searcher() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
The searcher for the shard this Aggregator is running against.
- searcher() - Method in class org.elasticsearch.search.aggregations.bucket.filter.QueryToFilterAdapter
-
Searcher that this filter is targeting.
- searcher() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- searcher() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
The searcher that will execute this query.
- searcher() - Method in class org.elasticsearch.search.fetch.FetchContext
-
The point-in-time searcher the original query was executed against
- searcher() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- searcher() - Method in class org.elasticsearch.search.internal.SearchContext
- Searcher(String, IndexReader, Similarity, QueryCache, QueryCachingPolicy, Closeable) - Constructor for class org.elasticsearch.index.engine.Engine.Searcher
- searcherSupplier - Variable in class org.elasticsearch.search.internal.ReaderContext
- SearcherSupplier(Function<Engine.Searcher, Engine.Searcher>) - Constructor for class org.elasticsearch.index.engine.Engine.SearcherSupplier
- SearchException - Exception in org.elasticsearch.search
- SearchException(StreamInput) - Constructor for exception org.elasticsearch.search.SearchException
- SearchException(SearchShardTarget, String) - Constructor for exception org.elasticsearch.search.SearchException
- SearchException(SearchShardTarget, String, Throwable) - Constructor for exception org.elasticsearch.search.SearchException
- searchExecutionContext() - Method in class org.elasticsearch.index.mapper.MappingParserContext
- SearchExecutionContext - Class in org.elasticsearch.index.query
-
The context used to execute a search request on a shard.
- SearchExecutionContext(int, int, IndexSettings, BitsetFilterCache, TriFunction<MappedFieldType, String, Supplier<SearchLookup>, IndexFieldData<?>>, MapperService, MappingLookup, SimilarityService, ScriptService, NamedXContentRegistry, NamedWriteableRegistry, Client, IndexSearcher, LongSupplier, String, Predicate<String>, BooleanSupplier, ValuesSourceRegistry, Map<String, Object>) - Constructor for class org.elasticsearch.index.query.SearchExecutionContext
-
Build a SearchExecutionContext.
- SearchExecutionContext(SearchExecutionContext) - Constructor for class org.elasticsearch.index.query.SearchExecutionContext
- SearchExecutionStatsCollector - Class in org.elasticsearch.action.search
-
A wrapper of search action listeners (search results) that unwraps the query result to get the piggybacked queue size and service time EWMA, adding those values to the coordinating nodes'
ResponseCollectorService
. - SearchExtBuilder - Class in org.elasticsearch.search
-
Intermediate serializable representation of a search ext section.
- SearchExtBuilder() - Constructor for class org.elasticsearch.search.SearchExtBuilder
- SearchExtensionSpec(String, Writeable.Reader<? extends W>, P) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SearchExtensionSpec
-
Build the spec with a String.
- SearchExtensionSpec(ParseField, Writeable.Reader<? extends W>, P) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SearchExtensionSpec
-
Build the spec with a ParseField.
- SearchExtSpec(String, Writeable.Reader<? extends T>, CheckedFunction<XContentParser, T, IOException>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SearchExtSpec
- SearchExtSpec(ParseField, Writeable.Reader<? extends T>, CheckedFunction<XContentParser, T, IOException>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SearchExtSpec
- SearchFailure(Throwable) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
-
Build a search failure that doesn't have shard information available.
- SearchFailure(Throwable, String, Integer, String) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- SearchFailure(Throwable, String, Integer, String, RestStatus) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- SearchFailure(StreamInput) - Constructor for class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
-
Read from a stream.
- SearchHighlightContext - Class in org.elasticsearch.search.fetch.subphase.highlight
- SearchHighlightContext(Collection<SearchHighlightContext.Field>) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext
- SearchHighlightContext(Collection<SearchHighlightContext.Field>, boolean) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.SearchHighlightContext
- SearchHighlightContext.Field - Class in org.elasticsearch.search.fetch.subphase.highlight
- SearchHighlightContext.FieldOptions - Class in org.elasticsearch.search.fetch.subphase.highlight
- SearchHit - Class in org.elasticsearch.search
-
A single search hit.
- SearchHit(int) - Constructor for class org.elasticsearch.search.SearchHit
- SearchHit(int, String, Text, Map<String, DocumentField>, Map<String, DocumentField>) - Constructor for class org.elasticsearch.search.SearchHit
- SearchHit(int, String, Text, SearchHit.NestedIdentity, Map<String, DocumentField>, Map<String, DocumentField>) - Constructor for class org.elasticsearch.search.SearchHit
- SearchHit(StreamInput) - Constructor for class org.elasticsearch.search.SearchHit
- SearchHit.Fields - Class in org.elasticsearch.search
- SearchHit.NestedIdentity - Class in org.elasticsearch.search
-
Encapsulates the nested identity of a hit.
- SearchHits - Class in org.elasticsearch.search
- SearchHits(StreamInput) - Constructor for class org.elasticsearch.search.SearchHits
- SearchHits(SearchHit[], TotalHits, float) - Constructor for class org.elasticsearch.search.SearchHits
- SearchHits(SearchHit[], TotalHits, float, SortField[], String, Object[]) - Constructor for class org.elasticsearch.search.SearchHits
- SearchHits.Fields - Class in org.elasticsearch.search
- SearchIndexNameMatcher - Class in org.elasticsearch.index.query
-
A predicate that checks whether an index pattern matches the current search shard target.
- SearchIndexNameMatcher(String, String, ClusterService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.index.query.SearchIndexNameMatcher
-
Creates a new index name matcher.
- searchLookup - Variable in class org.elasticsearch.script.DocValuesDocReader
- searchLookup() - Method in class org.elasticsearch.search.fetch.FetchContext
-
The
SearchLookup
for the this context - SearchLookup - Class in org.elasticsearch.search.lookup
- SearchLookup(Function<String, MappedFieldType>, BiFunction<MappedFieldType, Supplier<SearchLookup>, IndexFieldData<?>>) - Constructor for class org.elasticsearch.search.lookup.SearchLookup
-
Create the top level field lookup for a search request.
- SearchModule - Class in org.elasticsearch.search
-
Sets up things that can be done at search time like queries, aggregations, and suggesters.
- SearchModule(Settings, boolean, List<SearchPlugin>) - Constructor for class org.elasticsearch.search.SearchModule
-
Constructs a new SearchModule object NOTE: This constructor should not be called in production unless an accurate
Settings
object is provided. - SearchOperationListener - Interface in org.elasticsearch.index.shard
-
An listener for search, fetch and context events.
- SearchOperationListener.CompositeListener - Class in org.elasticsearch.index.shard
-
A Composite listener that multiplexes calls to each of the listeners methods.
- SearchParseException - Exception in org.elasticsearch.search
- SearchParseException(StreamInput) - Constructor for exception org.elasticsearch.search.SearchParseException
- SearchParseException(SearchShardTarget, String, XContentLocation) - Constructor for exception org.elasticsearch.search.SearchParseException
- SearchParseException(SearchShardTarget, String, XContentLocation, Throwable) - Constructor for exception org.elasticsearch.search.SearchParseException
- SearchPhaseController - Class in org.elasticsearch.action.search
- SearchPhaseController(BiFunction<Supplier<Boolean>, SearchRequest, InternalAggregation.ReduceContextBuilder>) - Constructor for class org.elasticsearch.action.search.SearchPhaseController
- SearchPhaseController.ReducedQueryPhase - Class in org.elasticsearch.action.search
- SearchPhaseExecutionException - Exception in org.elasticsearch.action.search
- SearchPhaseExecutionException(String, String, Throwable, ShardSearchFailure[]) - Constructor for exception org.elasticsearch.action.search.SearchPhaseExecutionException
- SearchPhaseExecutionException(String, String, ShardSearchFailure[]) - Constructor for exception org.elasticsearch.action.search.SearchPhaseExecutionException
- SearchPhaseExecutionException(StreamInput) - Constructor for exception org.elasticsearch.action.search.SearchPhaseExecutionException
- SearchPhaseResult - Class in org.elasticsearch.search
-
This class is a base class for all search related results.
- SearchPhaseResult() - Constructor for class org.elasticsearch.search.SearchPhaseResult
- SearchPhaseResult(StreamInput) - Constructor for class org.elasticsearch.search.SearchPhaseResult
- SearchPlugin - Interface in org.elasticsearch.plugins
-
Plugin for extending search time behavior.
- SearchPlugin.AggregationSpec - Class in org.elasticsearch.plugins
-
Specification for an
Aggregation
. - SearchPlugin.FetchPhaseConstructionContext - Class in org.elasticsearch.plugins
-
Context available during fetch phase construction.
- SearchPlugin.PipelineAggregationSpec - Class in org.elasticsearch.plugins
-
Specification for a
PipelineAggregator
. - SearchPlugin.QuerySpec<T extends QueryBuilder> - Class in org.elasticsearch.plugins
-
Specification of custom
Query
. - SearchPlugin.RescorerSpec<T extends RescorerBuilder<T>> - Class in org.elasticsearch.plugins
- SearchPlugin.ScoreFunctionSpec<T extends ScoreFunctionBuilder<T>> - Class in org.elasticsearch.plugins
-
Specification of custom
ScoreFunction
. - SearchPlugin.SearchExtensionSpec<W extends NamedWriteable,
P> - Class in org.elasticsearch.plugins -
Specification of search time behavior extension like a custom
MovAvgModel
orScoreFunction
. - SearchPlugin.SearchExtSpec<T extends SearchExtBuilder> - Class in org.elasticsearch.plugins
-
Specification for a
SearchExtBuilder
which represents an additional section that can be parsed in a search request (within the ext element). - SearchPlugin.SignificanceHeuristicSpec<T extends SignificanceHeuristic> - Class in org.elasticsearch.plugins
-
Specification of custom
SignificanceHeuristic
. - SearchPlugin.SuggesterSpec<T extends SuggestionBuilder<T>> - Class in org.elasticsearch.plugins
-
Specification for a
Suggester
. - SearchProfileQueryPhaseResult - Class in org.elasticsearch.search.profile
-
Profile results from a shard for the search phase.
- SearchProfileQueryPhaseResult(List<QueryProfileShardResult>, AggregationProfileShardResult) - Constructor for class org.elasticsearch.search.profile.SearchProfileQueryPhaseResult
- SearchProfileQueryPhaseResult(StreamInput) - Constructor for class org.elasticsearch.search.profile.SearchProfileQueryPhaseResult
- SearchProfileResults - Class in org.elasticsearch.search.profile
-
Profile results for all shards.
- SearchProfileResults(Map<String, SearchProfileShardResult>) - Constructor for class org.elasticsearch.search.profile.SearchProfileResults
- SearchProfileResults(StreamInput) - Constructor for class org.elasticsearch.search.profile.SearchProfileResults
- SearchProfileResultsBuilder - Class in org.elasticsearch.search.profile
-
Profile results for the query phase run on all shards.
- SearchProfileResultsBuilder(Map<String, SearchProfileQueryPhaseResult>) - Constructor for class org.elasticsearch.search.profile.SearchProfileResultsBuilder
- SearchProfileShardResult - Class in org.elasticsearch.search.profile
-
Profile results from a particular shard for all search phases.
- SearchProfileShardResult(StreamInput) - Constructor for class org.elasticsearch.search.profile.SearchProfileShardResult
- SearchProfileShardResult(SearchProfileQueryPhaseResult, ProfileResult) - Constructor for class org.elasticsearch.search.profile.SearchProfileShardResult
- SearchProgressActionListener - Class in org.elasticsearch.action.search
-
An
ActionListener
for search requests that allows to track progress of theSearchAction
. - SearchProgressActionListener() - Constructor for class org.elasticsearch.action.search.SearchProgressActionListener
- SearchProgressListener - Class in org.elasticsearch.action.search
-
A listener that allows to track progress of the
SearchAction
. - SearchProgressListener() - Constructor for class org.elasticsearch.action.search.SearchProgressListener
- searchQuoteAnalyzer - Variable in class org.elasticsearch.index.mapper.TextParams.Analyzers
- searchRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a search request against one or more indices.
- SearchRequest - Class in org.elasticsearch.action.search
-
A request to execute search against one or more indices (or all).
- SearchRequest() - Constructor for class org.elasticsearch.action.search.SearchRequest
- SearchRequest(String...) - Constructor for class org.elasticsearch.action.search.SearchRequest
-
Constructs a new search request against the indices.
- SearchRequest(String[], SearchSourceBuilder) - Constructor for class org.elasticsearch.action.search.SearchRequest
-
Constructs a new search request against the provided indices with the given search source.
- SearchRequest(SearchRequest) - Constructor for class org.elasticsearch.action.search.SearchRequest
-
Constructs a new search request from the provided search request
- SearchRequest(StreamInput) - Constructor for class org.elasticsearch.action.search.SearchRequest
-
Constructs a new search request from reading the specified stream.
- SearchRequest(Version) - Constructor for class org.elasticsearch.action.search.SearchRequest
- SearchRequestBuilder - Class in org.elasticsearch.action.search
-
A search action request builder.
- SearchRequestBuilder(ElasticsearchClient, SearchAction) - Constructor for class org.elasticsearch.action.search.SearchRequestBuilder
- SearchResponse - Class in org.elasticsearch.action.search
-
A response of a search request.
- SearchResponse(SearchResponseSections, String, int, int, int, long, ShardSearchFailure[], SearchResponse.Clusters) - Constructor for class org.elasticsearch.action.search.SearchResponse
- SearchResponse(SearchResponseSections, String, int, int, int, long, ShardSearchFailure[], SearchResponse.Clusters, String) - Constructor for class org.elasticsearch.action.search.SearchResponse
- SearchResponse(StreamInput) - Constructor for class org.elasticsearch.action.search.SearchResponse
- SearchResponse.Clusters - Class in org.elasticsearch.action.search
-
Holds info about the clusters that the search was executed on: how many in total, how many of them were successful and how many of them were skipped.
- SearchResponseSections - Class in org.elasticsearch.action.search
-
Base class that holds the various sections which a search response is composed of (hits, aggs, suggestions etc.) and allows to retrieve them.
- SearchResponseSections(SearchHits, Aggregations, Suggest, boolean, Boolean, SearchProfileResults, int) - Constructor for class org.elasticsearch.action.search.SearchResponseSections
- searchRouting() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Returns the search routing value associated with the alias
- searchRouting() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- searchRouting() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- searchRouting(String) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Associates a search routing value to the alias
- searchRouting(String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- searchRouting(String) - Method in class org.elasticsearch.cluster.metadata.AliasMetadata.Builder
- searchRoutingValues() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- searchScroll(SearchScrollRequest) - Method in interface org.elasticsearch.client.Client
-
A search scroll request to continue searching a previous scrollable search request.
- searchScroll(SearchScrollRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- searchScroll(SearchScrollRequest, ActionListener<SearchResponse>) - Method in interface org.elasticsearch.client.Client
-
A search scroll request to continue searching a previous scrollable search request.
- searchScroll(SearchScrollRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- SearchScrollAction - Class in org.elasticsearch.action.search
- searchScrollRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Creates a search scroll request allowing to continue searching a previous search request.
- SearchScrollRequest - Class in org.elasticsearch.action.search
- SearchScrollRequest() - Constructor for class org.elasticsearch.action.search.SearchScrollRequest
- SearchScrollRequest(String) - Constructor for class org.elasticsearch.action.search.SearchScrollRequest
- SearchScrollRequest(StreamInput) - Constructor for class org.elasticsearch.action.search.SearchScrollRequest
- SearchScrollRequestBuilder - Class in org.elasticsearch.action.search
-
A search scroll action request builder.
- SearchScrollRequestBuilder(ElasticsearchClient, SearchScrollAction) - Constructor for class org.elasticsearch.action.search.SearchScrollRequestBuilder
- SearchScrollRequestBuilder(ElasticsearchClient, SearchScrollAction, String) - Constructor for class org.elasticsearch.action.search.SearchScrollRequestBuilder
- SearchService - Class in org.elasticsearch.search
- SearchService(ClusterService, IndicesService, ThreadPool, ScriptService, BigArrays, FetchPhase, ResponseCollectorService, CircuitBreakerService, ExecutorSelector) - Constructor for class org.elasticsearch.search.SearchService
- SearchShard - Class in org.elasticsearch.action.search
-
A class that encapsulates the
ShardId
and the cluster alias of a shard used during the search action. - SearchShard(String, ShardId) - Constructor for class org.elasticsearch.action.search.SearchShard
- SearchShardIterator - Class in org.elasticsearch.action.search
-
Extension of
PlainShardIterator
used in the search api, which also holds theOriginalIndices
of the search request (useful especially with cross-cluster search, as each cluster has its own set of original indices) as well as the cluster alias. - SearchShardIterator(String, ShardId, List<String>, OriginalIndices, ShardSearchContextId, TimeValue) - Constructor for class org.elasticsearch.action.search.SearchShardIterator
- SearchShardIterator(String, ShardId, List<ShardRouting>, OriginalIndices) - Constructor for class org.elasticsearch.action.search.SearchShardIterator
-
Creates a
PlainShardIterator
instance that iterates over a subset of the given shards this the a givenshardId
. - searchShards(ClusterSearchShardsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns list of shards the given search would be executed on.
- searchShards(ClusterSearchShardsRequest, ActionListener<ClusterSearchShardsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Returns list of shards the given search would be executed on.
- searchShards(ClusterState, String[], Map<String, Set<String>>, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- searchShards(ClusterState, String[], Map<String, Set<String>>, String, ResponseCollectorService, Map<String, Long>) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- SearchShardTarget - Class in org.elasticsearch.search
-
The target that the search request was executed on.
- SearchShardTarget(String, ShardId, String) - Constructor for class org.elasticsearch.search.SearchShardTarget
- SearchShardTarget(StreamInput) - Constructor for class org.elasticsearch.search.SearchShardTarget
- SearchShardTask - Class in org.elasticsearch.action.search
-
Task storing information about a currently running search shard request.
- SearchShardTask(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.action.search.SearchShardTask
- SearchSlowLog - Class in org.elasticsearch.index
- SearchSlowLog(IndexSettings) - Constructor for class org.elasticsearch.index.SearchSlowLog
- SearchSortValues - Class in org.elasticsearch.search
- SearchSortValues(Object[], DocValueFormat[]) - Constructor for class org.elasticsearch.search.SearchSortValues
- SearchSortValuesAndFormats - Class in org.elasticsearch.search
- SearchSortValuesAndFormats(Object[], DocValueFormat[]) - Constructor for class org.elasticsearch.search.SearchSortValuesAndFormats
- SearchSortValuesAndFormats(StreamInput) - Constructor for class org.elasticsearch.search.SearchSortValuesAndFormats
- searchSource() - Static method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
A static factory method to construct a new search source.
- SearchSourceBuilder - Class in org.elasticsearch.search.builder
-
A search source builder allowing to easily build search source.
- SearchSourceBuilder() - Constructor for class org.elasticsearch.search.builder.SearchSourceBuilder
-
Constructs a new search source builder.
- SearchSourceBuilder(StreamInput) - Constructor for class org.elasticsearch.search.builder.SearchSourceBuilder
-
Read from a stream.
- SearchSourceBuilder.IndexBoost - Class in org.elasticsearch.search.builder
- SearchSourceBuilder.ScriptField - Class in org.elasticsearch.search.builder
- SearchSourceBuilderException - Exception in org.elasticsearch.search.builder
- SearchSourceBuilderException(String) - Constructor for exception org.elasticsearch.search.builder.SearchSourceBuilderException
- SearchSourceBuilderException(String, Throwable) - Constructor for exception org.elasticsearch.search.builder.SearchSourceBuilderException
- SearchSourceBuilderException(StreamInput) - Constructor for exception org.elasticsearch.search.builder.SearchSourceBuilderException
- searchStats(String...) - Method in class org.elasticsearch.index.shard.IndexShard
- SearchStats - Class in org.elasticsearch.index.search.stats
- SearchStats() - Constructor for class org.elasticsearch.index.search.stats.SearchStats
- SearchStats(StreamInput) - Constructor for class org.elasticsearch.index.search.stats.SearchStats
- SearchStats(SearchStats.Stats, long, Map<String, SearchStats.Stats>) - Constructor for class org.elasticsearch.index.search.stats.SearchStats
- SearchStats.Stats - Class in org.elasticsearch.index.search.stats
- SearchTask - Class in org.elasticsearch.action.search
-
Task storing information about a currently running
SearchRequest
. - SearchTask(long, String, String, Supplier<String>, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.action.search.SearchTask
- searchThreadPoolSize(int) - Static method in class org.elasticsearch.threadpool.ThreadPool
- searchTimedOut() - Method in class org.elasticsearch.search.query.QuerySearchResult
- searchTimedOut(boolean) - Method in class org.elasticsearch.search.query.QuerySearchResult
- searchToString(StringBuilder) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Append a short description of the search request to a StringBuilder.
- searchToString(StringBuilder) - Method in class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
- SearchTransportService - Class in org.elasticsearch.action.search
-
An encapsulation of
SearchService
operations exposed through transport. - SearchTransportService(TransportService, NodeClient, BiFunction<Transport.Connection, SearchActionListener<? super SearchPhaseResult>, ActionListener<? super SearchPhaseResult>>) - Constructor for class org.elasticsearch.action.search.SearchTransportService
- SearchTransportService.SearchFreeContextResponse - Class in org.elasticsearch.action.search
- searchType() - Method in class org.elasticsearch.action.search.SearchRequest
-
The tye of search to execute.
- searchType() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- searchType() - Method in class org.elasticsearch.search.internal.SearchContext
- searchType() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- searchType(String) - Method in class org.elasticsearch.action.search.SearchRequest
-
The a string representation search type to execute, defaults to
SearchType.DEFAULT
. - searchType(SearchType) - Method in class org.elasticsearch.action.search.SearchRequest
-
The search type to execute, defaults to
SearchType.DEFAULT
. - SearchType - Enum Class in org.elasticsearch.action.search
-
Search type represent the manner at which the search operation is executed.
- seasonalityType(HoltWintersModel.SeasonalityType) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
- SECOND - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- SECOND_OF_MINUTE - Enum constant in enum class org.elasticsearch.common.rounding.DateTimeUnit
- SECOND_OF_MINUTE - Enum constant in enum class org.elasticsearch.common.Rounding.DateTimeUnit
- seconds(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- secureFile(String, Setting<InputStream>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.SecureSetting
-
A setting which contains a file.
- SecureSetting<T> - Class in org.elasticsearch.common.settings
-
A secure setting.
- SecureSettings - Interface in org.elasticsearch.common.settings
-
An accessor for settings which are securely stored.
- secureString(String, Setting<SecureString>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.SecureSetting
-
A setting which contains a sensitive string.
- SecureString - Class in org.elasticsearch.common.settings
-
A String implementations which allows clearing the underlying char array.
- SecureString(char[]) - Constructor for class org.elasticsearch.common.settings.SecureString
-
Constructs a new SecureString which controls the passed in char array.
- SecureString(String) - Constructor for class org.elasticsearch.common.settings.SecureString
-
Deprecated.Only use for compatibility between deprecated string settings and new secure strings
- SECURITY - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- SECURITY_FILTER_BAD_DEFAULTS_SETTING - Static variable in class org.elasticsearch.bootstrap.BootstrapSettings
- SEE_OTHER - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The response to the request can be found under a different URI and SHOULD be retrieved using a GET method on that resource.
- seed(int) - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
-
Sets the seed based on which the random number will be generated.
- seed(long) - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
-
seed variant taking a long value.
- seed(String) - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
-
seed variant taking a String value.
- SEED - Static variable in class org.elasticsearch.search.slice.TermsSliceQuery
- SEED_SETTING - Static variable in class org.elasticsearch.common.settings.KeyStoreWrapper
- SeedHostsProvider - Interface in org.elasticsearch.discovery
-
A pluggable provider of the list of seed hosts to use for discovery.
- SeedHostsProvider.HostsResolver - Interface in org.elasticsearch.discovery
-
Helper object that allows to resolve a list of hosts to a list of transport addresses.
- SeedHostsResolver - Class in org.elasticsearch.discovery
- SeedHostsResolver(String, Settings, TransportService, SeedHostsProvider) - Constructor for class org.elasticsearch.discovery.SeedHostsResolver
- seek(long) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- seek(long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- seek(long) - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- seekCeil(BytesRef) - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- seekExact(long) - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- seekExact(BytesRef) - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- seekExact(BytesRef) - Method in class org.elasticsearch.common.lucene.index.FreqTermsEnum
- seekExact(BytesRef, TermState) - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- Segment - Class in org.elasticsearch.index.engine
- Segment(String) - Constructor for class org.elasticsearch.index.engine.Segment
- Segment(StreamInput) - Constructor for class org.elasticsearch.index.engine.Segment
- segmentReader(LeafReader) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Tries to extract a segment reader from the given index reader.
- segments - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- segments() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- segments(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- segments(boolean) - Method in class org.elasticsearch.index.engine.Engine
-
The list of segments in the engine.
- segments(boolean) - Method in class org.elasticsearch.index.engine.InternalEngine
- segments(boolean) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- segments(boolean) - Method in class org.elasticsearch.index.shard.IndexShard
- segments(IndicesSegmentsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
The segments of one or more indices.
- segments(IndicesSegmentsRequest, ActionListener<IndicesSegmentResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
The segments of one or more indices.
- Segments - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- segmentSort - Variable in class org.elasticsearch.index.engine.Segment
- segmentsStats(boolean, boolean) - Method in class org.elasticsearch.index.engine.Engine
-
Global stats on segments.
- segmentsStats(boolean, boolean) - Method in class org.elasticsearch.index.engine.NoOpEngine
- SegmentsStats - Class in org.elasticsearch.index.engine
- SegmentsStats() - Constructor for class org.elasticsearch.index.engine.SegmentsStats
- SegmentsStats(StreamInput) - Constructor for class org.elasticsearch.index.engine.SegmentsStats
- SegmentsStats.FileStats - Class in org.elasticsearch.index.engine
- segmentStats(boolean, boolean) - Method in class org.elasticsearch.index.shard.IndexShard
- segmentsWithMultiValuedOrds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- segmentsWithSingleValuedOrds - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- select(SortedNumericDocValues) - Method in enum class org.elasticsearch.search.MultiValueMode
-
Return a
NumericDocValues
instance that can be used to sort documents with this mode and the provided values. - select(SortedNumericDocValues, long, BitSet, DocIdSetIterator, int, int) - Method in enum class org.elasticsearch.search.MultiValueMode
-
Return a
NumericDocValues
instance that can be used to sort root documents with this mode, the provided values and filters for root/inner documents. - select(SortedSetDocValues) - Method in enum class org.elasticsearch.search.MultiValueMode
-
Return a
SortedDocValues
instance that can be used to sort documents with this mode and the provided values. - select(SortedSetDocValues, BitSet, DocIdSetIterator, int) - Method in enum class org.elasticsearch.search.MultiValueMode
-
Return a
SortedDocValues
instance that can be used to sort root documents with this mode, the provided values and filters for root/inner documents. - select(SortedBinaryDocValues, BytesRef) - Method in enum class org.elasticsearch.search.MultiValueMode
-
Return a
BinaryDocValues
instance that can be used to sort documents with this mode and the provided values. - select(SortedBinaryDocValues, BytesRef, BitSet, DocIdSetIterator, int, int) - Method in enum class org.elasticsearch.search.MultiValueMode
-
Return a
BinaryDocValues
instance that can be used to sort root documents with this mode, the provided values and filters for root/inner documents. - select(SortedNumericDoubleValues) - Method in enum class org.elasticsearch.search.MultiValueMode
-
Return a
NumericDoubleValues
instance that can be used to sort documents with this mode and the provided values. - select(SortedNumericDoubleValues, double, BitSet, DocIdSetIterator, int, int) - Method in enum class org.elasticsearch.search.MultiValueMode
-
Return a
NumericDoubleValues
instance that can be used to sort root documents with this mode, the provided values and filters for root/inner documents. - selectBestTerms() - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- selectCloneShard(int, IndexMetadata, int) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Returns the source shard ID to clone the given target shard off
- selectedFields() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return only term vectors for special selected fields.
- selectedFields(String...) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return only term vectors for special selected fields.
- selectLeastLoadedNode(ClusterState, Collection<DiscoveryNode>, Predicate<DiscoveryNode>) - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
-
Finds the least loaded node from amongs the candidate node collection that satisfies the selector criteria
- selectNewPathForShard(NodeEnvironment, ShardId, IndexSettings, long, Map<Path, Integer>) - Static method in class org.elasticsearch.index.shard.ShardPath
- selectRecoverFromShards(int, IndexMetadata, int) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Selects the source shards for a local shard recovery.
- selectShrinkShards(int, IndexMetadata, int) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Returns the source shard ids to shrink into the given shard id.
- selectSplitShard(int, IndexMetadata, int) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Returns the source shard ID to split the given target shard off
- self() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
`this` cast to Self.
- self() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
- self() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- self() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequestBuilder
- self() - Method in class org.elasticsearch.index.reindex.ReindexRequest
- self() - Method in class org.elasticsearch.index.reindex.ReindexRequestBuilder
- self() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- self() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequestBuilder
- SEND_ACTION_NAME - Static variable in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- SEND_LEAVE_REQUEST_SETTING - Static variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- sendApplyCommit(DiscoveryNode, ApplyCommitRequest, ActionListener<TransportResponse.Empty>) - Method in class org.elasticsearch.cluster.coordination.Publication
- sendApplyCommit(DiscoveryNode, ApplyCommitRequest, ActionListener<TransportResponse.Empty>) - Method in class org.elasticsearch.cluster.coordination.PublicationTransportHandler.PublicationContext
- sendBufferSize - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- sendCanMatch(Transport.Connection, CanMatchNodeRequest, SearchTask, ActionListener<CanMatchNodeResponse>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendCanMatch(Transport.Connection, ShardSearchRequest, SearchTask, ActionListener<CanMatchShardResponse>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendChildRequest(DiscoveryNode, String, TransportRequest, Task, TransportRequestOptions, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- sendChildRequest(Transport.Connection, String, TransportRequest, Task, TransportRequestOptions, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- sendChildRequest(Transport.Connection, String, TransportRequest, Task, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- sendClearAllScrollContexts(Transport.Connection, ActionListener<TransportResponse>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendCompletionRequest(String, long, Exception, String, ActionListener<PersistentTasksCustomMetadata.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksService
-
Notifies the master node about the completion of a persistent task.
- sendErrorResponse(TransportChannel, String, TransportRequest, Exception) - Static method in interface org.elasticsearch.transport.TransportChannel
-
A helper method to send an exception and handle and log a subsequent exception
- sendExecuteDfs(Transport.Connection, ShardSearchRequest, SearchTask, SearchActionListener<DfsSearchResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendExecuteFetch(Transport.Connection, ShardFetchSearchRequest, SearchTask, SearchActionListener<FetchSearchResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendExecuteFetchScroll(Transport.Connection, ShardFetchRequest, SearchTask, SearchActionListener<FetchSearchResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendExecuteQuery(Transport.Connection, ShardSearchRequest, SearchTask, SearchActionListener<? super SearchPhaseResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendExecuteQuery(Transport.Connection, QuerySearchRequest, SearchTask, SearchActionListener<QuerySearchResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendExecuteScrollFetch(Transport.Connection, InternalScrollSearchRequest, SearchTask, SearchActionListener<ScrollQueryFetchSearchResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendExecuteScrollQuery(Transport.Connection, InternalScrollSearchRequest, SearchTask, SearchActionListener<ScrollQuerySearchResult>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendFreeContext(Transport.Connection, ShardSearchContextId, ActionListener<SearchTransportService.SearchFreeContextResponse>) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendFreeContext(Transport.Connection, ShardSearchContextId, OriginalIndices) - Method in class org.elasticsearch.action.search.SearchTransportService
- sendJoinRequest(DiscoveryNode, long, Optional<Join>) - Method in class org.elasticsearch.cluster.coordination.JoinHelper
- sendJoinRequest(DiscoveryNode, long, Optional<Join>, Runnable) - Method in class org.elasticsearch.cluster.coordination.JoinHelper
- sendJoinRequestBlocking(DiscoveryNode, DiscoveryNode, TimeValue) - Method in class org.elasticsearch.discovery.zen.MembershipAction
- sendLeaveRequest(DiscoveryNode, DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.MembershipAction
- sendLeaveRequestBlocking(DiscoveryNode, DiscoveryNode, TimeValue) - Method in class org.elasticsearch.discovery.zen.MembershipAction
- sendMessage(BytesReference, ActionListener<Void>) - Method in interface org.elasticsearch.transport.TcpChannel
-
Sends a tcp message to the channel.
- sendPings(TimeValue, UnicastZenPing.PingingRound) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
- sendPublishRequest(DiscoveryNode, PublishRequest, ActionListener<PublishWithJoinResponse>) - Method in class org.elasticsearch.cluster.coordination.Publication
- sendPublishRequest(DiscoveryNode, PublishRequest, ActionListener<PublishWithJoinResponse>) - Method in class org.elasticsearch.cluster.coordination.PublicationTransportHandler.PublicationContext
- sendRemoveRequest(String, ActionListener<PersistentTasksCustomMetadata.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksService
-
Notifies the master node to remove a persistent task from the cluster state
- sendRequest(long, String, TransportRequest, TransportRequestOptions) - Method in class org.elasticsearch.transport.TcpTransport.NodeChannels
- sendRequest(long, String, TransportRequest, TransportRequestOptions) - Method in interface org.elasticsearch.transport.Transport.Connection
-
Sends the request to the node this connection is associated with
- sendRequest(DiscoveryNode, String, TransportRequest, TransportRequestOptions, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- sendRequest(DiscoveryNode, String, TransportRequest, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- sendRequest(Transport.Connection, String, TransportRequest, TransportRequestOptions, TransportResponseHandler<T>) - Method in interface org.elasticsearch.transport.TransportInterceptor.AsyncSender
- sendRequest(Transport.Connection, String, TransportRequest, TransportRequestOptions, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
-
Sends a request on the specified connection.
- SendRequestTransportException - Exception in org.elasticsearch.transport
- SendRequestTransportException(DiscoveryNode, String, Throwable) - Constructor for exception org.elasticsearch.transport.SendRequestTransportException
- SendRequestTransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.SendRequestTransportException
- sendResponse(Exception) - Method in class org.elasticsearch.transport.TaskTransportChannel
- sendResponse(Exception) - Method in class org.elasticsearch.transport.TcpTransportChannel
- sendResponse(Exception) - Method in interface org.elasticsearch.transport.TransportChannel
- sendResponse(HttpResponse, ActionListener<Void>) - Method in interface org.elasticsearch.http.HttpChannel
-
Sends an http response to the channel.
- sendResponse(RestResponse) - Method in class org.elasticsearch.http.DefaultRestChannel
- sendResponse(RestResponse) - Method in interface org.elasticsearch.rest.RestChannel
- sendResponse(TransportResponse) - Method in class org.elasticsearch.transport.TaskTransportChannel
- sendResponse(TransportResponse) - Method in class org.elasticsearch.transport.TcpTransportChannel
- sendResponse(TransportResponse) - Method in interface org.elasticsearch.transport.TransportChannel
- sendShardRequest(DiscoveryNode, ShardRequest, ActionListener<ShardResponse>) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- sendStartJoinRequest(StartJoinRequest, DiscoveryNode) - Method in class org.elasticsearch.cluster.coordination.JoinHelper
- sendStartRequest(String, String, Params, ActionListener<PersistentTasksCustomMetadata.PersistentTask<Params>>) - Method in class org.elasticsearch.persistent.PersistentTasksService
-
Notifies the master node to create new persistent task and to assign it to a node.
- sendUpdateMapping(Index, String, Mapping, ActionListener<Void>) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
- sendValidateJoinRequestBlocking(DiscoveryNode, ClusterState, TimeValue) - Method in class org.elasticsearch.discovery.zen.MembershipAction
-
Validates the join request, throwing a failure if it failed.
- SENTENCE - Enum constant in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
- sentFromLocalReroute() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- separator - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- separator() - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
-
Get the separator used to join pairs of bucket keys
- separator() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the separator that is used to separate terms in the bigram field.
- separator(String) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
-
Set the separator used to join pairs of bucket keys
- separator(String) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets the separator that is used to separate terms in the bigram field.
- SEPARATOR_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- SEQ_NO_PRIMARY_TERM_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- SEQ_NO_SNAPSHOT_RECOVERIES_SUPPORTED_VERSION - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
- seqID() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- seqID(SeqNoFieldMapper.SequenceIDFields) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- seqNo - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- seqNo - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndSeqNo
- seqNo - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndVersion
- seqNo - Variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SequenceIDFields
- seqNo() - Method in class org.elasticsearch.index.engine.Engine.Operation
- seqNo() - Method in class org.elasticsearch.index.translog.Translog.Delete
- seqNo() - Method in class org.elasticsearch.index.translog.Translog.Index
- seqNo() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- seqNo() - Method in interface org.elasticsearch.index.translog.Translog.Operation
- seqNoAndPrimaryTerm() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Indicates whether
SearchHit
s should be returned with the sequence number and primary term of the last modification of the document. - seqNoAndPrimaryTerm() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicates whether
SearchHit
s should be returned with the sequence number and primary term of the last modification of the document. - seqNoAndPrimaryTerm() - Method in class org.elasticsearch.search.fetch.FetchContext
-
Should the response include sequence number and primary term metadata
- seqNoAndPrimaryTerm() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- seqNoAndPrimaryTerm() - Method in class org.elasticsearch.search.internal.SearchContext
-
indicates whether the sequence number and primary term of the last modification to each hit should be returned
- seqNoAndPrimaryTerm() - Method in class org.elasticsearch.search.internal.SubSearchContext
- seqNoAndPrimaryTerm(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Should each
SearchHit
be returned with the sequence number and primary term of the last modification of the document. - seqNoAndPrimaryTerm(boolean) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- seqNoAndPrimaryTerm(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
-
controls whether the sequence number and primary term of the last modification to each hit should be returned
- seqNoAndPrimaryTerm(boolean) - Method in class org.elasticsearch.search.internal.SubSearchContext
- seqNoAndPrimaryTerm(Boolean) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Should each
SearchHit
be returned with the sequence number and primary term of the last modification of the document. - seqNoAndPrimaryTerm(Boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Should each
SearchHit
be returned with the sequence number and primary term of the last modification of the document. - seqNoDocValue - Variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SequenceIDFields
- SeqNoFieldMapper - Class in org.elasticsearch.index.mapper
-
Mapper for the
_seq_no
field. - SeqNoFieldMapper.SequenceIDFields - Class in org.elasticsearch.index.mapper
-
A sequence ID, which is made up of a sequence number (both the searchable and doc_value version of the field) and the primary term.
- SeqNoPrimaryTermPhase - Class in org.elasticsearch.search.fetch.subphase
- SeqNoPrimaryTermPhase() - Constructor for class org.elasticsearch.search.fetch.subphase.SeqNoPrimaryTermPhase
- seqNoStats() - Method in class org.elasticsearch.index.shard.IndexShard
- SeqNoStats - Class in org.elasticsearch.index.seqno
- SeqNoStats(long, long, long) - Constructor for class org.elasticsearch.index.seqno.SeqNoStats
- SeqNoStats(StreamInput) - Constructor for class org.elasticsearch.index.seqno.SeqNoStats
- SequenceNumbers - Class in org.elasticsearch.index.seqno
-
A utility class for handling sequence numbers.
- SequenceNumbers() - Constructor for class org.elasticsearch.index.seqno.SequenceNumbers
- SequenceNumbers.CommitInfo - Class in org.elasticsearch.index.seqno
- SequentialStoredFieldsLeafReader - Class in org.elasticsearch.common.lucene.index
-
A
FilterLeafReader
that exposes aStoredFieldsReader
optimized for sequential access. - SequentialStoredFieldsLeafReader(LeafReader) - Constructor for class org.elasticsearch.common.lucene.index.SequentialStoredFieldsLeafReader
-
Construct a StoredFieldsFilterLeafReader based on the specified base reader.
- SerialDiffPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- SerialDiffPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
- SerialDiffPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
-
Read from a stream.
- SerialDiffPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- SerialDiffPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregator
-
Read from a stream.
- SERIALIZATION_FORMAT - Static variable in class org.elasticsearch.index.translog.Translog.Delete
- SERIALIZATION_FORMAT - Static variable in class org.elasticsearch.index.translog.Translog.Index
- serialize(XContentBuilder, String, T) - Method in interface org.elasticsearch.index.mapper.FieldMapper.Serializer
- serialize(T, String, boolean, OutputStream) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- serialize(T, String, boolean, Map<String, String>, OutputStream) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- SERIALIZE_WRITER_UUID - Static variable in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
- serializeDiffClusterState(Diff<?>, Version) - Static method in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- serializeFullClusterState(ClusterState, Version) - Static method in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- serializeMappers(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- serializeTargetValueType(Version) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- serializeTargetValueType(Version) - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- serializeTargetValueType(Version) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- serializeTargetValueType(Version) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- serializeTargetValueType(Version) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- serializeTargetValueType(Version) - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- serializeTargetValueType(Version) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
DO NOT OVERRIDE THIS!
- SERVER_NAME - Static variable in class org.elasticsearch.transport.ProxyConnectionStrategy
-
A configurable server_name attribute
- serverAcceptedChannel(HttpChannel) - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- serverAcceptedChannel(TcpChannel) - Method in class org.elasticsearch.transport.TcpTransport
- serverOpen() - Method in class org.elasticsearch.transport.TransportStats
- SERVICE_UNAVAILABLE - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server is currently unable to handle the request due to a temporary overloading or maintenance of the server.
- serviceTime - Variable in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- serviceTimeEWMA() - Method in class org.elasticsearch.search.query.QuerySearchResult
- serviceTimeEWMA(long) - Method in class org.elasticsearch.search.query.QuerySearchResult
- set(int) - Method in class org.apache.lucene.util.CombinedBitSet
- set(int) - Method in class org.elasticsearch.index.seqno.CountedBitSet
- set(int, E) - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
Sets the element at position
i
to the given value. - set(int, T) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
- set(long) - Method in class org.elasticsearch.common.util.BitArray
-
Set the
index
th bit. - set(long, byte) - Method in interface org.elasticsearch.common.util.ByteArray
-
Set a value at the given index and return the previous value.
- set(long, byte[], int, int) - Method in interface org.elasticsearch.common.util.ByteArray
-
Bulk set.
- set(long, double) - Method in interface org.elasticsearch.common.util.DoubleArray
-
Set a value at the given index and return the previous value.
- set(long, float) - Method in interface org.elasticsearch.common.util.FloatArray
-
Set a value at the given index and return the previous value.
- set(long, int) - Method in interface org.elasticsearch.common.util.IntArray
-
Set a value at the given index and return the previous value.
- set(long, long) - Method in interface org.elasticsearch.common.util.LongArray
-
Set a value at the given index and return the previous value.
- set(long, T) - Method in interface org.elasticsearch.common.util.ObjectArray
-
Set a value at the given index and return the previous value.
- set(String) - Method in class org.elasticsearch.script.ScoreScript.ExplanationHolder
-
Explain the current score.
- set(CommonStatsFlags.Flag, boolean) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- set(V) - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
-
Subclasses should invoke this method to set the result of the computation to
value
. - SET_MIN_COMPETITIVE_SCORE - Enum constant in enum class org.elasticsearch.search.profile.query.QueryTimingType
- setAbortOnVersionConflict(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Set whether or not version conflicts cause the action to abort.
- setAcceptDataLoss(boolean) - Method in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand.Builder
- setAction(String) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.RequestBuilder
- setActions(String...) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
-
Sets the list of action masks for the actions that should be returned
- setActions(String...) - Method in class org.elasticsearch.action.support.tasks.TasksRequestBuilder
- setActiveOnly(boolean) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequestBuilder
- setActivityTimeout(TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setAdditionalRoles(Set<DiscoveryNodeRole>) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
- setAfter(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
- setAfter(GetSnapshotsRequest.After) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
- setAggregatedDfs(AggregatedDfs) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- setAggregatedDfs(AggregatedDfs) - Method in class org.elasticsearch.search.internal.LegacyReaderContext
- setAggregatedDfs(AggregatedDfs) - Method in class org.elasticsearch.search.internal.ReaderContext
- setAggregations(Aggregations) - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- setAggregatorRegistrar(Consumer<ValuesSourceRegistry.Builder>) - Method in class org.elasticsearch.plugins.SearchPlugin.AggregationSpec
-
Set the function to register the
ValuesSource
to aggregator mappings for this aggregation - setAliases(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(String) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
- setAliases(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(BytesReference) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(BytesReference) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliases(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the aliases that will be associated with the index when it gets created
- setAliasFilter(AliasFilter) - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- setAliasName(String) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setAllocationDelay(TimeValue) - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Builder
- setAllocationId(long) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- setAllowedElasticProductOrigins(List<String>) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setAllowedFields(Predicate<String>) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- setAllowPartialSearchResults(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets if this request should allow partial results.
- setAllowsTemplates() - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setAllowUnmappedFields(boolean) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- setAllShards(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
-
Indicates whether the query should be validated on all shards
- setAnalyzer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Sets the analyzer name to use in order to analyze the text.
- setAnalyzer(String) - Method in class org.elasticsearch.index.search.MatchQueryParser
- setAnalyzer(String, Analyzer) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setAnalyzer(Analyzer) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the analyzer to use.
- setAnalyzer(Analyzer) - Method in class org.elasticsearch.index.search.MatchQueryParser
- setAnalyzer(Analyzer) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setAnalyzeWildcard(boolean) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setAndGetObservedState() - Method in class org.elasticsearch.cluster.ClusterStateObserver
-
sets the last observed state to the currently applied cluster state and returns it
- setAppliedVersion(DiscoveryNode, long) - Method in class org.elasticsearch.cluster.coordination.LagDetector
- setArtificial(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setAttributes(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Sets attributes that will include results
- setAutoGenerateMultiTermSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setAutoGenerateSynonymsPhraseQuery(boolean) - Method in class org.elasticsearch.index.search.MatchQueryParser
- setAutoShrinkVotingConfiguration(boolean) - Method in class org.elasticsearch.cluster.coordination.Reconfigurator
- SetBackedScalingCuckooFilter - Class in org.elasticsearch.common.util
-
An approximate set membership datastructure that scales as more unique values are inserted.
- SetBackedScalingCuckooFilter(int, Random, double) - Constructor for class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
- SetBackedScalingCuckooFilter(StreamInput, Random) - Constructor for class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
- setBackoffPolicy(BackoffPolicy) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Sets a custom backoff policy.
- setBan(TaskId, String, TransportChannel) - Method in class org.elasticsearch.tasks.TaskManager
-
Bans all tasks with the specified parent task from execution, cancels all tasks that are currently executing.
- setBatchedReduceSize(int) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets the number of shard results that should be reduced at once on the coordinating node.
- setBatchedReduceSize(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the number of shard results that should be reduced at once on the coordinating node.
- setBatches(Integer) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setBatchSize(int) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
The scroll size to control number of documents processed per batch
- setBatchSize(int) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
The scroll size to control number of documents processed per batch
- setBinding(BindingImpl<T>) - Method in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- setBlocks(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
- setBoost(boolean) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets whether to boost terms in query based on "score" or not.
- setBoost(float) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- setBoost(int) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext.Builder
-
Sets the query-time boost of the context.
- setBoost(int) - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext.Builder
-
Sets the query-time boost for the context Defaults to 1
- setBoostFactor(float) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the boost factor to use when boosting terms
- setBoostTerms(boolean) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setBoostTermsFactor(float) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setBottomSortValues(SearchSortValuesAndFormats) - Method in class org.elasticsearch.search.internal.ShardSearchRequest
-
Sets the bottom sort values that can be used by the searcher to filter documents that are after it.
- setBulkActions(int) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Sets when to flush a new bulk request based on the number of actions currently added.
- setBulkActions(int) - Method in class org.elasticsearch.action.bulk.BulkProcessor2.Builder
-
Sets when to flush a new bulk request based on the number of actions currently added.
- setBulkRetries(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setBulkSize(ByteSizeValue) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Sets when to flush a new bulk request based on the size of actions currently added.
- setBulkSize(ByteSizeValue) - Method in class org.elasticsearch.action.bulk.BulkProcessor2.Builder
-
Sets when to flush a new bulk request based on the size of actions currently added.
- setCategory(String) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext.Builder
-
Sets the category of the category.
- setCause(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
The cause for this index creation.
- setCcsMinimizeRoundtrips(boolean) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets whether network round-trips should be minimized when executing cross-cluster search requests.
- setCharFilters(List<NameOrDefinition>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- setCharset(Charset) - Method in class org.elasticsearch.common.logging.ESJsonLayout.Builder
- setChildInnerHits(Map<String, InnerHitsContext.InnerHitSubContext>) - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- setChunkSize(ByteSizeValue) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setCircuitBreaker(CircuitBreaker) - Method in interface org.elasticsearch.plugins.CircuitBreakerPlugin
-
The passed
CircuitBreaker
object is the same one that was constructed by theBreakerSettings
provided byCircuitBreakerPlugin.getCircuitBreaker(Settings)
. - setClient(Client) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
- setClusterStatePublisher(ClusterStatePublisher) - Method in class org.elasticsearch.cluster.service.MasterService
- setClusterStateSupplier(Supplier<ClusterState>) - Method in class org.elasticsearch.cluster.service.MasterService
- setCollapse(CollapseBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
- setCollector(InternalProfileCollector) - Method in class org.elasticsearch.search.profile.query.QueryProfiler
-
Set the collector that is associated with this profiler.
- setCommonTermsCutoff(Float) - Method in class org.elasticsearch.index.search.MatchQueryParser
-
Deprecated.See
MatchQueryParser.setCommonTermsCutoff(Float)
for more details - setComplete() - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- setCompletion(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setCompletionFields(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setCompress(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- setCompression(double) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.TDigest
- setCompressionEnabled(Compression.Enabled) - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Sets compression enabled configuration for this connection profile
- setCompressionScheme(Compression.Scheme) - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Sets compression scheme for this connection profile
- setConcreteIndex(Index) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
Sets a concrete index for this put mapping request.
- setConcreteIndex(Index) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
- setConcreteNodes(DiscoveryNode[]) - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- setConcurrentRequests(int) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Sets the number of concurrent requests allowed to be executed.
- setConflicts(String) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Sets abortOnVersionConflict based on REST-friendly names.
- setConnectTimeout(TimeValue) - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Sets a connect timeout for this connection profile
- setContent(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequestBuilder
-
Set the source of the script along with the content type of the source
- setContext(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequestBuilder
- setContextMappings(ContextMappings) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- setCopySettings(Boolean) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- setCorners(double, double, double, double) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds top left point.
- setCorners(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds points from a single geohash.
- setCorners(String, String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds points.
- setCorners(GeoPoint, GeoPoint) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds points.
- setCornersOGC(String, String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds corners in OGC standard bbox/ envelop format.
- setCornersOGC(GeoPoint, GeoPoint) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Adds corners in OGC standard bbox/ envelop format.
- setCorsResponseHeaders(HttpRequest, HttpResponse) - Method in class org.elasticsearch.http.CorsHandler
- setCreate(boolean) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Set to
true
to force only creation, not an update of an index template. - setCreate(boolean) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Set to
true
to force this index to useDocWriteRequest.OpType.CREATE
. - setCreated(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setCurrentNode(String) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Requests the explain API to explain an already assigned replica shard currently allocated to the given node.
- setCurrentNode(String) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
Requests the explain API to explain an already assigned replica shard currently allocated to the given node.
- setCurrentNodes(DiscoveryNodes) - Method in class org.elasticsearch.cluster.coordination.FollowersChecker
-
Update the set of known nodes, starting to check any new ones and stopping checking any previously-known-but-now-unknown ones.
- setCurrentProcessedCheckpointSupplier(LongSupplier) - Method in class org.elasticsearch.index.shard.RefreshListeners
-
Setup the engine used to find the last processed sequence number checkpoint.
- setCurrentReference(T) - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- setCurrentRefreshLocationSupplier(Supplier<Translog.Location>) - Method in class org.elasticsearch.index.shard.RefreshListeners
-
Setup the translog used to find the last refreshed location.
- setCurrentSnapshot() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Makes the request to return the current snapshot
- setCurrentTerm(long) - Method in interface org.elasticsearch.cluster.coordination.CoordinationState.PersistedState
-
Sets a new current term.
- setCurrentTerm(long) - Method in class org.elasticsearch.cluster.coordination.InMemoryPersistedState
- setCurrentTerm(long) - Method in class org.elasticsearch.discovery.PeerFinder
- setCustoms(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Should the cluster state result include the
ClusterState.Custom
. - setDataStream(String) - Method in class org.elasticsearch.cluster.metadata.DataStreamAction
- setDebugMode(RoutingAllocation.DebugMode) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- setDefaultOperator(QueryParser.Operator) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setDefaultOperator(BooleanClause.Occur) - Method in class org.elasticsearch.index.search.SimpleQueryStringQueryParser
- setDefaultPipeline(String) - Method in class org.elasticsearch.index.IndexSettings
- setDeferredCollector(Iterable<BucketCollector>) - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
-
Set the deferred collectors.
- setDeferredCollector(Iterable<BucketCollector>) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
-
Set the deferred collectors.
- setDeferredCollector(Iterable<BucketCollector>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.BestDocsDeferringCollector
-
Set the deferred collectors.
- setDeleted(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setDependency(Dependency<?>) - Method in class org.elasticsearch.common.inject.internal.InternalContext
- setDescription(String) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setDescriptions(String...) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
- setDescriptions(String...) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequestBuilder
-
Should the task match specific descriptions.
- setDestDocType(String) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the document type for the destination index
- setDestIndex(String) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the target index for the ReindexRequest
- setDestOpType(String) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Sets the optype on the destination index
- setDestPipeline(String) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Allows to set the ingest pipeline for the target index.
- setDestRouting(String) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the routing to decide which shard the documents need to be routed to
- setDestVersionType(VersionType) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the version type for the target index.
- setDetailed(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
-
Should the detailed task information be returned.
- setDetailed(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequestBuilder
-
Should detailed task information be returned.
- setDetailed(boolean) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequestBuilder
- setDetails(String) - Method in class org.elasticsearch.env.ShardLock
-
Update the details of the holder of this lock.
- setDetectNoop(boolean) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets whether to perform extra effort to detect noop updates via docAsUpsert.
- setDoc(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(byte[], XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(Object...) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified, the doc provided is a field and value pairs.
- setDoc(String, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(Map<String, Object>, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(IndexRequest) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(XContentBuilder) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the artificial document from which to generate term vectors.
- setDoc(XContentBuilder) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified.
- setDoc(XContentType, Object...) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc to use for updates when a script is not specified, the doc provided is a field and value pairs.
- setDocAsUpsert(boolean) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets whether the specified doc parameter should be used as upsert document.
- setDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.ParsedSingleBucketAggregation
- setDocCount(long) - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- setDocCountError(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms.AbstractTermsBucket
- setDocCountError(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms
- setDocCountError(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- setDocCountError(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- setDocCountError(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- setDocCountError(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- setDocs(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setDocTypes(String...) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Deprecated.Types are in the process of being removed. Instead of using a type, prefer to filter on a field of the document.
- setDocTypes(String...) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Deprecated.Types are in the process of being removed. Instead of using a type, prefer to filter on a field of the document.
- setDocument(int) - Method in class org.elasticsearch.script.DocBasedScript
-
Set the current document to run the script on next.
- setDocument(int) - Method in interface org.elasticsearch.script.DocReader
-
Set the underlying docId
- setDocument(int) - Method in class org.elasticsearch.script.DocValuesDocReader
- setDocument(int) - Method in class org.elasticsearch.script.FilterScript
-
Set the current document to run the script on next.
- setDocument(int) - Method in class org.elasticsearch.script.ScoreScript
-
Set the current document to run the script on next.
- setDocument(int) - Method in class org.elasticsearch.script.TermsSetQueryScript
-
Set the current document to run the script on next.
- setDocument(int) - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- setDocument(int) - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
- setDocument(int) - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- setDocumentField(String, DocumentField) - Method in class org.elasticsearch.search.SearchHit
- setDocValueFields(List<FieldAndFormat>) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Sets the stored fields to load from the docvalue and return.
- setDocVersion(long) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setDryRun(boolean) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
-
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. - setDynamicTemplates(Map<String, String>) - Method in class org.elasticsearch.action.index.IndexRequest
-
Specifies a map from the full path of field names to the name of dynamic mapping templates
- setEnableAssignment(EnableAssignmentDecider.Allocation) - Method in class org.elasticsearch.persistent.decider.EnableAssignmentDecider
- setEnabled(boolean) - Method in class org.elasticsearch.monitor.fs.FsHealthService
- setEnableGcDeletes(boolean) - Method in class org.elasticsearch.index.engine.EngineConfig
-
Enables / disables gc deletes
- setEnablePositionIncrements(boolean) - Method in class org.elasticsearch.index.search.MatchQueryParser
- setEnablePositionIncrements(boolean) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setEnforceDefaultTierPreference(boolean) - Method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
- setError(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- setESMessageFields(String) - Method in class org.elasticsearch.common.logging.ESJsonLayout.Builder
- setException(Throwable) - Method in class org.elasticsearch.common.util.concurrent.BaseFuture
-
Subclasses should invoke this method to set the result of the computation to an error,
throwable
. - setExistingShardsAllocators(Map<String, ExistingShardsAllocator>) - Method in class org.elasticsearch.cluster.routing.allocation.AllocationService
-
Inject the
ExistingShardsAllocator
s to use. - setExistingShardsAllocators(GatewayAllocator) - Method in class org.elasticsearch.cluster.ClusterModule
- setExists(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setExpandWildcardsClosed(boolean) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequestBuilder
-
Controls whether wildcard expressions will be expanded to existing closed indices
- setExpandWildcardsOpen(boolean) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequestBuilder
-
Controls whether wildcard expressions will be expanded to existing open indices
- setExpireAfterAccess(TimeValue) - Method in class org.elasticsearch.common.cache.CacheBuilder
-
Sets the amount of time before an entry in the cache expires after it was last accessed.
- setExpireAfterWrite(TimeValue) - Method in class org.elasticsearch.common.cache.CacheBuilder
-
Sets the amount of time before an entry in the cache expires after it was written.
- setExplain(boolean) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
-
Sets the explain flag (defaults to
false
). - setExplain(boolean) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Sets explain
- setExplain(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
-
Indicates if detailed information about the query should be returned.
- setExplain(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Should each
SearchHit
be returned with an explanation of the hit (ranking). - setExplain(boolean) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setFeatures(Set<String>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Set the features on the stream.
- setFeatures(GetIndexRequest.Feature...) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequestBuilder
- setFeatureStates(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Provide a list of features whose state indices should be included in the snapshot
- setFeatureStates(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets the list of features whose states should be restored as part of this snapshot
- setFetchFields(List<FieldAndFormat>) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Sets the stored fields to load and return as part of the search request.
- setFetchSource(boolean) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Indicates whether the response should contain the stored _source
- setFetchSource(boolean) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Indicates whether the response should contain the stored _source.
- setFetchSource(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Indicates whether the response should contain the stored _source for every hit
- setFetchSource(boolean) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Indicates whether the response should contain the updated _source.
- setFetchSource(String[], String[]) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Indicate that _source should be returned, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String[], String[]) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Indicate that _source should be returned, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String[], String[]) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Indicate that _source should be returned with every hit, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String[], String[]) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Indicate that _source should be returned, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String, String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Indicate that _source should be returned, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String, String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Indicate that _source should be returned, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String, String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Indicate that _source should be returned with every hit, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSource(String, String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Indicate that _source should be returned with every hit, with an "include" and/or "exclude" set which can include simple wildcard elements.
- setFetchSourceContext(FetchSourceContext) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setField(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Sets the field that its analyzer will be used to analyze the text.
- setField(String) - Method in class org.elasticsearch.index.query.functionscore.RandomScoreFunctionBuilder
-
Set the field to be used for random number generation.
- setField(String) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setFielddata(boolean) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- setFielddata(boolean, TextFieldMapper.FielddataFrequencyFilter) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- setFieldData(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setFieldDataCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
- setFieldDataFields(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setFieldName(String) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- setFieldNames(String[]) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the field names that will be used when generating the 'More Like This' query.
- setFields(String...) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
- setFields(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
-
Sets the fields to retrieve.
- setFields(String...) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequestBuilder
-
The list of field names to retrieve.
- setFields(Fields, Set<String>, EnumSet<TermVectorsRequest.Flag>, Fields) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setFields(Fields, Set<String>, EnumSet<TermVectorsRequest.Flag>, Fields, TermVectorsFilter) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setFieldsOptionEmulationEnabled(boolean) - Method in class org.elasticsearch.action.search.SearchRequest
-
Deprecated.This option is only available temporarily. Instead of using this setter directly, use the parameter on the rest request. The bwc emulation will not be necessary on 8.0 any more, so this setter will not be availabe there.
- setFieldStatistics(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to return the field statistics for each term in the shard or skip.
- setFieldValue(int) - Method in class org.elasticsearch.index.mapper.CustomTermFreqField
- setFieldValue(String, Object) - Method in class org.elasticsearch.ingest.IngestDocument
-
Sets the provided value to the provided path in the document.
- setFieldValue(TemplateScript.Factory, Object, boolean) - Method in class org.elasticsearch.ingest.IngestDocument
-
Sets the provided value to the provided path in the document.
- setFieldValue(TemplateScript.Factory, ValueSource) - Method in class org.elasticsearch.ingest.IngestDocument
-
Sets the provided value to the provided path in the document.
- setFieldValue(TemplateScript.Factory, ValueSource, boolean) - Method in class org.elasticsearch.ingest.IngestDocument
-
Sets the provided value to the provided path in the document.
- setFileDetailsComplete() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- setFilter(QueryBuilder) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- setFilter(QueryBuilder) - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- setFilterSettings(TermVectorsRequest.FilterSettings) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the settings for filtering out terms.
- setFinalPipeline(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the final ingest pipeline to be executed before indexing the document.
- setFlags(String) - Method in class org.elasticsearch.search.suggest.completion.RegexOptions.Builder
-
Sets the regular expression syntax flags see
RegexpFlag
- setFlush(boolean) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequestBuilder
-
Should flush be performed after the merge.
- setFlush(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setFlushCondition(Supplier<Boolean>) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
- setFlushInterval(TimeValue) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
-
Sets a flush interval flushing *any* bulk actions pending if the interval passes.
- setFlushInterval(TimeValue) - Method in class org.elasticsearch.action.bulk.BulkProcessor2.Builder
-
Sets a flush interval flushing *any* bulk actions pending if the interval passes.
- setForce(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequestBuilder
- setForceAnalyzer(Analyzer) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setForcedRefresh(boolean) - Method in class org.elasticsearch.action.bulk.BulkShardResponse
- setForcedRefresh(boolean) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setForcedRefresh(boolean) - Method in class org.elasticsearch.action.DocWriteResponse
- setForcedRefresh(boolean) - Method in class org.elasticsearch.action.resync.ResyncReplicationResponse
- setForcedRefresh(boolean) - Method in interface org.elasticsearch.action.support.WriteResponse
-
Mark the response as having forced a refresh? Requests that set
WriteRequest.setRefreshPolicy(RefreshPolicy)
toWriteRequest.RefreshPolicy.IMMEDIATE
should always mark this as true. - setForcedRefresh(boolean) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Response
- setForceQuoteAnalyzer(Analyzer) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setFormat(String) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- setFormat(String) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Specifies a format specification that will be used to format the output value of this sort field.
- setFreq(int) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- setFrom(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
From index to start the search from.
- setFrom(int) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setFromSortValue(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
- setFuzziness(int) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Sets the level of fuzziness used to create suggestions using a
Fuzziness
instance. - setFuzziness(Fuzziness) - Method in class org.elasticsearch.index.search.MatchQueryParser
- setFuzziness(Fuzziness) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setFuzziness(Fuzziness) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Sets the level of fuzziness used to create suggestions using a
Fuzziness
instance. - setFuzzyMaxExpansions(int) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setFuzzyMinLength(int) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Sets the minimum length of input string before fuzzy suggestions are returned, defaulting to 3.
- setFuzzyPrefixLength(int) - Method in class org.elasticsearch.index.search.MatchQueryParser
- setFuzzyPrefixLength(int) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Sets the minimum length of the input, which is not checked for fuzzy alternatives, defaults to 1
- setFuzzyRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.elasticsearch.index.search.MatchQueryParser
- setFuzzyRewriteMethod(MultiTermQuery.RewriteMethod) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setFuzzyTranspositions(boolean) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setGeoBoundingBox(GeoBoundingBox) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- setGeoPoint(GeoPoint) - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext.Builder
-
Sets the geo point of the context.
- setGet(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setGetResult(GetResult) - Method in class org.elasticsearch.action.update.UpdateResponse.Builder
- setGetResult(GetResult) - Method in class org.elasticsearch.action.update.UpdateResponse
- setGlobalIndex(String) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
- setGlobalPipeline(String) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
- setGlobalRouting(String) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
- setGlobalText(String) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
-
Sets the text to provide suggestions for.
- setGlobalType(String) - Method in class org.elasticsearch.action.bulk.BulkProcessor.Builder
- setGroups(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setGroupTieBreaker(float) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setHandshakeTimeout(TimeValue) - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Sets a handshake timeout for this connection profile
- setHasPendingAsyncFetch() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Sets a flag that signals that current allocation run has not processed all of the in-flight or available shard or store fetches.
- setHeader(BytesReference) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setHeaders(Tuple<Map<String, String>, Map<String, Set<String>>>) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
- setHighFreqMinimumNumberShouldMatch(String) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
-
Deprecated.
- setHighlightBuilder(HighlightBuilder) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setHit(SearchHit) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- setId(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequestBuilder
- setId(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequestBuilder
- setId(String) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequestBuilder
- setId(String) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
Sets the id of the document to delete.
- setId(String) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setId(String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Sets the id to get a score explanation for.
- setId(String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Sets the id of the document to fetch.
- setId(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the id to index the document under.
- setId(String) - Method in class org.elasticsearch.action.ingest.DeletePipelineRequest
- setId(String) - Method in class org.elasticsearch.action.ingest.DeletePipelineRequestBuilder
-
Sets the id of the pipeline to delete.
- setId(String) - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- setId(String) - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequestBuilder
-
Set the id for the pipeline to simulate
- setId(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the id of the document.
- setId(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the id of the indexed document.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
only perform this delete request if the document was last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
only perform this delete request if the document was last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in interface org.elasticsearch.action.DocWriteRequest
-
only performs this request if the document was last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.action.index.IndexRequest
-
only performs this indexing request if the document was last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
only perform this indexing request if the document was last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.action.update.UpdateRequest
-
only performs this update request if the document's last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
only perform this update request if the document was last modification was assigned the given primary term.
- setIfPrimaryTerm(long) - Method in class org.elasticsearch.index.engine.Engine.Get
- setIfSeqNo(long) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
only perform this delete request if the document was last modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
only perform this delete request if the document was last modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in interface org.elasticsearch.action.DocWriteRequest
-
only perform this request if the document was last modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in class org.elasticsearch.action.index.IndexRequest
-
only perform this indexing request if the document was last modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
only perform this indexing request if the document was last modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in class org.elasticsearch.action.update.UpdateRequest
-
only perform this update request if the document's modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
only perform this update request if the document was last modification was assigned the given sequence number.
- setIfSeqNo(long) - Method in class org.elasticsearch.index.engine.Engine.Get
- setIgnoreIdleThreads(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
- setIgnoreIndexSettings(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets the list of index settings and index settings groups that shouldn't be restored from snapshot
- setIgnoreIndexSettings(List<String>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets the list of index settings and index settings groups that shouldn't be restored from snapshot
- setIgnoreUnavailable(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Makes the request ignore unavailable snapshots
- setIgnoreUnavailable(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
-
Set to
true
to ignore unavailable snapshots, instead of throwing an exception. - setIgnoreUnmapped(boolean) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setIncludeAliases(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
If set to true the restore procedure will restore aliases
- setIncludeDiskInfo(boolean) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
Whether to include information about the gathered disk information of nodes in the cluster
- setIncludeGlobalState(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Set to true if snapshot should include global cluster state
- setIncludeInParent(boolean) - Method in class org.elasticsearch.index.mapper.NestedObjectMapper
- setIncludeInRoot(boolean) - Method in class org.elasticsearch.index.mapper.NestedObjectMapper
- setIncludeSegmentFileSizes(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setIncludeUnmapped(boolean) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequestBuilder
- setIncludeYesDecisions(boolean) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
Whether to include "YES" decider decisions in the response instead of only "NO" decisions
- setIndex(String) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Sets the index name of the shard to explain.
- setIndex(String) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
The index name to use when finding the shard to explain
- setIndex(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the name of the index to be created
- setIndex(String) - Method in class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
- setIndex(String) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequestBuilder
- setIndex(String) - Method in class org.elasticsearch.action.support.single.shard.SingleShardOperationRequestBuilder
-
Sets the index.
- setIndex(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the index where the document is located.
- setIndex(String) - Method in class org.elasticsearch.cluster.metadata.DataStreamAction
- setIndex(String) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- setIndex(String) - Method in exception org.elasticsearch.ElasticsearchException
- setIndex(Index) - Method in exception org.elasticsearch.ElasticsearchException
- setIndexFilter(QueryBuilder) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequestBuilder
- setIndexFormat(int) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setIndexing(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setIndexPattern(String) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setIndexSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets index settings that should be added or replaced during restore
- setIndexSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets index settings that should be added or replaced during restore
- setIndexSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets index settings that should be added or replaced during restore
- setIndexSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets index settings that should be added or replaced during restore
- setIndexToDocValue(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForDoubles.Leaf
- setIndexToDocValue(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForFloats.Leaf
- setIndexToDocValue(long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForLongs.Leaf
- setIndexToDocValue(long) - Method in class org.elasticsearch.search.sort.BucketedSort.Leaf
-
Set the value at the index to the value of the document to which we just advanced.
- setIndexType(String) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
-
Deprecated.Index types are going away over the next two major releases. New system indices should accept the default, which is
MapperService.SINGLE_MAPPING_NAME
. - setIndices(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the node indices stats be returned.
- setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequestBuilder
-
Sets the indices the search will be executed on.
- setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequestBuilder
-
Sets a list of indices that should be cloned from the source to the target snapshot
- setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets a list of indices that should be included into the snapshot
- setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets the list of indices that should be restored from snapshot
- setIndices(String...) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
When
ClusterStateRequestBuilder.setMetadata(boolean)
is set, which indices to return theIndexMetadata
for. - setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
-
Sets the indices to be closed
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequestBuilder
- setIndices(String[]) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequestBuilder
-
Deprecated.
- setIndices(String[]) - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
-
Sets the indices to be opened
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockRequestBuilder
-
Sets the indices to be blocked
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Sets the indices the update settings will execute on
- setIndices(String...) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoreRequestBuilder
-
Sets the indices for the shard stores request
- setIndices(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the indices the search will be executed on.
- setIndices(String...) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequestBuilder
- setIndices(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequestBuilder
- setIndices(CommonStatsFlags) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder
-
Should the node indices stats be returned.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequestBuilder
-
Specifies what type of requested indices to ignore and how to deal indices wildcard expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequestBuilder
-
Specifies the indices options.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Specifies the indices options.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Specifies what type of requested indices to ignore and how to deal with wildcard expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.alias.get.BaseAliasesRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions For example indices that don't exist.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequestBuilder
-
Deprecated.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequestBuilder
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
-
Specifies what type of requested indices to ignore and how to deal with wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions For example indices that don't exist.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoreRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions By default, expands wildcards to both open and closed indices
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.search.MultiSearchRequestBuilder
-
Specifies what type of requested indices to ignore and how to deal with wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Specifies what type of requested indices to ignore and wildcard indices expressions.
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequestBuilder
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequestBuilder
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Set the IndicesOptions for controlling unavailable indices
- setIndicesOptions(IndicesOptions) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Set the IndicesOptions for controlling unavailable indices
- setInitialBuffer(int) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- setInitialConfiguration(CoordinationMetadata.VotingConfiguration) - Method in class org.elasticsearch.cluster.coordination.Coordinator
-
Sets the initial configuration to the given
CoordinationMetadata.VotingConfiguration
. - setInitialState(ClusterState) - Method in class org.elasticsearch.cluster.coordination.CoordinationState
-
Used to bootstrap a cluster by injecting the initial state and configuration.
- setInitialState(ClusterState) - Method in interface org.elasticsearch.cluster.service.ClusterApplier
-
Sets the initial state for this applier.
- setInitialState(ClusterState) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- setInnerCollapse(CollapseBuilder) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setInnerHits(List<InnerHitBuilder>) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- setInnerHits(Map<String, SearchHits>) - Method in class org.elasticsearch.search.SearchHit
- setInnerHits(InnerHitBuilder) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- setInternalActionLongTimeout(TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setInternalActionRetryTimeout(TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setInternalActionTimeout(TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setInterval(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedAutoDateHistogram
- setInterval(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
- setInterval(TimeValue) - Method in class org.elasticsearch.common.util.concurrent.AbstractAsyncTask
-
Change the interval between runs.
- setKeepAlive(String) - Method in class org.elasticsearch.search.builder.PointInTimeBuilder
-
If specified, the search layer will keep this point in time around for at least the given keep-alive.
- setKeepAlive(TimeValue) - Method in class org.elasticsearch.search.builder.PointInTimeBuilder
-
If specified, the search layer will keep this point in time around for at least the given keep-alive.
- setKeyAsString(String) - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- setKeyed(boolean) - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- setKeyed(boolean) - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
-
Set whether the XContent should be keyed
- setLastAcceptedState(ClusterState) - Method in interface org.elasticsearch.cluster.coordination.CoordinationState.PersistedState
-
Sets a new last accepted cluster state.
- setLastAcceptedState(ClusterState) - Method in class org.elasticsearch.cluster.coordination.InMemoryPersistedState
- setLastAccessTime() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
-
sets the lasAccessTime flag to now
- setLeafReaderContext(LeafReaderContext) - Method in class org.elasticsearch.search.aggregations.bucket.DocCountProvider
- setLenient(boolean) - Method in class org.elasticsearch.index.search.MatchQueryParser
- setLevel(Logger, String) - Static method in class org.elasticsearch.common.logging.Loggers
-
Set the level of the logger.
- setLevel(Logger, Level) - Static method in class org.elasticsearch.common.logging.Loggers
- setLikeFields(Fields...) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setLikeText(String...) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setLikeText(List<String>) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setLimitAndOverhead(long, double) - Method in class org.elasticsearch.common.breaker.ChildMemoryCircuitBreaker
- setLimitAndOverhead(long, double) - Method in interface org.elasticsearch.common.breaker.CircuitBreaker
-
sets the new limit and overhead values for the circuit breaker.
- setLimitAndOverhead(long, double) - Method in class org.elasticsearch.common.breaker.NoopCircuitBreaker
- setListener(IndexFieldDataCache.Listener) - Method in class org.elasticsearch.index.fielddata.IndexFieldDataService
-
Sets a
IndexFieldDataCache.Listener
passed to eachIndexFieldData
creation to capture onCache and onRemoval events. - setLocal(boolean) - Method in class org.elasticsearch.action.support.master.MasterNodeReadOperationRequestBuilder
-
Specifies if the request should be executed on local node rather than on master
- setLocalCheckpointOfSafeCommit(long) - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
- setLocalNode(DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
- setLocalTranslogStage() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- setLowFreqMinimumNumberShouldMatch(String) - Method in class org.apache.lucene.queries.ExtendedCommonTermsQuery
-
Deprecated.
- setMappings(String) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setMappings(XContentBuilder) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setMapUnmappedFieldAsString(boolean) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- setMasterApplyElapsedMillis(long) - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- setMasterNodeTimeout(String) - Method in class org.elasticsearch.action.support.master.MasterNodeOperationRequestBuilder
-
Sets the master node timeout in case the master has not yet been discovered.
- setMasterNodeTimeout(TimeValue) - Method in class org.elasticsearch.action.support.master.MasterNodeOperationRequestBuilder
-
Sets the master node timeout in case the master has not yet been discovered.
- setMax(Double) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram.ParsedBucket
- setMaxAsString(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram.ParsedBucket
- setMaxBytesInFlight(ByteSizeValue) - Method in class org.elasticsearch.action.bulk.BulkProcessor2.Builder
-
Sets the maximum number of bytes allowed in in-flight requests (both the BulkRequest being built up by the BulkProcessor and any BulkRequests sent to Retry2 that have not yet completed) before subsequent calls to add()result in EsRejectedExecutionException.
- setMaxChildren(int) - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- setMaxConcurrentGroupRequests(int) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- setMaxConcurrentSearchRequests(int) - Method in class org.elasticsearch.action.search.MultiSearchRequestBuilder
-
Sets how many search requests specified in this multi search requests are allowed to be ran concurrently.
- setMaxConcurrentShardRequests(int) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets the number of shard requests that should be executed concurrently on a single node.
- setMaxConcurrentShardRequests(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the number of shard requests that should be executed concurrently on a single node.
- setMaxConcurrentSnapshotFileDownloads(int) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setMaxDeterminizedStates(int) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Sets the maximum automaton states allowed for the fuzzy expansion
- setMaxDeterminizedStates(int) - Method in class org.elasticsearch.search.suggest.completion.RegexOptions.Builder
-
Sets the maximum automaton states allowed for the regular expression expansion
- setMaxDocFreq(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMaxDocFreq(int) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMaxDocFreq(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Set the maximum frequency in which words may still appear.
- setMaxDocFreqPct(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Set the maximum percentage in which words may still appear.
- setMaxDocs(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Maximum number of processed documents.
- setMaxExpansions(int) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
- setMaxExpansions(int) - Method in class org.elasticsearch.index.search.MatchQueryParser
- setMaximumWeight(long) - Method in class org.elasticsearch.common.cache.CacheBuilder
- setMaxIssuedSeqNoSupplier(LongSupplier) - Method in class org.elasticsearch.index.shard.RefreshListeners
-
Setup the engine used to find the max issued seqNo.
- setMaxNestedDepth(int) - Static method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Set the maximum nested depth of bool queries.
- setMaxNumberOfRetries(int) - Method in class org.elasticsearch.action.bulk.BulkProcessor2.Builder
-
Sets the maximum number of times a BulkRequest will be retried if it fails.
- setMaxNumSegments(int) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequestBuilder
-
Will force merge the index down to <= maxNumSegments.
- setMaxNumTerms(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMaxNumTokensParsed(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
- setMaxPermits(int) - Method in class org.elasticsearch.common.util.concurrent.AdjustableSemaphore
- setMaxPrimaryShardSize(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
Sets the max primary shard size of the target index.
- setMaxPrimaryShardSize(ByteSizeValue) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
-
Sets the max primary shard size of the target index.
- setMaxQueryTerms(int) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMaxQueryTerms(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the maximum number of query terms that will be included in any generated query.
- setMaxRetries(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Set the total number of retries attempted for rejections.
- setMaxRetries(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Total number of retries attempted for rejections.
- setMaxTermFreq(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMaxWordLen(int) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMaxWordLen(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the maximum word length above which words will be ignored.
- setMaxWordLength(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMBPerSec(ByteSizeValue) - Method in class org.elasticsearch.common.util.CombinedRateLimiter
- setMerge(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setMergeValidator(FieldMapper.MergeValidator<T>) - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Sets a custom merge validator.
- setMessageListener(TransportMessageListener) - Method in class org.elasticsearch.transport.TcpTransport
- setMessageListener(TransportMessageListener) - Method in interface org.elasticsearch.transport.Transport
- setMetadata(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Should the cluster state result include the
Metadata
. - setMetadata(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- setMetadata(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Associate metadata with this
AggregationBuilder
. - setMetadata(Map<String, Object>) - Method in interface org.elasticsearch.search.aggregations.BaseAggregationBuilder
-
Set the aggregation's metadata.
- setMetadata(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- setMetadata(Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
-
Associate metadata with this
PipelineAggregationBuilder
. - setMin(Double) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram.ParsedBucket
- setMinAsString(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram.ParsedBucket
- setMinDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- setMinDocFreq(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMinDocFreq(int) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMinDocFreq(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the frequency at which words will be ignored which do not occur in at least this many docs.
- setMinimumIntervalExpression(String) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- setMinimumNodeVersion(Version) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setMinimumShouldMatch(String) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
-
Number of terms that must match the generated query expressed in the common syntax for minimum should match.
- setMinimumShouldMatchField(String) - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- setMinimumShouldMatchScript(Script) - Method in class org.elasticsearch.index.query.TermsSetQueryBuilder
- setMinScore(float) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the minimum score below which docs will be filtered out.
- setMinScore(float) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- setMinScore(float) - Method in class org.elasticsearch.index.query.functionscore.ScriptScoreQueryBuilder
- setMinTermFreq(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMinTermFreq(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the frequency below which terms will be ignored in the source doc.
- setMinTermFrequency(int) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMinWordLen(int) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMinWordLen(int) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets the minimum word length below which words will be ignored.
- setMinWordLength(int) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setMissing(Object) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- setMoreLikeFields(String[]) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setMultiValueMode(MultiValueMode) - Method in class org.elasticsearch.index.query.functionscore.DecayFunctionBuilder
- setName(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryRequestBuilder
- setName(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequestBuilder
-
Sets the repository name
- setName(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository name
- setName(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequestBuilder
-
Sets the repository name
- setName(String) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedIndexAbstraction
- setName(String) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequestBuilder
-
Sets the name of the index template to delete.
- setName(String) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setName(String) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.ParsedGeoGrid
- setName(String) - Method in class org.elasticsearch.search.aggregations.ParsedAggregation
- setNames(String...) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequestBuilder
- setNeighbours(List<Integer>) - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext.Builder
-
Sets the precision levels at which geohash cells neighbours are considered.
- setNestedFilter(QueryBuilder) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Deprecated.set nested sort with
FieldSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withFieldSortBuilder.getNestedSort()
- setNestedFilter(QueryBuilder) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Deprecated.set nested sort with
GeoDistanceSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withGeoDistanceSortBuilder.getNestedSort()
- setNestedFilter(QueryBuilder) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Deprecated.set nested sort with
ScriptSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withScriptSortBuilder.getNestedSort()
- setNestedPath(String) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Deprecated.set nested sort with
FieldSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withFieldSortBuilder.getNestedSort()
- setNestedPath(String) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Deprecated.set nested sort with
GeoDistanceSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withGeoDistanceSortBuilder.getNestedSort()
- setNestedPath(String) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Deprecated.set nested sort with
ScriptSortBuilder.setNestedSort(NestedSortBuilder)
and retrieve withScriptSortBuilder.getNestedSort()
- setNestedSort(NestedSortBuilder) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Sets the
NestedSortBuilder
to be used for fields that are inside a nested object. - setNestedSort(NestedSortBuilder) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Sets the
NestedSortBuilder
to be used for fields that are inside a nested object. - setNestedSort(NestedSortBuilder) - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- setNestedSort(NestedSortBuilder) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Sets the
NestedSortBuilder
to be used for fields that are inside a nested object. - setNetNew() - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setNewIndexName(String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Sets the alias to rollover to another index
- setNewIndexName(String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- setNextAggregationValue(Object) - Method in class org.elasticsearch.script.AggregationScript
-
Sets per-document aggregation
_value
. - setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.BytesRefs
- setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Dates
- setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
- setNextDocId(int) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
-
Set the current doc ID.
- setNextDocId(int) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType.IpScriptDocValues
- setNextDocId(int) - Method in interface org.elasticsearch.script.field.DocValuesField
-
Set the current document ID.
- setNextGatherOffset(long, int) - Method in class org.elasticsearch.search.sort.BucketedSort.ForDoubles
- setNextGatherOffset(long, int) - Method in class org.elasticsearch.search.sort.BucketedSort.ForFloats
- setNextGatherOffset(long, int) - Method in class org.elasticsearch.search.sort.BucketedSort.ForLongs
- setNextGatherOffset(long, int) - Method in class org.elasticsearch.search.sort.BucketedSort
-
Set the next index that should be "gathered" for a bucket rooted at
rootIndex
. - setNextReader(LeafReaderContext) - Method in class org.elasticsearch.index.mapper.DocValueFetcher
- setNextReader(LeafReaderContext) - Method in class org.elasticsearch.index.mapper.NestedValueFetcher
- setNextReader(LeafReaderContext) - Method in class org.elasticsearch.index.mapper.StoredValueFetcher
- setNextReader(LeafReaderContext) - Method in interface org.elasticsearch.index.mapper.ValueFetcher
-
Update the leaf reader used to fetch values.
- setNextReader(LeafReaderContext) - Method in interface org.elasticsearch.search.fetch.FetchSubPhaseProcessor
-
Called when moving to the next
LeafReaderContext
for a set of hits - setNextReader(LeafReaderContext) - Method in class org.elasticsearch.search.fetch.subphase.FieldFetcher
- setNode(String) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- setNodeConnectionsService(NodeConnectionsService) - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- setNodeConnectionsService(NodeConnectionsService) - Method in class org.elasticsearch.cluster.service.ClusterService
- setNodeId(String) - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Builder
- setNodeIdAndClusterId(String, String) - Static method in class org.elasticsearch.common.logging.NodeAndClusterIdConverter
-
Updates only once the clusterID and nodeId.
- setNodeName(String) - Static method in class org.elasticsearch.common.logging.LogConfigurator
-
Sets the node name.
- setNodes(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Should the cluster state result include the
DiscoveryNodes
. - setNodes(String...) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- setNodes(List<VerifyRepositoryResponse.NodeView>) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- setNodeSeen(boolean) - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Builder
- setNodesIds(String...) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequestBuilder
- setNodesIds(String...) - Method in class org.elasticsearch.action.support.tasks.TasksRequestBuilder
- setNoops(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setNormalizer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Instead of setting the analyzer and tokenizer, sets the normalizer as name
- setNumberOfSignificantValueDigits(int) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.Hdr
- setNumBuckets(int) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- setNumBuckets(int) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- setNumericType(String) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Forces the numeric type to use for the field.
- setNumPriorUsesInASequence(short) - Method in interface org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttribute
- setNumPriorUsesInASequence(short) - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateSequenceAttributeImpl
- setOccur(BooleanClause.Occur) - Method in class org.elasticsearch.index.search.MatchQueryParser
- setOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a type modelling a
Set
whose elements are of typeelementType
. - setOffset(int) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
- setOffsets(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to return the start and stop offsets for each term if they were stored or skip offsets.
- setOnCancel(CancellableThreads.OnCancel) - Method in class org.elasticsearch.common.util.CancellableThreads
-
Registers a callback that will be invoked when some running operations are cancelled or
CancellableThreads.checkForCancel()
is called. - setOnce(int, E) - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
- setOnlyExpungeDeletes(boolean) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequestBuilder
-
Should the merge only expunge deletes from the index, without full merging.
- setOperationPrimaryTerm(long) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Sets the current operation primary term.
- setOpType(DocWriteRequest.OpType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the type of operation to perform.
- setOrder(int) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the order of this template if more than one template matches.
- setOrder(SortOrder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
- setOrigin(String) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setOutput(OutputStream) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Sets the output stream to use for writing until this writer is closed.
- setParams(PersistentTaskParams) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- setParent(String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Simple sets the routing.
- setParentTask(String, long) - Method in class org.elasticsearch.action.admin.indices.diskusage.AnalyzeIndexDiskUsageRequest
- setParentTask(String, long) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- setParentTask(String, long) - Method in interface org.elasticsearch.tasks.TaskAwareRequest
-
Set a reference to task that caused this task to be run.
- setParentTask(TaskId) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- setParentTask(TaskId) - Method in interface org.elasticsearch.tasks.TaskAwareRequest
-
Set a reference to task that created this request.
- setParentTask(TaskId) - Method in class org.elasticsearch.transport.TransportRequest
-
Set a reference to task that created this request.
- setParentTaskId(TaskId) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- setParentTaskId(TaskId) - Method in class org.elasticsearch.action.support.tasks.TasksRequestBuilder
-
Match all children of the provided task.
- setPartial(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
If set to true the request should snapshot indices with unavailable shards
- setPartial(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
If set to true the restore procedure will restore partially snapshotted indices
- setPatterns(List<String>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the match expression that will be used to match on indices created.
- setPayloads(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to return the payloads for each term or skip.
- setPercents(double[]) - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
-
Set the percentages to calculate percentiles for in this aggregation
- setPerFieldAnalyzer(Map<String, String>) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the analyzer used at each field when generating term vectors.
- setPersistentSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the source containing the persistent settings to be updated.
- setPersistentSettings(Map<String, ?>) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the persistent settings to be updated.
- setPersistentSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the persistent settings to be updated.
- setPersistentSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the persistent settings to be updated.
- setPhase(String) - Method in class org.elasticsearch.action.support.replication.ReplicationTask
-
Set the current phase of the task.
- setPhase(String) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
-
Set the current phase of the task.
- setPhraseSlop(int) - Method in class org.elasticsearch.index.search.MatchQueryParser
- setPhraseSlop(int) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setPingInterval(TimeValue) - Method in class org.elasticsearch.transport.ConnectionProfile.Builder
-
Sets a ping interval for this connection profile
- setPipeline(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the ingest pipeline to be executed before indexing the document
- setPipeline(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the ingest pipeline to be executed before indexing the document
- setPipeline(String) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Set the ingest pipeline to set on index requests made by this action.
- setPipeline(String) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequestBuilder
- setPointInTime(PointInTimeBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
If specified, Elasticsearch will execute this search request using reader contexts from that point in time.
- setPolicies(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Sets slm policy patterns
- setPosition(int) - Method in class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- setPositions(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to return the positions for each term if stored or skip.
- setPostFilter(QueryBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a filter that will be executed after the query has been executed and only has affect on the search hits (not aggregations).
- setPrecision(double) - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
-
Set's the false-positive rate for individual cuckoo filters.
- setPrecision(int) - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext.Builder
-
Sets the precision level for computing the geohash from the context geo point.
- setPreference(String) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequestBuilder
-
Sets the preference to execute the search.
- setPreference(String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Sets the shard preference.
- setPreference(String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Sets the preference to execute the search.
- setPreference(String) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
-
Sets the preference to execute the search.
- setPreference(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the preference to execute the search.
- setPreference(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the preference to execute the search.
- setPreFilterShardSize(int) - Method in class org.elasticsearch.action.search.SearchRequest
-
Sets a threshold that enforces a pre-filter roundtrip to pre-filter search shards based on query rewriting if the number of shards the search request expands to exceeds the threshold.
- setPreFilterShardSize(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets a threshold that enforces a pre-filter roundtrip to pre-filter search shards based on query rewriting if the number of shards the search request expands to exceeds the threshold.
- setPrefix(boolean) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext.Builder
-
Sets if the context should be treated as a prefix or not.
- setPrefix(BytesRef) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setPreload(MMapDirectory, LockFactory, Set<String>) - Static method in class org.elasticsearch.index.store.FsDirectoryFactory
- setPreserveExisting(boolean) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
-
Iff set to
true
this settings update will only add settings not already set on an index. - setPreserveExisting(boolean) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Iff set to
true
this settings update will only add settings not already set on an index. - setPreserveExisting(boolean) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
- setPrimary(boolean) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
Whether the primary or replica should be explained
- setPrimary(Boolean) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Sets whether to explain the allocation of the primary shard or a replica shard copy for the shard id (see
ClusterAllocationExplainRequest.getShard()
). - setPrimaryIndex(String) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setPrimaryTerm(long) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setPrimaryTerm(long) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- setPrimaryTerm(long) - Method in class org.elasticsearch.search.SearchHit
- setPriorSystemIndexDescriptors(List<SystemIndexDescriptor>) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setProfile(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Should the query be profiled.
- setProfiler(QueryProfiler) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- setProgressListener(SearchProgressListener) - Method in class org.elasticsearch.action.search.SearchTask
-
Attach a
SearchProgressListener
to this task. - setProxyDelegates(T) - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- setPublicationCommitElapsedMillis(long) - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- setPublicationCompletionElapsedMillis(long) - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- setPublicationContextConstructionElapsedMillis(long) - Method in class org.elasticsearch.cluster.ClusterStatePublicationEvent
- setQuery(Query) - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- setQuery(QueryBuilder) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
-
The query to validate.
- setQuery(QueryBuilder) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Sets the query to get a score explanation for.
- setQuery(QueryBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Constructs a new search source builder with a search query.
- setQuery(QueryBuilder) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Set the query for selective delete
- setQuery(QueryBuilder) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Set the query for selective update
- setQueryCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
- setQueryCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setQueryWeight(float) - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- setQueryWeight(float) - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Sets the original query weight for rescoring.
- setQuoteFieldSuffix(String) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setReaderWrapper(Function<IndexService, CheckedFunction<DirectoryReader, DirectoryReader, IOException>>) - Method in class org.elasticsearch.index.IndexModule
-
Sets the factory for creating new
DirectoryReader
wrapper instances. - setRealtime(boolean) - Method in class org.elasticsearch.action.get.GetRequestBuilder
- setRealtime(boolean) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
- setRealtime(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether term vectors are generated real-time.
- setReason(String) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
-
Set the reason for canceling the task.
- setReason(String) - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Builder
- setReasonCancelled(String) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setRecheckInterval(TimeValue) - Method in class org.elasticsearch.persistent.PersistentTasksClusterService
- setRecovery(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setRefresh(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setRefresh(boolean) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Should a refresh be executed before this get operation causing the operation to return the latest value.
- setRefresh(boolean) - Method in class org.elasticsearch.action.get.MultiGetRequestBuilder
-
Should a refresh be executed before this get operation causing the operation to return the latest value.
- setRefresh(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Call refresh on the indexes we've written to after the request ends?
- setRefreshPolicy(String) - Method in interface org.elasticsearch.action.support.WriteRequest
-
Parse the refresh policy from a string, only modifying it if the string is non null.
- setRefreshPolicy(String) - Method in interface org.elasticsearch.action.support.WriteRequestBuilder
-
Parse the refresh policy from a string, only modifying it if the string is non null.
- setRefreshPolicy(WriteRequest.RefreshPolicy) - Method in class org.elasticsearch.action.bulk.BulkRequest
- setRefreshPolicy(WriteRequest.RefreshPolicy) - Method in class org.elasticsearch.action.support.replication.ReplicatedWriteRequest
- setRefreshPolicy(WriteRequest.RefreshPolicy) - Method in interface org.elasticsearch.action.support.WriteRequest
-
Should this request trigger a refresh (WriteRequest.RefreshPolicy.IMMEDIATE), wait for a refresh ( WriteRequest.RefreshPolicy.WAIT_UNTIL), or proceed ignore refreshes entirely (WriteRequest.RefreshPolicy.NONE, the default).
- setRefreshPolicy(WriteRequest.RefreshPolicy) - Method in interface org.elasticsearch.action.support.WriteRequestBuilder
-
Should this request trigger a refresh (WriteRequest.RefreshPolicy.IMMEDIATE), wait for a refresh ( WriteRequest.RefreshPolicy.WAIT_UNTIL), or proceed ignore refreshes entirely (WriteRequest.RefreshPolicy.NONE, the default).
- setRefreshPolicy(WriteRequest.RefreshPolicy) - Method in class org.elasticsearch.action.update.UpdateRequest
- setRegex(BytesRef) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setRemoteInfo(RemoteInfo) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the
RemoteInfo
if the source indices are in a remote cluster. - setRemoteInfo(RemoteInfo) - Method in class org.elasticsearch.index.reindex.ReindexRequestBuilder
-
Setup reindexing from a remote cluster.
- setRemoteTranslogStage() - Method in class org.elasticsearch.indices.recovery.RecoveryState
- setRenamePattern(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets rename pattern that should be applied to restored indices.
- setRenameReplacement(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets rename replacement
- setRepositories(String...) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequestBuilder
-
Sets list of repositories to get
- setRepositories(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Sets the repository names
- setRepository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets the repository name
- setRepository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequestBuilder
-
Sets the repository name
- setRepository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Sets the repository name
- setRepository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets repository name
- setRepository(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
-
Sets the repository name
- setRequest(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- setRequest(PersistentTaskParams) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.RequestBuilder
- setRequestCache(boolean) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequestBuilder
- setRequestCache(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setRequestCache(Boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets if this request should use the request cache or not, assuming that it can (for example, if "now" is used, it will never be cached).
- setRequestsPerSecond(float) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Set the throttle for this request in sub-requests per second.
- setRequestsPerSecond(float) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Set the throttle for this request in sub-requests per second.
- setRequestsPerSecond(Float) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setRequireAlias(boolean) - Method in class org.elasticsearch.action.index.IndexRequest
- setRequireAlias(boolean) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the require_alias flag
- setRequireAlias(boolean) - Method in class org.elasticsearch.action.update.UpdateRequest
- setRequireAlias(boolean) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Sets the require_alias request flag on the destination index
- setRequiredPipeline(String) - Method in class org.elasticsearch.index.IndexSettings
- setRequiredSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- setRerouteService(RerouteService) - Method in class org.elasticsearch.cluster.service.ClusterService
- setRescoredDocs(Set<Integer>) - Method in class org.elasticsearch.search.rescore.RescoreContext
- setRescoreDocIds(RescoreDocIds) - Method in class org.elasticsearch.search.internal.LegacyReaderContext
- setRescoreDocIds(RescoreDocIds) - Method in class org.elasticsearch.search.internal.ReaderContext
- setRescoreDocIds(RescoreDocIds) - Method in class org.elasticsearch.search.SearchPhaseResult
- setRescoreQueryWeight(float) - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- setRescoreQueryWeight(float) - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Sets the original query weight for rescoring.
- setRescorer(RescorerBuilder<?>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Clears all rescorers on the builder and sets the first one.
- setRescorer(RescorerBuilder<?>, int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Clears all rescorers on the builder and sets the first one.
- setResizeType(ResizeType) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
The type of the resize operation
- setResizeType(ResizeType) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
- setResources(String, String...) - Method in exception org.elasticsearch.ElasticsearchException
- setResponse(byte) - Static method in class org.elasticsearch.transport.TransportStatus
- setRestoreGlobalState(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
If set to true the restore procedure will restore global cluster state.
- setResult(DocWriteResponse.Result) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setResyncedOperations(int) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
- setRetentionAgeInMillis(long) - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
- setRetentionSizeInBytes(long) - Method in class org.elasticsearch.index.translog.TranslogDeletionPolicy
- setRetries(Tuple<Long, Long>) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setRetryBackoffInitialTime(TimeValue) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Set the initial delay after a rejection before retrying request.
- setRetryBackoffInitialTime(TimeValue) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Initial delay after a rejection before retrying a bulk request.
- setRetryDelayNetwork(TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setRetryDelayStateSync(TimeValue) - Method in class org.elasticsearch.indices.recovery.RecoverySettings
- setRetryFailed(boolean) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
-
Sets the retry failed flag (defaults to
false
). - setRetryFailed(boolean) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequestBuilder
-
Sets the retry failed flag (defaults to
false
). - setRetryOnConflict(int) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the number of retries of a version conflict occurs because the document was updated between getting it and updating it.
- setRewrite(boolean) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
-
Indicates whether the query should be rewritten into primitive queries
- setRewriteMethod(MultiTermQuery, MultiTermQuery.RewriteMethod) - Static method in class org.elasticsearch.index.query.support.QueryParsers
- setRolloverTarget(String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Sets the rollover target to rollover to another index
- setRolloverTarget(String) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- setRootId(Uid) - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- setRootLookup(SourceLookup) - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- setRouting(String) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequestBuilder
-
A comma separated list of routing values to control the shards the search will be executed on.
- setRouting(String) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
Controls the shard routing of the delete request.
- setRouting(String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Sets the routing for sharding.
- setRouting(String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Controls the shard routing of the request.
- setRouting(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Controls the shard routing of the request.
- setRouting(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
A comma separated list of routing values to control the shards the search will be executed on.
- setRouting(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the routing.
- setRouting(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Controls the shard routing of the request.
- setRouting(String) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Set routing limiting the process to the shards that match that routing value
- setRouting(String) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- setRouting(String) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
-
Set routing limiting the process to the shards that match that routing value
- setRouting(String...) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequestBuilder
-
The routing values to control the shards that the search will be executed on.
- setRouting(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The routing values to control the shards that the search will be executed on.
- setRoutingNumShards(int) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
-
Sets the number of shards that should be used for routing.
- setRoutingTable(boolean) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Should the cluster state result include the
RoutingTable
. - setRuntime(Map<String, RuntimeField>) - Method in class org.elasticsearch.index.mapper.RootObjectMapper.Builder
- setRuntimeFields(Map<String, Object>) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequestBuilder
- setRuntimeMappings(Map<String, Object>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Set runtime mappings to create runtime fields that exist only as part of this particular search.
- Sets - Class in org.elasticsearch.common.util.set
- setScore(float) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- setScoreMode(String) - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- setScoreMode(QueryRescoreMode) - Method in class org.elasticsearch.search.rescore.QueryRescorer.QueryRescoreContext
- setScoreMode(QueryRescoreMode) - Method in class org.elasticsearch.search.rescore.QueryRescorerBuilder
-
Sets the original query score mode.
- setScorer(Scorable) - Method in class org.elasticsearch.action.search.MaxScoreCollector
- setScorer(Scorable) - Method in class org.elasticsearch.common.lucene.MinimumScoreCollector
- setScorer(Scorable) - Method in interface org.elasticsearch.common.lucene.ScorerAware
- setScorer(Scorable) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.BytesRefFieldComparatorSource
- setScorer(Scorable) - Method in class org.elasticsearch.index.fielddata.fieldcomparator.DoubleValuesComparatorSource
- setScorer(Scorable) - Method in class org.elasticsearch.script.StringSortScript
- setScorer(Scorable) - Method in class org.elasticsearch.script.AggregationScript
- setScorer(Scorable) - Method in class org.elasticsearch.script.ScoreScript
- setScorer(Scorable) - Method in class org.elasticsearch.script.ScriptedMetricAggContexts.MapScript
- setScorer(Scorable) - Method in class org.elasticsearch.search.aggregations.LeafBucketCollector
- setScorer(Scorable) - Method in class org.elasticsearch.search.aggregations.LeafBucketCollectorBase
- setScorer(Scorable) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptBytesValues
- setScorer(Scorable) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptDoubleValues
- setScorer(Scorable) - Method in class org.elasticsearch.search.aggregations.support.values.ScriptLongValues
- setScorer(Scorable) - Method in class org.elasticsearch.search.profile.aggregation.ProfilingLeafBucketCollector
- setScorer(Scorable) - Method in class org.elasticsearch.search.sort.BucketedSort.ForDoubles.Leaf
- setScorer(Scorable) - Method in class org.elasticsearch.search.sort.BucketedSort.ForLongs.Leaf
- setScript(Script) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
The script to execute.
- setScript(Script) - Method in class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
-
Script to modify the documents before they are processed.
- setScript(Script) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- setScriptedUpsert(boolean) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets whether the script should be run in the case of an insert
- setScriptFields(Set<SearchSourceBuilder.ScriptField>) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setScroll(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
If set, will enable scrolling of the search request for the specified timeout.
- setScroll(String) - Method in class org.elasticsearch.action.search.SearchScrollRequestBuilder
-
If set, will enable scrolling of the search request for the specified timeout.
- setScroll(String) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource
-
Set the id of the last scroll.
- setScroll(TimeValue) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
If set, will enable scrolling of the search request for the specified timeout.
- setScroll(TimeValue) - Method in class org.elasticsearch.action.search.SearchScrollRequestBuilder
-
If set, will enable scrolling of the search request for the specified timeout.
- setScroll(TimeValue) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Set scroll timeout for
SearchRequest
- setScroll(Scroll) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
If set, will enable scrolling of the search request.
- setScroll(Scroll) - Method in class org.elasticsearch.action.search.SearchScrollRequestBuilder
-
If set, will enable scrolling of the search request.
- setScrollId(String) - Method in class org.elasticsearch.action.search.SearchScrollRequestBuilder
-
The scroll id to use to continue scrolling.
- setScrollIds(List<String>) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- setScrollIds(List<String>) - Method in class org.elasticsearch.action.search.ClearScrollRequestBuilder
- setSearch(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setSearchRetries(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setSearchShardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- setSearchShardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- setSearchShardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
- setSearchShardTarget(SearchShardTarget) - Method in class org.elasticsearch.search.SearchPhaseResult
- setSearchType(String) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The a string representation search type to execute, defaults to
SearchType.DEFAULT
. - setSearchType(SearchType) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The search type to execute, defaults to
SearchType.DEFAULT
. - setSecureSettings(SecureSettings) - Method in class org.elasticsearch.common.settings.Settings.Builder
- setSecureStorePassword(SecureString) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequest
- setSecureStorePassword(SecureString) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequestBuilder
- setSegmentAndDocument(LeafReaderContext, int) - Method in class org.elasticsearch.search.lookup.SourceLookup
- setSegments(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setSelectedFields(String...) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to return only term vectors for special selected fields.
- setSeqNo(long) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setSeqNo(long) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- setSeqNo(long) - Method in class org.elasticsearch.search.SearchHit
- setSeqNoAndPrimaryTerm(boolean) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setSerializer(FieldMapper.Serializer<T>, Function<T, String>) - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Configure a custom serializer for this parameter
- setSerializerCheck(FieldMapper.SerializerCheck<T>) - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Configure a custom serialization check for this parameter
- setSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository settings in Json or Yaml format
- setSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets repository-specific snapshot settings in YAML or JSON format
- setSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
The settings to create the index with (either json or yaml format)
- setSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Sets the settings to be updated (either json or yaml format)
- setSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The settings to crete the index template with (either json or yaml format)
- setSettings(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
The settings to create the index with (either json/yaml/properties format)
- setSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository settings
- setSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets repository-specific snapshot settings.
- setSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Sets the settings to be updated
- setSettings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The settings to crete the index template with (either json or yaml format)
- setSettings(TermVectorsRequest.FilterSettings) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- setSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository settings
- setSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets repository-specific snapshot settings.
- setSettings(Settings) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
The settings to create the index with.
- setSettings(Settings) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Sets the settings to be updated
- setSettings(Settings) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
- setSettings(Settings) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The settings to created the index template with.
- setSettings(Settings) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository settings
- setSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets repository-specific snapshot settings.
- setSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
The settings to create the index with.
- setSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
-
Sets the settings to be updated
- setSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The settings to created the index template with.
- setSettings(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Allows to set the settings using a json builder.
- setShard(int) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
The shard number to use when finding the shard to explain
- setShard(int) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- setShard(Integer) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Sets the shard id of the shard to explain.
- setShard(ShardId) - Method in exception org.elasticsearch.ElasticsearchException
- setShardId(ShardId) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setShardIndex(int) - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- setShardIndex(int) - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- setShardIndex(int) - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
- setShardIndex(int) - Method in class org.elasticsearch.search.SearchPhaseResult
- setShardIndex(int) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- setShardIndex(int) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- setShardInfo(ReplicationResponse.ShardInfo) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setShardInfo(ReplicationResponse.ShardInfo) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.PrimaryResult
- setShardInfo(ReplicationResponse.ShardInfo) - Method in class org.elasticsearch.action.support.replication.ReplicationResponse
- setShardInfo(ReplicationResponse.ShardInfo) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.PrimaryResult
- setShardMinDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- setShardSearchRequest(ShardSearchRequest) - Method in class org.elasticsearch.search.SearchPhaseResult
- setShardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- setShardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- setShardSize(int) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setShardStatuses(String...) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoreRequestBuilder
-
Set statuses to filter shards to get stores info on.
- setShift(int) - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- setShouldStoreResult(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Should this task store its result after it has finished?
- setShouldStoreResult(boolean) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Should this task store its result after it has finished?
- setSimilarity(Similarity) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setSimilarity(TFIDFSimilarity) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
- setSize(int) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
- setSize(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The number of search hits to return.
- setSize(int) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setSize(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Deprecated.please use setMaxDocs(int) instead.
- setSize(int) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setSkippedOperations(int) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
- setSkipTerms(Set<Term>) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Sets a list of terms to never select from
- setSliceId(Integer) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setSlices(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
The number of slices this task should be divided into.
- setSlices(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
The number of slices this task should be divided into.
- setSliceStatuses(List<BulkByScrollTask.StatusOrException>) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setSlop(int) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
-
Sets the phrase slop for this query.
- setSlowLogThreshold(TimeValue) - Method in class org.elasticsearch.transport.TcpTransport
- setSlowLogThreshold(TimeValue) - Method in interface org.elasticsearch.transport.Transport
- setSlowPathLoggingThreshold(TimeValue) - Method in class org.elasticsearch.monitor.fs.FsHealthService
- setSnapshot(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Sets the snapshot name
- setSnapshot(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
Sets snapshot name
- setSnapshots(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequestBuilder
-
Sets the snapshot name
- setSnapshots(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Sets list of snapshots to return
- setSnapshots(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
-
Sets list of snapshots to return
- setSort(GetSnapshotsRequest.SortBy) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
- setSort(SortBy) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- setSortOrder(HotThreads.SortOrder) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
- setSorts(List<SortBuilder<?>>) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setSortValues(Object[]) - Method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- setSource(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the document to index in bytes form (assumed to be safe to be used from different threads).
- setSource(byte[], XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(byte[], XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(byte[], XContentType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the document to index in bytes form.
- setSource(Object...) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- setSource(Object...) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Constructs a simple document with a field name and value pairs.
- setSource(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
The mapping source definition.
- setSource(String, XContentType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the document source to index.
- setSource(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
The mapping source definition.
- setSource(Map<String, ?>) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Index the Map as a JSON.
- setSource(Map<String, ?>, XContentType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Index the Map as the provided content type.
- setSource(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(Map<String, Object>) - Method in class org.elasticsearch.search.lookup.SourceLookup
- setSource(BytesReference) - Method in class org.elasticsearch.search.lookup.SourceLookup
- setSource(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(BytesReference, XContentType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the source.
- setSource(BytesReference, XContentType) - Method in class org.elasticsearch.index.mapper.ParsedDocument
- setSource(BytesReference, XContentType) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.BasicHit
- setSource(SearchSourceBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Sets the source of the request as a SearchSourceBuilder.
- setSource(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the settings and mappings as a single source.
- setSource(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
The mapping source definition.
- setSource(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
The template source definition.
- setSource(XContentBuilder) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the content source to index.
- setSource(XContentType, Object...) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Constructs a simple document with a field name and value pairs.
- setSourceBatchSize(int) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Sets the scroll size for setting how many documents are to be processed in one batch during reindex
- setSourceContentType(XContentType) - Method in class org.elasticsearch.search.lookup.SourceLookup
- setSourceDocTypes(String...) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the document types which need to be copied from the source indices
- setSourceIndex(String) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- setSourceIndex(String) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
- setSourceIndices(String...) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the indices which will act as the source for the ReindexRequest
- setSourceLookup(SourceLookup) - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- setSourceQuery(QueryBuilder) - Method in class org.elasticsearch.index.reindex.ReindexRequest
-
Set the query for selecting documents from the source indices
- setStage(RecoveryState.Stage) - Method in class org.elasticsearch.indices.recovery.RecoveryState
- setStartedAtMillis(long) - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Builder
- setState(PersistentTaskState) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- setState(PersistentTaskState) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.RequestBuilder
- setStats(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The stats groups this request will be aggregated under.
- setStats(List<String>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
The stats groups this request will be aggregated under.
- setStatus(ClusterHealthStatus) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
-
Allows to explicitly override the derived cluster health status.
- setStopWords(Set<?>) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setStopWords(Set<?>) - Method in class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Set the set of stopwords.
- setStore(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setStoredFieldNames(List<String>) - Method in class org.elasticsearch.index.query.InnerHitBuilder
-
Sets the stored fields to load and return.
- setStoredFields(String...) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Explicitly specify the stored fields that will be returned for the explained document.
- setStoredFields(String...) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Explicitly specify the fields that will be returned.
- setTargetIndex(CreateIndexRequest) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- setTargetIndex(CreateIndexRequest) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
- setTargetNodeName(String) - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Builder
- setTask(SearchShardTask) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- setTask(SearchShardTask) - Method in class org.elasticsearch.search.internal.SearchContext
- setTaskCancellationService(TaskCancellationService) - Method in class org.elasticsearch.tasks.TaskManager
- setTaskId(String) - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- setTaskId(String) - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.RequestBuilder
- setTaskId(String) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- setTaskId(String) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.RequestBuilder
- setTaskId(String) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- setTaskId(String) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.RequestBuilder
- setTaskId(TaskId) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
-
Set the TaskId to look up.
- setTaskId(TaskId) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequestBuilder
-
Set the TaskId to look up.
- setTaskId(TaskId) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- setTaskId(TaskId) - Method in class org.elasticsearch.action.support.tasks.TasksRequestBuilder
-
Set the task to lookup.
- setTaskName(String) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- setTaskResultsService(TaskResultsService) - Method in class org.elasticsearch.tasks.TaskManager
- setTerminateAfter(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
An optional document count, upon collecting which the search query will early terminate
- setTermStatistics(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets whether to return the term statistics for each term in the shard or skip.
- setTermVectorParams(String, FieldType) - Static method in class org.elasticsearch.index.mapper.TextParams
- setTermVectorsField(BytesStreamOutput) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setText(String) - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- setText(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Sets texts to analyze
- setText(CharacterIterator) - Method in class org.apache.lucene.search.uhighlight.BoundedBreakIteratorScanner
- setText(BytesRef) - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- setThreadContext(ThreadContext) - Static method in class org.elasticsearch.common.logging.HeaderWarning
-
Set the
ThreadContext
used to add warning headers to network responses. - setThreadPools(ExecutorNames) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setThreads(int) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
- setThrottled(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setThrottledUntil(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setTieBreaker(float) - Method in class org.elasticsearch.index.search.MultiMatchQueryParser
- setTimedOut(boolean) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- setTimeout(String) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setTimeout(String) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
A timeout to wait if the index operation can't be performed immediately.
- setTimeout(String) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequestBuilder
-
Timeout to wait for the operation to be acknowledged by current cluster nodes.
- setTimeout(String) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequestBuilder
- setTimeout(String) - Method in class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
-
A timeout to wait if the index operation can't be performed immediately.
- setTimeout(String) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequestBuilder
-
A timeout to wait if the index operation can't be performed immediately.
- setTimeout(String) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- setTimeout(String) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Timeout to wait for the shards on to be available for each bulk request?
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsRequest
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
-
Timeout to wait for any async actions this request must take.
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequestBuilder
-
Timeout to wait for any async actions this request must take.
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
A timeout to wait if the index operation can't be performed immediately.
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
An optional timeout to control how long search is allowed to take.
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequestBuilder
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequestBuilder
-
Sets the maximum wait for acknowledgement from other nodes
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequestBuilder
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
-
A timeout to wait if the index operation can't be performed immediately.
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequestBuilder
-
A timeout to wait if the index operation can't be performed immediately.
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- setTimeout(TimeValue) - Method in class org.elasticsearch.action.support.tasks.TasksRequestBuilder
- setTimeout(TimeValue) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Timeout to wait for the shards on to be available for each bulk request?
- setTimer(T, Timer) - Method in class org.elasticsearch.search.profile.AbstractProfileBreakdown
- setTimeZone(ZoneId) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setTimeZone(ZoneId) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- setting() - Method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
- Setting<T> - Class in org.elasticsearch.common.settings
-
A setting.
- Setting(String, String, Function<String, T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new Setting instance
- Setting(String, String, Function<String, T>, Setting.Validator<T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new
Setting
instance. - Setting(String, Function<Settings, String>, Function<String, T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new Setting instance
- Setting(String, Setting<T>, Function<String, T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new Setting instance
- Setting(String, Setting<T>, Function<String, T>, Setting.Validator<T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new Setting instance
- Setting(Setting.Key, Function<Settings, String>, Function<String, T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new Setting instance
- Setting(Setting.Key, Function<Settings, String>, Function<String, T>, Setting.Validator<T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new
Setting
instance. - Setting(Setting.Key, Setting<T>, Function<String, T>, Setting.Property...) - Constructor for class org.elasticsearch.common.settings.Setting
-
Creates a new Setting instance
- SETTING - Static variable in class org.elasticsearch.cluster.metadata.AutoExpandReplicas
- SETTING_ALLOCATION_MAX_RETRY - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.MaxRetryAllocationDecider
- SETTING_AUTO_EXPAND_REPLICAS - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_BLOCKS_METADATA - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_BLOCKS_READ - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_BLOCKS_WRITE - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_CLUSTER_MAX_SHARDS_PER_NODE - Static variable in class org.elasticsearch.indices.ShardLimitValidator
- SETTING_CLUSTER_MAX_SHARDS_PER_NODE_FROZEN - Static variable in class org.elasticsearch.indices.ShardLimitValidator
- SETTING_CORS_ALLOW_CREDENTIALS - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_CORS_ALLOW_HEADERS - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_CORS_ALLOW_METHODS - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_CORS_ALLOW_ORIGIN - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_CORS_ENABLED - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_CORS_EXPOSE_HEADERS - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_CORS_MAX_AGE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_CREATION_DATE - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_CREATION_DATE_STRING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_DATA_PATH - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_HISTORY_UUID - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_HTTP_BIND_HOST - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_CLIENT_STATS_ENABLED - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_CLIENT_STATS_MAX_CLOSED_CHANNEL_AGE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_CLIENT_STATS_MAX_CLOSED_CHANNEL_COUNT - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_COMPRESSION - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_COMPRESSION_LEVEL - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_CONTENT_TYPE_REQUIRED - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_DETAILED_ERRORS_ENABLED - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_HOST - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_MAX_CHUNK_SIZE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_MAX_CONTENT_LENGTH - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_MAX_HEADER_SIZE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_MAX_INITIAL_LINE_LENGTH - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_MAX_WARNING_HEADER_COUNT - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_MAX_WARNING_HEADER_SIZE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_PORT - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_PUBLISH_HOST - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_PUBLISH_PORT - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_READ_TIMEOUT - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_RESET_COOKIES - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TCP_KEEP_ALIVE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TCP_KEEP_COUNT - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TCP_KEEP_IDLE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TCP_KEEP_INTERVAL - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TCP_NO_DELAY - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TCP_RECEIVE_BUFFER_SIZE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TCP_REUSE_ADDRESS - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TCP_SEND_BUFFER_SIZE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TRACE_LOG_EXCLUDE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_HTTP_TRACE_LOG_INCLUDE - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_IGNORE_DISK_WATERMARKS - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
- SETTING_INDEX_HIDDEN - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_INDEX_PROVIDED_NAME - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
-
The user provided name for an index.
- SETTING_INDEX_UUID - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_INDEX_VERSION_CREATED - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_MAX_TOMBSTONES - Static variable in class org.elasticsearch.cluster.metadata.IndexGraveyard
-
Setting for the maximum tombstones allowed in the cluster state; prevents the cluster state size from exploding too large, but it opens the very unlikely risk that if there are greater than MAX_TOMBSTONES index deletions while a node was offline, when it comes back online, it will have missed index deletions that it may need to process.
- SETTING_NUMBER_OF_REPLICAS - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_NUMBER_OF_SHARDS - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_PIPELINING_MAX_EVENTS - Static variable in class org.elasticsearch.http.HttpTransportSettings
- SETTING_PRIORITY - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_READ_ONLY - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_READ_ONLY_ALLOW_DELETE - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_READ_ONLY_ALLOW_DELETE_SETTING - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- SETTING_READ_ONLY_SETTING - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- SETTING_ROUTING_PARTITION_SIZE - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_TV_HIGHLIGHT_MULTI_VALUE - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.FastVectorHighlighter
- SETTING_VERSION_CREATED - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_VERSION_CREATED_STRING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
- SETTING_VERSION_UPGRADED - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Deprecated.
- SETTING_VERSION_UPGRADED_STRING - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
-
Deprecated.
- SETTING_WAIT_FOR_ACTIVE_SHARDS - Static variable in class org.elasticsearch.cluster.metadata.IndexMetadata
-
The number of active shard copies to check for before proceeding with a write operation.
- Setting.AffixKey - Class in org.elasticsearch.common.settings
-
A key that allows for static pre and suffix.
- Setting.AffixSetting<T> - Class in org.elasticsearch.common.settings
- Setting.AffixSettingDependency - Interface in org.elasticsearch.common.settings
-
Allows an affix setting to declare a dependency on another affix setting.
- Setting.GroupKey - Class in org.elasticsearch.common.settings
- Setting.Key - Interface in org.elasticsearch.common.settings
- Setting.ListKey - Class in org.elasticsearch.common.settings
- Setting.Property - Enum Class in org.elasticsearch.common.settings
- Setting.SettingDependency - Interface in org.elasticsearch.common.settings
-
Allows a setting to declare a dependency on another setting being set.
- Setting.SimpleKey - Class in org.elasticsearch.common.settings
- Setting.Validator<T> - Interface in org.elasticsearch.common.settings
-
Represents a validator for a setting.
- settingName() - Method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
- settings - Variable in class org.elasticsearch.client.support.AbstractClient
- settings - Variable in class org.elasticsearch.http.AbstractHttpServerTransport
- settings - Variable in class org.elasticsearch.script.ScriptService.ContextSettings
- settings - Variable in class org.elasticsearch.transport.RemoteClusterAware
- settings - Variable in class org.elasticsearch.transport.TcpTransport
- settings() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Returns repository settings
- settings() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns repository-specific snapshot settings
- settings() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- settings() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The settings to create the index with.
- settings() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- settings() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
-
Returns the
Settings
to update - settings() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- settings() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- settings() - Method in class org.elasticsearch.bootstrap.BootstrapContext
- settings() - Method in interface org.elasticsearch.client.Client
-
Returns this clients settings
- settings() - Method in class org.elasticsearch.client.support.AbstractClient
- settings() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- settings() - Method in class org.elasticsearch.cluster.metadata.Metadata
-
Returns the merged transient and persistent settings.
- settings() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
-
Returns repository settings
- settings() - Method in class org.elasticsearch.cluster.metadata.Template
- settings() - Method in interface org.elasticsearch.common.settings.Setting.Validator
-
The settings on which the validity of this setting depends.
- settings() - Method in class org.elasticsearch.env.Environment
-
The settings used to build this environment.
- settings() - Method in class org.elasticsearch.node.Node
-
The settings that are used by this node.
- settings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Sets the repository settings.
- settings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets repository-specific snapshot settings in JSON or YAML format
- settings(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The settings to create the index with (either json or yaml format)
- settings(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Sets the settings to be updated (either json or yaml format)
- settings(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The settings to create the index template with (either json/yaml format).
- settings(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The settings to create the index with (either json/yaml/properties format)
- settings(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Sets the settings to be updated (either json or yaml format)
- settings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Sets the repository settings.
- settings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets repository-specific snapshot settings.
- settings(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The settings to create the index template with (either json or yaml format).
- settings(Settings) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Sets the repository settings
- settings(Settings) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets repository-specific snapshot settings.
- settings(Settings) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- settings(Settings) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The settings to create the index with.
- settings(Settings) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
- settings(Settings) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
-
Sets the
Settings
to update - settings(Settings) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Sets the settings to be updated
- settings(Settings) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The settings to create the index template with.
- settings(Settings) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- settings(Settings) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- settings(Settings) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutRequest
- settings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Sets the repository settings
- settings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets repository-specific snapshot settings.
- settings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
The settings to create the index with.
- settings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Sets the settings to be updated
- settings(Settings.Builder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The settings to create the index template with.
- settings(Settings.Builder) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- settings(Settings.Builder) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- settings(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Allows to set the settings using a json builder.
- Settings - Class in org.elasticsearch.common.settings
-
An immutable settings implementation.
- Settings() - Constructor for class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
-
Generates default
SimpleQueryStringQueryParser.Settings
object (uses ROOT locale, does lowercase terms, no lenient parsing, no wildcard analysis). - Settings(SimpleQueryStringQueryParser.Settings) - Constructor for class org.elasticsearch.index.search.SimpleQueryStringQueryParser.Settings
- SETTINGS - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
- SETTINGS - Enum constant in enum class org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
- SETTINGS - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- SETTINGS - Static variable in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- SETTINGS - Static variable in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
- SETTINGS_FILTER_PARAM - Static variable in class org.elasticsearch.common.settings.SettingsFilter
-
Can be used to specify settings filter that will be used to filter out matching settings in toXContent method
- Settings.Builder - Class in org.elasticsearch.common.settings
-
A builder allowing to put different settings and then
Settings.Builder.build()
an immutable settings implementation. - SettingsBasedSeedHostsProvider - Class in org.elasticsearch.discovery
-
An implementation of
SeedHostsProvider
that reads hosts/ports from the "discovery.seed_hosts" node setting. - SettingsBasedSeedHostsProvider(Settings, TransportService) - Constructor for class org.elasticsearch.discovery.SettingsBasedSeedHostsProvider
- SettingsException - Exception in org.elasticsearch.common.settings
-
A generic failure to handle settings.
- SettingsException(String) - Constructor for exception org.elasticsearch.common.settings.SettingsException
- SettingsException(String, Object...) - Constructor for exception org.elasticsearch.common.settings.SettingsException
- SettingsException(String, Throwable) - Constructor for exception org.elasticsearch.common.settings.SettingsException
- SettingsException(StreamInput) - Constructor for exception org.elasticsearch.common.settings.SettingsException
- SettingsFilter - Class in org.elasticsearch.common.settings
-
A class that allows to filter settings objects by simple regular expression patterns or full settings keys.
- SettingsFilter(Collection<String>) - Constructor for class org.elasticsearch.common.settings.SettingsFilter
- settingsKey(String, String) - Static method in class org.elasticsearch.threadpool.ExecutorBuilder
- SettingsModule - Class in org.elasticsearch.common.settings
-
A module that binds the provided settings to the
Settings
interface. - SettingsModule(Settings, List<Setting<?>>, List<String>, Set<SettingUpgrader<?>>) - Constructor for class org.elasticsearch.common.settings.SettingsModule
- SettingsModule(Settings, Setting<?>...) - Constructor for class org.elasticsearch.common.settings.SettingsModule
- settingsVersion() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- settingsVersion(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- SettingUpgrader<T> - Interface in org.elasticsearch.common.settings
-
Represents the logic to upgrade a setting.
- setTokenFilters(List<NameOrDefinition>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- setTokenizer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Instead of setting the analyzer, sets the tokenizer as name that will be used as part of a custom analyzer.
- setTokenizer(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeRequestBuilder
-
Instead of setting the analyzer, sets the tokenizer using custom settings that will be used as part of a custom analyzer.
- setTookInMillis(long) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- setTotal(long) - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- setTotal(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setTotalOperations(int) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask
- setTrackedNodes(Iterable<DiscoveryNode>) - Method in class org.elasticsearch.cluster.coordination.LagDetector
- setTrackScores(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Applies when sorting, and controls if scores will be tracked as well.
- setTrackScores(boolean) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setTrackTotalHits(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Indicates if the total hit count for the query should be tracked.
- setTrackTotalHitsUpTo(int) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Indicates the total hit count that should be tracked accurately or null if the value is unset.
- setTragicException(Exception) - Method in class org.elasticsearch.index.translog.TragicExceptionHolder
-
Sets the tragic exception or if the tragic exception is already set adds passed exception as suppressed exception
- setTransientSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the source containing the transient settings to be updated.
- setTransientSettings(Map<String, ?>) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the transient settings to be updated.
- setTransientSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the transient settings to be updated.
- setTransientSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequestBuilder
-
Sets the transient settings to be updated.
- setTranslog(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setTranslogSyncInterval(TimeValue) - Method in class org.elasticsearch.index.IndexSettings
- setTranspositions(boolean) - Method in class org.elasticsearch.index.search.MatchQueryParser
- setTranspositions(boolean) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Sets if transpositions (swapping one character for another) counts as one character change or two.
- setTriangleValue(int, int, boolean, int, int, boolean, int, int, boolean) - Method in class org.apache.lucene.document.XLatLonShape.Triangle
-
sets the vertices of the triangle as integer encoded values
- setType(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets the repository type
- setType(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder
-
The type of the mappings.
- setType(String) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
Sets the type of the document to delete.
- setType(String) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setType(String) - Method in class org.elasticsearch.action.explain.ExplainRequestBuilder
-
Sets the type to get a score explanation for.
- setType(String) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Sets the type of the document to fetch.
- setType(String) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the type to index the document to.
- setType(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Sets the type of the document.
- setType(String) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the type of the indexed document.
- setType(String) - Method in class org.elasticsearch.common.logging.ESJsonLayout.Builder
- setType(SingleNodeShutdownMetadata.Type) - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Builder
- setType(MultiMatchQueryBuilder.Type) - Method in class org.elasticsearch.index.search.QueryStringQueryParser
- setType(SystemIndexDescriptor.Type) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setType(HotThreads.ReportType) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder
- setTypes(String...) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequestBuilder
-
Deprecated.
- setTypes(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequestBuilder
- setTypes(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
-
Document types to return stats for.
- setTypes(String...) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
-
The types of documents the query will run against.
- setTypes(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Deprecated.Types are going away, prefer filtering on a field.
- setTypes(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequestBuilder
- setTypes(String...) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- setUnicodeAware(boolean) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions.Builder
-
Set to true if all measurements (like edit distance, transpositions and lengths) are in unicode code points (actual letters) instead of bytes.
- setUnlikeFields(Fields...) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setUnlikeText(String[]) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- setUpdated(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setupFieldType(MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Builder
- setUpgradeInProgress(boolean, boolean) - Method in class org.elasticsearch.index.shard.ElasticsearchMergePolicy
-
When
upgrade
is true, running a force merge will upgrade any segments written with older versions. - setUpgradeOnlyAncientSegments(boolean) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequestBuilder
-
Should the upgrade only the ancient (older major version of Lucene) segments?
- setupHunspellDictionaries(List<AnalysisPlugin>) - Method in class org.elasticsearch.indices.analysis.AnalysisModule
- setupInnerHitsContext(SearchExecutionContext, InnerHitsContext.InnerHitSubContext) - Method in class org.elasticsearch.index.query.InnerHitContextBuilder
- setupParser(String, TriFunction<List<TaskInfo>, List<TaskOperationFailure>, List<ElasticsearchException>, T>) - Static method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- setUpsert(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(byte[], XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(Object...) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(String, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(Map<String, Object>, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(IndexRequest) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the index request to be used if the document does not exists.
- setUpsert(XContentBuilder) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUpsert(XContentType, Object...) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the doc source of the update request to be used when the document does not exists.
- setUserMetadata(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
Provide a map of user metadata that should be included in the snapshot metadata.
- setUserValueTypeHint(ValueType) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig.Builder
- setUseXOpaqueId(boolean) - Method in class org.elasticsearch.common.logging.RateLimitingFilter
- setValidationMethod(GeoValidationMethod) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Specify whether or not to ignore validation errors of bounding boxes.
- setValidationMethod(GeoValidationMethod) - Method in class org.elasticsearch.index.query.GeoDistanceQueryBuilder
-
Set validation method for geo coordinates.
- setValidationMethod(GeoValidationMethod) - Method in class org.elasticsearch.index.query.GeoPolygonQueryBuilder
-
Deprecated.Sets the validation method to use for geo coordinates.
- setValue(double) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- setValue(T) - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Sets the current value of the parameter
- setValueAsString(String) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- setVerbose(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequestBuilder
-
Set to
false
to only show the snapshot names and the indices they contain. - setVerbose(boolean) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequestBuilder
- setVerbose(boolean) - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- setVerbose(boolean) - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequestBuilder
-
Enable or disable verbose mode
- setVerify(boolean) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequestBuilder
-
Sets whether or not repository should be verified after creation
- setVersion(boolean) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Should each
SearchHit
be returned with its version. - setVersion(boolean) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- setVersion(long) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
Sets the version, which will cause the delete operation to only be performed if a matching version exists and no changes happened on the doc since then.
- setVersion(long) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Sets the version, which will cause the get operation to only be performed if a matching version exists and no changes happened on the doc since then.
- setVersion(long) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the version, which will cause the index operation to only be performed if a matching version exists and no changes happened on the doc since then.
- setVersion(long) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
- setVersion(long) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the version, which will cause the index operation to only be performed if a matching version exists and no changes happened on the doc since then.
- setVersion(Integer) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequestBuilder
-
Sets the optional version of this template.
- setVersion(Long) - Method in class org.elasticsearch.action.DocWriteResponse.Builder
- setVersion(Version) - Method in class org.elasticsearch.common.io.stream.FilterStreamInput
- setVersion(Version) - Method in class org.elasticsearch.common.io.stream.StreamInput
-
Set the version of the node on the other side of this stream.
- setVersion(Version) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Set the version of the node on the other side of this stream.
- setVersionConflicts(Long) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- setVersionMetaKey(String) - Method in class org.elasticsearch.indices.SystemIndexDescriptor.Builder
- setVersions(Map<String, Tuple<Version, String>>) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequestBuilder
-
Sets the index versions to be updated
- setVersionType(VersionType) - Method in class org.elasticsearch.action.delete.DeleteRequestBuilder
-
Sets the type of versioning to use.
- setVersionType(VersionType) - Method in class org.elasticsearch.action.get.GetRequestBuilder
-
Sets the versioning type.
- setVersionType(VersionType) - Method in class org.elasticsearch.action.index.IndexRequestBuilder
-
Sets the versioning type.
- setVersionType(VersionType) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
- setVersionType(VersionType) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the versioning type.
- setWaitForActiveShards(int) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
A shortcut for
ClusterHealthRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
-
A shortcut for
CloseIndexRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
A shortcut for
CreateIndexRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
-
A shortcut for
OpenIndexRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
A shortcut for
ResizeRequest.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
-
A shortcut for
ResizeRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
A shortcut for
BulkRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
-
A shortcut for
ReplicationRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
A shortcut for
UpdateRequestBuilder.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
A shortcut for
AbstractBulkByScrollRequest.setWaitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
Sets the number of shard copies that must be active before getting the health status.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequestBuilder
-
Sets the number of shard copies that should be active for indices closing to return.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder
-
Sets the number of shard copies that should be active for index creation to return.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequestBuilder
-
Sets the number of shard copies that should be active for indices opening to return.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
-
Sets the wait for active shards configuration for the rolled index that gets created.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
-
Sets the number of shard copies that should be active for creation of the new shrunken index to return.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequestBuilder
-
Sets the number of shard copies that should be active for creation of the new shrunken index to return.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.bulk.BulkRequestBuilder
-
Sets the number of shard copies that must be active before proceeding with the write.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.support.replication.ReplicationRequestBuilder
-
Sets the number of shard copies that must be active before proceeding with the write.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.update.UpdateRequestBuilder
-
Sets the number of shard copies that must be active before proceeding with the write.
- setWaitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Sets the number of shard copies that must be active before proceeding with the write.
- setWaitForCheckpoints(Map<String, long[]>) - Method in class org.elasticsearch.action.search.SearchRequest
- setWaitForCheckpoints(Map<String, long[]>) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Wait for checkpoints configured for a concrete index, will require that the search request only be executed after the checkpoints are available for search due to a refresh.
- setWaitForCheckpointsTimeout(TimeValue) - Method in class org.elasticsearch.action.search.SearchRequest
- setWaitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
-
If
true
, the request blocks until the cancellation of the task and its descendant tasks is completed. - setWaitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
-
Should this request wait for all found tasks to complete?
- setWaitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequestBuilder
-
Should this request wait for all found tasks to complete?
- setWaitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
-
Should this request wait for all found tasks to complete?
- setWaitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequestBuilder
-
Should this request wait for all found tasks to complete?
- setWaitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequestBuilder
-
If set to true the request should wait for the snapshot completion before returning.
- setWaitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequestBuilder
-
If this parameter is set to true the operation will wait for completion of restore process before returning.
- setWaitForEvents(Priority) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setWaitForGreenStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setWaitForMetadataVersion(long) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
Causes the request to wait for the metadata version to advance to at least the given version.
- setWaitForNodes(String) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
Waits for N number of nodes.
- setWaitForNoInitializingShards(boolean) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
Sets whether the request should wait for there to be no initializing shards before retrieving the cluster health status.
- setWaitForNoRelocatingShards(boolean) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
-
Sets whether the request should wait for there to be no relocating shards before retrieving the cluster health status.
- setWaitForRemoval(boolean) - Method in class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsRequest
- setWaitForStatus(ClusterHealthStatus) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setWaitForTimeOut(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder
-
If
ClusterStateRequest.waitForMetadataVersion()
is set then this determines how long to wait - setWaitForYellowStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder
- setWaitIfOngoing(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequestBuilder
- setWarmer(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequestBuilder
- setWeight(float) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Set the weight applied to the function before combining.
- setWindow(int) - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
-
Sets the window size for this aggregation
- setWorker(float, Integer) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Sets this task to be a worker task that performs search requests
- setWorkerCount(int) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Sets this task to be a leader task for
slices
sliced subtasks - setZeroTermsQuery(ZeroTermsQueryOption) - Method in class org.elasticsearch.index.search.MatchQueryParser
- sha1() - Static method in class org.elasticsearch.common.hash.MessageDigests
-
Returns a
MessageDigest
instance for SHA-1 digests; note that the instance returned is thread local and must not be shared amongst threads. - sha256() - Static method in class org.elasticsearch.common.hash.MessageDigests
-
Returns a
MessageDigest
instance for SHA-256 digests; note that the instance returned is thread local and must not be shared amongst threads. - sha512() - Static method in class org.elasticsearch.common.hash.MessageDigests
-
Returns a
MessageDigest
instance for SHA-512 digests; note that the instance returned is thread local and must not be shared amongst threads. - SHALLOW_ADVANCE - Enum constant in enum class org.elasticsearch.search.profile.query.QueryTimingType
- shallowCopy() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Create a shallow copy of this builder with a new slice configuration.
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Create a shallow copy of this builder and replacing
AggregationBuilder.factoriesBuilder
andmetadata
. - shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FilterAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoHashGridAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileGridAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.global.GlobalAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.missing.MissingAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.nested.NestedAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.nested.ReverseNestedAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.DateRangeAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.AvgAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.CardinalityAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.GeoCentroidAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.MaxAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.MedianAbsoluteDeviationAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.MinAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentileRanksAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.ScriptedMetricAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- shallowCopy(AggregatorFactories.Builder, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- shape - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- shape - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- shape() - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- shape(Geometry) - Method in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
-
Sets the shapeBuilder for the query shape.
- SHAPE_FIELD - Static variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- SHAPE_ID_FIELD - Static variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- SHAPE_INDEX_FIELD - Static variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- SHAPE_PATH_FIELD - Static variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- SHAPE_ROUTING_FIELD - Static variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- SHAPE_TYPE_FIELD - Static variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- shapePath - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- ShapeRelation - Enum Class in org.elasticsearch.common.geo
-
Enum representing the relationship between a Query / Filter Shape and indexed Shapes that will be used to determine if a Document should be matched or not
- shapeRouting - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- shard - Variable in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- shard() - Method in exception org.elasticsearch.action.search.ShardSearchFailure
-
The search shard target the failure occurred on.
- shard() - Method in exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
-
Returns the shard instance referenced by this exception
- shard() - Method in exception org.elasticsearch.search.SearchException
- shard(int) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- shard(SearchShardTarget) - Method in class org.elasticsearch.search.SearchHit
- Shard(String[], ShardId, int, AliasFilter, float, ShardSearchContextId, TimeValue, long) - Constructor for class org.elasticsearch.action.search.CanMatchNodeRequest.Shard
- Shard(StreamInput) - Constructor for class org.elasticsearch.action.search.CanMatchNodeRequest.Shard
- SHARD_BALANCE_FACTOR_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- SHARD_COUNT_LIMIT_SETTING - Static variable in class org.elasticsearch.action.search.TransportSearchAction
-
The maximum number of shards for a single search request.
- SHARD_DOC_FIELD_NAME - Static variable in class org.elasticsearch.search.sort.FieldSortBuilder
-
special field name to sort by index order
- SHARD_FAILED_ACTION_NAME - Static variable in class org.elasticsearch.cluster.action.shard.ShardStateAction
- SHARD_FIELD - Static variable in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- SHARD_FIELD - Static variable in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- SHARD_GEN_IN_REPO_DATA_VERSION - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- SHARD_INACTIVE_TIME_SETTING - Static variable in class org.elasticsearch.indices.IndexingMemoryController
-
If we see no indexing operations after this much time for a given shard, we consider that shard inactive (default: 5 minutes).
- SHARD_MEMORY_INTERVAL_TIME_SETTING - Static variable in class org.elasticsearch.indices.IndexingMemoryController
-
How frequently we check indexing memory usage (default: 5 seconds).
- SHARD_MIN_DOC_COUNT_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- SHARD_PARSER - Static variable in class org.elasticsearch.cluster.health.ClusterIndexHealth
- SHARD_SIZE_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- SHARD_SIZE_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- SHARD_STARTED_ACTION_NAME - Static variable in class org.elasticsearch.cluster.action.shard.ShardStateAction
- ShardAllocationDecision - Class in org.elasticsearch.cluster.routing.allocation
-
Represents the decision taken for the allocation of a single shard.
- ShardAllocationDecision(AllocateUnassignedDecision, MoveDecision) - Constructor for class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
- ShardAllocationDecision(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
- shardBitsetFilterCache() - Method in class org.elasticsearch.index.shard.IndexShard
- ShardBitsetFilterCache - Class in org.elasticsearch.index.cache.bitset
- ShardBitsetFilterCache(ShardId, IndexSettings) - Constructor for class org.elasticsearch.index.cache.bitset.ShardBitsetFilterCache
- shardContainer(IndexId, int) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- ShardCoreKeyMap - Class in org.elasticsearch.common.lucene
-
A map between segment core cache keys and the shard that these segments belong to.
- ShardCoreKeyMap() - Constructor for class org.elasticsearch.common.lucene.ShardCoreKeyMap
- shardCountPerPath(Index) - Method in class org.elasticsearch.env.NodeEnvironment
-
Find all the shards for this index, returning a map of the
DataPath
to the number of shards on that path - ShardCountStats - Class in org.elasticsearch.index.shard
- ShardCountStats() - Constructor for class org.elasticsearch.index.shard.ShardCountStats
- ShardCountStats(long) - Constructor for class org.elasticsearch.index.shard.ShardCountStats
- ShardCountStats(StreamInput) - Constructor for class org.elasticsearch.index.shard.ShardCountStats
- ShardDocSortField - Class in org.elasticsearch.search.sort
-
A
SortField
that first compares the shard index and then uses the document number (_doc) to tiebreak if the value is the same. - ShardDocSortField(int, boolean) - Constructor for class org.elasticsearch.search.sort.ShardDocSortField
- shardExecute(Task, Request, ShardId, ActionListener<ShardResponse>) - Method in class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- shardFailed(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.allocation.IndexMetadataUpdater
- shardFailed(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- shardFailed(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- shardFailed(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- shardFailed(ShardRouting, UnassignedInfo) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when a shard is failed or cancelled.
- shardFailed(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.snapshots.RestoreService.RestoreInProgressUpdater
- ShardFailedClusterStateTaskExecutor(AllocationService, RerouteService, Supplier<Priority>, Logger) - Constructor for class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardFailedClusterStateTaskExecutor
- ShardFailure(ShardRouting, String, Exception) - Constructor for class org.elasticsearch.index.shard.IndexShard.ShardFailure
- shardFailures() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- shardFailures() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns shard failures; an empty list will be returned if there were no shard failures, or if
SnapshotInfo.state()
returnsnull
. - ShardFetchRequest - Class in org.elasticsearch.search.fetch
-
Shard level fetch base request.
- ShardFetchRequest(StreamInput) - Constructor for class org.elasticsearch.search.fetch.ShardFetchRequest
- ShardFetchRequest(ShardSearchContextId, IntArrayList, ScoreDoc) - Constructor for class org.elasticsearch.search.fetch.ShardFetchRequest
- ShardFetchSearchRequest - Class in org.elasticsearch.search.fetch
-
Shard level fetch request used with search.
- ShardFetchSearchRequest(OriginalIndices, ShardSearchContextId, ShardSearchRequest, IntArrayList, ScoreDoc, RescoreDocIds, AggregatedDfs) - Constructor for class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- ShardFetchSearchRequest(StreamInput) - Constructor for class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- ShardFieldData - Class in org.elasticsearch.index.fielddata
- ShardFieldData() - Constructor for class org.elasticsearch.index.fielddata.ShardFieldData
- ShardFieldUsageTracker - Class in org.elasticsearch.index.search.stats
-
Records and provides field usage stats
- ShardFieldUsageTracker() - Constructor for class org.elasticsearch.index.search.stats.ShardFieldUsageTracker
- ShardFieldUsageTracker.FieldUsageStatsTrackingSession - Class in org.elasticsearch.index.search.stats
- ShardFlushRequest - Class in org.elasticsearch.action.admin.indices.flush
- ShardFlushRequest(FlushRequest, ShardId) - Constructor for class org.elasticsearch.action.admin.indices.flush.ShardFlushRequest
- ShardFlushRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.flush.ShardFlushRequest
- ShardGeneration - Class in org.elasticsearch.repositories
-
The generation ID of a shard, used to name the shard-level
index-$SHARD_GEN
file that represents aBlobStoreIndexShardSnapshots
instance. - ShardGeneration(long) - Constructor for class org.elasticsearch.repositories.ShardGeneration
-
Construct a specific
ShardGeneration
for a repository using the legacy numeric format. - ShardGeneration(String) - Constructor for class org.elasticsearch.repositories.ShardGeneration
-
Construct a specific
ShardGeneration
. - ShardGeneration(StreamInput) - Constructor for class org.elasticsearch.repositories.ShardGeneration
- shardGenerations() - Method in class org.elasticsearch.repositories.RepositoryData
- ShardGenerations - Class in org.elasticsearch.repositories
-
Represents the current
ShardGeneration
for each shard in a repository. - ShardGenerations.Builder - Class in org.elasticsearch.repositories
- ShardGetService - Class in org.elasticsearch.index.get
- ShardGetService(IndexSettings, IndexShard, MapperService) - Constructor for class org.elasticsearch.index.get.ShardGetService
- shardId - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- shardId - Variable in exception org.elasticsearch.action.ShardOperationFailedException
- shardId - Variable in class org.elasticsearch.action.support.replication.ReplicationRequest
-
Target shard the request should execute on.
- shardId - Variable in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- shardId - Variable in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- shardId - Variable in class org.elasticsearch.gateway.AsyncShardFetch
- shardId - Variable in class org.elasticsearch.index.engine.Engine
- shardId - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
- shardId - Variable in class org.elasticsearch.indices.fielddata.cache.IndicesFieldDataCache.Key
- shardId - Variable in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- shardId() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- shardId() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- shardId() - Method in class org.elasticsearch.action.search.CanMatchNodeRequest.Shard
- shardId() - Method in exception org.elasticsearch.action.ShardOperationFailedException
-
The index the operation failed on.
- shardId() - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- shardId() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- shardId() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- shardId() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
-
Get the shard id
- shardId() - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
-
Get the id of the shard which allocation should be canceled
- shardId() - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- shardId() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns the shards id
- shardId() - Method in class org.elasticsearch.cluster.routing.PlainShardIterator
- shardId() - Method in interface org.elasticsearch.cluster.routing.ShardIterator
-
The shard id this group relates to.
- shardId() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard id.
- shardId() - Method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
-
Returns the shard id this index belongs to.
- shardId() - Method in class org.elasticsearch.common.lucene.index.ElasticsearchLeafReader
-
Returns the shard id this segment belongs to.
- shardId() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
- shardId() - Method in class org.elasticsearch.index.shard.AbstractIndexShardComponent
- shardId() - Method in interface org.elasticsearch.index.shard.IndexShardComponent
- shardId() - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.Shard
-
Returns the shard id of this shard.
- shardId() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- shardId() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.InFlightOpsRequest
- shardId() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.PreShardSyncedFlushRequest
- shardId() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryFilesInfoRequest
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- shardId() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- shardId() - Method in class org.elasticsearch.indices.recovery.ReestablishRecoveryRequest
- shardId() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- shardId() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.Request
- shardId() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
- shardId() - Method in class org.elasticsearch.repositories.RepositoryShardId
- shardId() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- shardId() - Method in class org.elasticsearch.snapshots.InternalSnapshotsInfoService.SnapshotShard
- shardId() - Method in class org.elasticsearch.snapshots.UpdateIndexShardSnapshotStatusRequest
- shardId(String, String) - Method in class org.elasticsearch.cluster.routing.IndexRouting
-
Generate the single shard id that should contain a document with the provided
id
androuting
. - shardId(ClusterState, String, String, String) - Method in class org.elasticsearch.cluster.routing.OperationRouting
- shardId(RepositoryShardId) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- ShardId - Class in org.elasticsearch.index.shard
-
Allows for shard level components to be injected with the shard id.
- ShardId(String, String, int) - Constructor for class org.elasticsearch.index.shard.ShardId
- ShardId(StreamInput) - Constructor for class org.elasticsearch.index.shard.ShardId
- ShardId(Index, int) - Constructor for class org.elasticsearch.index.shard.ShardId
- shardIdentifierFromRouting(ShardRouting) - Static method in class org.elasticsearch.cluster.ClusterInfo
-
Method that incorporates the ShardId for the shard into a string that includes a 'p' or 'r' depending on whether the shard is a primary.
- shardIds() - Method in class org.elasticsearch.index.IndexService
- ShardIndexWarmerService - Class in org.elasticsearch.index.warmer
- ShardIndexWarmerService(ShardId, IndexSettings) - Constructor for class org.elasticsearch.index.warmer.ShardIndexWarmerService
- shardInfo - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- ShardInfo() - Constructor for class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- ShardInfo(int, int, ReplicationResponse.ShardInfo.Failure...) - Constructor for class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- ShardInfo(StreamInput) - Constructor for class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- shardInitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.IndexMetadataUpdater
- shardInitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- shardInitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- shardInitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- shardInitialized(ShardRouting, ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when unassigned shard is initialized.
- shardInitialized(ShardRouting, ShardRouting) - Method in class org.elasticsearch.snapshots.RestoreService.RestoreInProgressUpdater
- ShardIterator - Interface in org.elasticsearch.cluster.routing
-
Allows to iterate over a set of shard instances (routing) within a shard id group.
- shardLimitPerNode - Variable in class org.elasticsearch.indices.ShardLimitValidator
- shardLimitPerNodeFrozen - Variable in class org.elasticsearch.indices.ShardLimitValidator
- ShardLimitValidator - Class in org.elasticsearch.indices
-
This class contains the logic used to check the cluster-wide shard limit before shards are created and ensuring that the limit is updated correctly on setting updates, etc.
- ShardLimitValidator(Settings, ClusterService) - Constructor for class org.elasticsearch.indices.ShardLimitValidator
- shardLock(ShardId, String) - Method in class org.elasticsearch.env.NodeEnvironment
-
Tries to lock the given shards ID.
- shardLock(ShardId, String, long) - Method in class org.elasticsearch.env.NodeEnvironment
-
Tries to lock the given shards ID.
- ShardLock - Class in org.elasticsearch.env
-
A shard lock guarantees exclusive access to a shards data directory.
- ShardLock(ShardId) - Constructor for class org.elasticsearch.env.ShardLock
- ShardLockObtainFailedException - Exception in org.elasticsearch.env
-
Exception used when the in-memory lock for a shard cannot be obtained
- ShardLockObtainFailedException(StreamInput) - Constructor for exception org.elasticsearch.env.ShardLockObtainFailedException
- ShardLockObtainFailedException(ShardId, String) - Constructor for exception org.elasticsearch.env.ShardLockObtainFailedException
- ShardLockObtainFailedException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.env.ShardLockObtainFailedException
- ShardLongFieldRange - Class in org.elasticsearch.index.shard
-
Class representing an (inclusive) range of
long
values in a field in a single shard. - shardMinDocCount() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Returns the minimum document count required per term, per shard
- shardMinDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
-
Set the minimum document count terms should have on the shard in order to appear in the response.
- shardMinDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
-
Set the minimum document count terms should have on the shard in order to appear in the response.
- shardMinDocCount(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Set the minimum document count terms should have on the shard in order to appear in the response.
- ShardNotFoundException - Exception in org.elasticsearch.index.shard
- ShardNotFoundException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.ShardNotFoundException
- ShardNotFoundException(ShardId) - Constructor for exception org.elasticsearch.index.shard.ShardNotFoundException
- ShardNotFoundException(ShardId, String, Object...) - Constructor for exception org.elasticsearch.index.shard.ShardNotFoundException
- ShardNotFoundException(ShardId, String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.shard.ShardNotFoundException
- ShardNotFoundException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.shard.ShardNotFoundException
- ShardNotInPrimaryModeException - Exception in org.elasticsearch.index.shard
- ShardNotInPrimaryModeException(StreamInput) - Constructor for exception org.elasticsearch.index.shard.ShardNotInPrimaryModeException
- ShardNotInPrimaryModeException(ShardId, IndexShardState) - Constructor for exception org.elasticsearch.index.shard.ShardNotInPrimaryModeException
- shardOperation(AnalyzeAction.Request, ShardId) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- shardOperation(ClearIndicesCacheRequest, ShardRouting, Task, ActionListener<TransportBroadcastByNodeAction.EmptyResult>) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
- shardOperation(AnalyzeDiskUsageShardRequest, Task) - Method in class org.elasticsearch.action.admin.indices.diskusage.TransportAnalyzeIndexDiskUsageAction
- shardOperation(ForceMergeRequest, ShardRouting, Task, ActionListener<TransportBroadcastByNodeAction.EmptyResult>) - Method in class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
- shardOperation(GetFieldMappingsIndexRequest, ShardId) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
- shardOperation(RecoveryRequest, ShardRouting, Task, ActionListener<RecoveryState>) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- shardOperation(IndicesSegmentsRequest, ShardRouting, Task, ActionListener<ShardSegments>) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
- shardOperation(FieldUsageStatsRequest, ShardRouting, Task, ActionListener<FieldUsageShardResponse>) - Method in class org.elasticsearch.action.admin.indices.stats.TransportFieldUsageAction
- shardOperation(IndicesStatsRequest, ShardRouting, Task, ActionListener<ShardStats>) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
- shardOperation(UpgradeStatusRequest, ShardRouting, Task, ActionListener<ShardUpgradeStatus>) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
- shardOperation(UpgradeRequest, ShardRouting, Task, ActionListener<ShardUpgradeResult>) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
- shardOperation(ShardValidateQueryRequest, Task) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- shardOperation(ExplainRequest, ShardId) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- shardOperation(GetRequest, ShardId) - Method in class org.elasticsearch.action.get.TransportGetAction
- shardOperation(MultiGetShardRequest, ShardId) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- shardOperation(MultiTermVectorsShardRequest, ShardId) - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- shardOperation(TermVectorsRequest, ShardId) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- shardOperation(UpdateRequest, ActionListener<UpdateResponse>) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- shardOperation(UpdateRequest, ActionListener<UpdateResponse>, int) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- shardOperation(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- shardOperation(Request, ShardRouting, Task, ActionListener<ShardOperationResult>) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Executes the shard-level operation.
- shardOperation(Request, ShardId) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- shardOperation(ShardRequest, Task) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- shardOperation(RetentionLeaseActions.RemoveRequest, ShardId) - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove.TransportAction
- ShardOperationFailedException - Exception in org.elasticsearch.action
-
An exception indicating that a failure occurred performing an operation on the shard.
- ShardOperationFailedException() - Constructor for exception org.elasticsearch.action.ShardOperationFailedException
- ShardOperationFailedException(String, int, String, RestStatus, Throwable) - Constructor for exception org.elasticsearch.action.ShardOperationFailedException
- shardOperationOnPrimary(TransportVerifyShardBeforeCloseAction.ShardRequest, IndexShard, ActionListener<TransportReplicationAction.PrimaryResult<TransportVerifyShardBeforeCloseAction.ShardRequest, ReplicationResponse>>) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- shardOperationOnPrimary(ShardFlushRequest, IndexShard, ActionListener<TransportReplicationAction.PrimaryResult<ShardFlushRequest, ReplicationResponse>>) - Method in class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
- shardOperationOnPrimary(TransportVerifyShardIndexBlockAction.ShardRequest, IndexShard, ActionListener<TransportReplicationAction.PrimaryResult<TransportVerifyShardIndexBlockAction.ShardRequest, ReplicationResponse>>) - Method in class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction
- shardOperationOnPrimary(BasicReplicationRequest, IndexShard, ActionListener<TransportReplicationAction.PrimaryResult<BasicReplicationRequest, ReplicationResponse>>) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
- shardOperationOnPrimary(GlobalCheckpointSyncAction.Request, IndexShard, ActionListener<TransportReplicationAction.PrimaryResult<GlobalCheckpointSyncAction.Request, ReplicationResponse>>) - Method in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- shardOperationOnPrimary(RetentionLeaseBackgroundSyncAction.Request, IndexShard, ActionListener<TransportReplicationAction.PrimaryResult<RetentionLeaseBackgroundSyncAction.Request, ReplicationResponse>>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- shardOperationOnPrimary(Request, IndexShard, ActionListener<TransportReplicationAction.PrimaryResult<ReplicaRequest, Response>>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Primary operation on node with primary copy.
- shardOperationOnPrimary(Request, IndexShard, ActionListener<TransportReplicationAction.PrimaryResult<ReplicaRequest, Response>>) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
-
Called on the primary with a reference to the primary IndexShard to modify.
- shardOperationOnReplica(TransportVerifyShardBeforeCloseAction.ShardRequest, IndexShard, ActionListener<TransportReplicationAction.ReplicaResult>) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- shardOperationOnReplica(ShardFlushRequest, IndexShard, ActionListener<TransportReplicationAction.ReplicaResult>) - Method in class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
- shardOperationOnReplica(TransportVerifyShardIndexBlockAction.ShardRequest, IndexShard, ActionListener<TransportReplicationAction.ReplicaResult>) - Method in class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction
- shardOperationOnReplica(BasicReplicationRequest, IndexShard, ActionListener<TransportReplicationAction.ReplicaResult>) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
- shardOperationOnReplica(GlobalCheckpointSyncAction.Request, IndexShard, ActionListener<TransportReplicationAction.ReplicaResult>) - Method in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- shardOperationOnReplica(RetentionLeaseBackgroundSyncAction.Request, IndexShard, ActionListener<TransportReplicationAction.ReplicaResult>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction
- shardOperationOnReplica(ReplicaRequest, IndexShard, ActionListener<TransportReplicationAction.ReplicaResult>) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
-
Execute the specified replica operation.
- shardOperationOnReplica(ReplicaRequest, IndexShard, ActionListener<TransportReplicationAction.ReplicaResult>) - Method in class org.elasticsearch.action.support.replication.TransportWriteAction
-
Called once per replica with a reference to the replica IndexShard to modify.
- shardPath() - Method in class org.elasticsearch.index.shard.IndexShard
- ShardPath - Class in org.elasticsearch.index.shard
- ShardPath(boolean, Path, Path, ShardId) - Constructor for class org.elasticsearch.index.shard.ShardPath
- shardRandomSeed() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- shardRandomSeed() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Get a deterministic random seed based for this particular shard.
- ShardRecoveryPlan - Class in org.elasticsearch.indices.recovery.plan
- ShardRecoveryPlan(ShardRecoveryPlan.SnapshotFilesToRecover, List<StoreFileMetadata>, List<StoreFileMetadata>, long, int, Store.MetadataSnapshot) - Constructor for class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- ShardRecoveryPlan(ShardRecoveryPlan.SnapshotFilesToRecover, List<StoreFileMetadata>, List<StoreFileMetadata>, long, int, Store.MetadataSnapshot, ShardRecoveryPlan) - Constructor for class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan
- ShardRecoveryPlan.SnapshotFilesToRecover - Class in org.elasticsearch.indices.recovery.plan
- shardRecoveryStates() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
- ShardRequest(ShardId, ClusterBlock, boolean, TaskId) - Constructor for class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction.ShardRequest
- ShardRequest(ShardId, ClusterBlock, TaskId) - Constructor for class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction.ShardRequest
- ShardRequestCache - Class in org.elasticsearch.index.cache.request
-
Tracks the portion of the request cache in use for a particular shard.
- ShardRequestCache() - Constructor for class org.elasticsearch.index.cache.request.ShardRequestCache
- shardRequestIndex() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
-
Returns the shard request ordinal that is used by the main search request to reference this shard.
- shardResponses() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- ShardRestoreStatus(String) - Constructor for class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Constructs a new shard restore status in initializing state on the given node
- ShardRestoreStatus(String, RestoreInProgress.State) - Constructor for class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Constructs a new shard restore status in with specified state on the given node
- ShardRestoreStatus(String, RestoreInProgress.State, String) - Constructor for class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Constructs a new shard restore status in with specified state on the given node with specified failure reason
- shardResult(SearchHits, ProfileResult) - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- ShardResult(int, CloseIndexResponse.ShardResult.Failure[]) - Constructor for class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult
- shardRouting - Variable in class org.elasticsearch.index.shard.IndexShard
- ShardRouting - Class in org.elasticsearch.cluster.routing
-
ShardRouting
immutably encapsulates information about shard indexRoutings like id, state, version, etc. - ShardRouting(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.ShardRouting
- ShardRouting(ShardId, StreamInput) - Constructor for class org.elasticsearch.cluster.routing.ShardRouting
- shardRoutingChanged(IndexShard, ShardRouting, ShardRouting) - Method in interface org.elasticsearch.index.shard.IndexEventListener
-
Called when the shard routing has changed state.
- ShardRoutingState - Enum Class in org.elasticsearch.cluster.routing
-
Represents the current state of a
ShardRouting
as defined by the cluster. - shardRoutingTable(String, int) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
All shards for the provided index and shard id
- shardRoutingTable(IndexRoutingTable, int) - Static method in class org.elasticsearch.cluster.routing.RoutingTable
-
Get's the
IndexShardRoutingTable
for the given shard id from the givenIndexRoutingTable
or throws aShardNotFoundException
if no shard by the given id is found in the IndexRoutingTable. - shardRoutingTable(ShardId) - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
All shards for the provided
ShardId
- shards - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- shards() - Method in class org.elasticsearch.action.search.SearchContextId
- shards() - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
-
Returns list of shards that being restore and their status
- shards() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- shards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns a
List
of shards - shards() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- shards(Predicate<ShardRouting>) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- shards(ClusterState, ClearIndicesCacheRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
-
The refresh request works against *all* shards.
- shards(ClusterState, AnalyzeIndexDiskUsageRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.diskusage.TransportAnalyzeIndexDiskUsageAction
- shards(ClusterState, ForceMergeRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
-
The refresh request works against *all* shards.
- shards(ClusterState, RecoveryRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- shards(ClusterState, IndicesSegmentsRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
-
Segments goes across *all* active shards.
- shards(ClusterState, FieldUsageStatsRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.stats.TransportFieldUsageAction
- shards(ClusterState, IndicesStatsRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
-
Status goes across *all* shards.
- shards(ClusterState, UpgradeStatusRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
-
Getting upgrade stats from *all* active shards.
- shards(ClusterState, UpgradeRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
-
The upgrade request works against *all* shards.
- shards(ClusterState, ValidateQueryRequest, String[]) - Method in class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.explain.TransportExplainAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.get.TransportGetAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.get.TransportShardMultiGetAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
-
Returns the candidate shards to execute the operation on or
null
the execute the operation locally (the node that received the request) - shards(ClusterState, TransportSingleShardAction.InternalRequest) - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove.TransportAction
- shards(ClusterState, UpdateRequest) - Method in class org.elasticsearch.action.update.TransportUpdateAction
- shards(ClusterState, Request) - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
-
Should return an iterator with a single shard!
- shards(ClusterState, Request, String[]) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
-
Determines the shards on which this operation will be executed on.
- shards(ClusterState, Request, String[]) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
-
Determines the shards this operation will be executed on.
- shards(Request, ClusterState) - Method in class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- Shards - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- SHARDS - Enum constant in enum class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest.Level
- SHARDS - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.SortBy
- SHARDS - Enum constant in enum class org.elasticsearch.cluster.routing.Preference
-
Route to specific shards
- SHARDS_ACKNOWLEDGED - Static variable in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- SHARDS_ALLOCATOR_TYPE_SETTING - Static variable in class org.elasticsearch.cluster.ClusterModule
- ShardsAcknowledgedResponse - Class in org.elasticsearch.action.support.master
- ShardsAcknowledgedResponse(boolean, boolean) - Constructor for class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- ShardsAcknowledgedResponse(StreamInput, boolean, boolean) - Constructor for class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- ShardsAllocator - Interface in org.elasticsearch.cluster.routing.allocation.allocator
-
A
ShardsAllocator
is the main entry point for shard allocation on nodes in the cluster. - shardsByRepoShardId() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- ShardSearchContextId - Class in org.elasticsearch.search.internal
- ShardSearchContextId(String, long) - Constructor for class org.elasticsearch.search.internal.ShardSearchContextId
- ShardSearchContextId(String, long, String) - Constructor for class org.elasticsearch.search.internal.ShardSearchContextId
- ShardSearchContextId(StreamInput) - Constructor for class org.elasticsearch.search.internal.ShardSearchContextId
- ShardSearchFailure - Exception in org.elasticsearch.action.search
-
Represents a failure to search on a specific shard.
- ShardSearchFailure(Exception) - Constructor for exception org.elasticsearch.action.search.ShardSearchFailure
- ShardSearchFailure(Exception, SearchShardTarget) - Constructor for exception org.elasticsearch.action.search.ShardSearchFailure
- shardSearchRequest() - Method in class org.elasticsearch.search.query.QuerySearchRequest
- ShardSearchRequest - Class in org.elasticsearch.search.internal
-
Shard level request that represents a search.
- ShardSearchRequest(OriginalIndices, SearchRequest, ShardId, int, int, AliasFilter, float, long, String) - Constructor for class org.elasticsearch.search.internal.ShardSearchRequest
- ShardSearchRequest(OriginalIndices, SearchRequest, ShardId, int, int, AliasFilter, float, long, String, ShardSearchContextId, TimeValue) - Constructor for class org.elasticsearch.search.internal.ShardSearchRequest
- ShardSearchRequest(OriginalIndices, ShardId, int, int, SearchType, SearchSourceBuilder, String[], Boolean, AliasFilter, float, boolean, Scroll, long, String, ShardSearchContextId, TimeValue, long, TimeValue) - Constructor for class org.elasticsearch.search.internal.ShardSearchRequest
- ShardSearchRequest(StreamInput) - Constructor for class org.elasticsearch.search.internal.ShardSearchRequest
- ShardSearchRequest(ShardId, String[], long, AliasFilter) - Constructor for class org.elasticsearch.search.internal.ShardSearchRequest
- ShardSearchRequest(ShardSearchRequest) - Constructor for class org.elasticsearch.search.internal.ShardSearchRequest
- ShardSearchStats - Class in org.elasticsearch.index.search.stats
- ShardSearchStats() - Constructor for class org.elasticsearch.index.search.stats.ShardSearchStats
- ShardSegments - Class in org.elasticsearch.action.admin.indices.segments
- ShardShuffler - Class in org.elasticsearch.cluster.routing
-
A shuffler for shards whose primary goal is to balance load.
- ShardShuffler() - Constructor for class org.elasticsearch.cluster.routing.ShardShuffler
- shardsIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- shardsIt() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
A shard iterator with just this shard in it.
- shardsIt(int) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- ShardsIterator - Interface in org.elasticsearch.cluster.routing
-
Allows to iterate over unrelated shards.
- shardSize - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- shardSize - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregator
- shardSize - Variable in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- shardSize - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- shardSize - Variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- shardSize() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- shardSize() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
-
Get the max num docs to be returned from each shard.
- shardSize() - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
-
Get the max num docs to be returned from each shard.
- shardSize() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Returns the number of term buckets per shard that are currently configured
- shardSize() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the
SuggestionBuilder.shardSize()
parameter - shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.DiversifiedAggregationBuilder
-
Set the max num docs to be returned from each shard.
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregationBuilder
-
Set the max num docs to be returned from each shard.
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
-
Sets the shard_size - indicating the number of term buckets each shard will return to the coordinating node (the node that coordinates the search execution).
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
-
Sets the shard_size - indicating the number of term buckets each shard will return to the coordinating node (the node that coordinates the search execution).
- shardSize(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Sets the shard_size - indicating the number of term buckets each shard will return to the coordinating node (the node that coordinates the search execution).
- shardSize(Integer) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
Sets the maximum number of suggested term to be retrieved from each individual shard.
- SHARDSIZE_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- ShardsLimitAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This
AllocationDecider
limits the number of shards per node on a per index or node-wide basis. - ShardsLimitAllocationDecider(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider
- ShardSnapshot - Class in org.elasticsearch.indices.recovery.plan
- ShardSnapshotInfo - Class in org.elasticsearch.repositories
- ShardSnapshotInfo(StreamInput) - Constructor for class org.elasticsearch.repositories.ShardSnapshotInfo
- ShardSnapshotInfo(IndexId, ShardId, Snapshot, String, String, long) - Constructor for class org.elasticsearch.repositories.ShardSnapshotInfo
- shardSnapshotResult() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- ShardSnapshotResult - Class in org.elasticsearch.repositories
-
The details of a successful shard-level snapshot that are used to build the overall snapshot during finalization.
- ShardSnapshotResult(StreamInput) - Constructor for class org.elasticsearch.repositories.ShardSnapshotResult
- ShardSnapshotResult(ShardGeneration, ByteSizeValue, int) - Constructor for class org.elasticsearch.repositories.ShardSnapshotResult
- ShardSnapshotsService - Class in org.elasticsearch.indices.recovery.plan
- ShardSnapshotsService(Client, RepositoriesService, ThreadPool, ClusterService) - Constructor for class org.elasticsearch.indices.recovery.plan.ShardSnapshotsService
- ShardSnapshotStatus(String, SnapshotsInProgress.ShardState, String, ShardGeneration) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- ShardSnapshotStatus(String, SnapshotsInProgress.ShardState, ShardGeneration) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- ShardSnapshotStatus(String, ShardGeneration) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- shardsRandomIt() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- shardsResponses - Variable in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- shardsResponses() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- shardsStats() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
- ShardsSyncedFlushResult - Class in org.elasticsearch.indices.flush
-
Result for all copies of a shard
- ShardsSyncedFlushResult(StreamInput) - Constructor for class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- ShardsSyncedFlushResult(ShardId, int, String) - Constructor for class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
-
failure constructor
- ShardsSyncedFlushResult(ShardId, String, int, Map<ShardRouting, SyncedFlushService.ShardSyncedFlushResponse>) - Constructor for class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
-
success constructor
- shardStarted(ShardRouting, long, String, ShardLongFieldRange, ActionListener<Void>) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
- shardStarted(ShardRouting, long, String, ShardLongFieldRange, ActionListener<Void>, ClusterState) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
- shardStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.IndexMetadataUpdater
- shardStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- shardStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- shardStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- shardStarted(ShardRouting, ShardRouting) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when an initializing shard is started.
- shardStarted(ShardRouting, ShardRouting) - Method in class org.elasticsearch.snapshots.RestoreService.RestoreInProgressUpdater
- ShardStartedClusterStateTaskExecutor(AllocationService, RerouteService, Supplier<Priority>, Logger) - Constructor for class org.elasticsearch.cluster.action.shard.ShardStateAction.ShardStartedClusterStateTaskExecutor
- shardStateAction - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- ShardStateAction - Class in org.elasticsearch.cluster.action.shard
- ShardStateAction(ClusterService, TransportService, AllocationService, RerouteService, ThreadPool) - Constructor for class org.elasticsearch.cluster.action.shard.ShardStateAction
- ShardStateAction.FailedShardEntry - Class in org.elasticsearch.cluster.action.shard
- ShardStateAction.NoLongerPrimaryShardException - Exception in org.elasticsearch.cluster.action.shard
- ShardStateAction.ShardFailedClusterStateTaskExecutor - Class in org.elasticsearch.cluster.action.shard
- ShardStateAction.ShardStartedClusterStateTaskExecutor - Class in org.elasticsearch.cluster.action.shard
- ShardStateAction.StartedShardEntry - Class in org.elasticsearch.cluster.action.shard
- shardStateIdentifier() - Method in class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
-
Returns an identifier for the shard state that can be used to check whether a shard has changed between snapshots or not.
- ShardStateMetadata - Class in org.elasticsearch.index.shard
- ShardStateMetadata(boolean, String, AllocationId) - Constructor for class org.elasticsearch.index.shard.ShardStateMetadata
- shardStatePathToDataPath(Path) - Static method in class org.elasticsearch.env.NodeEnvironment
-
Returns the
DataPath.path
for this shard. - ShardStats - Class in org.elasticsearch.action.admin.indices.stats
- ShardStats() - Constructor for class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
- ShardStats(ShardRouting, ShardPath, CommonStats, CommitStats, SeqNoStats, RetentionLeaseStats) - Constructor for class org.elasticsearch.action.admin.indices.stats.ShardStats
- ShardStats(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.stats.ShardStats
- shardStatuses() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
Returns the shard criteria to get store information on
- shardStatuses(String...) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
-
Set statuses to filter shards to get stores info on.
- ShardStoreInfo(long) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
- ShardStoreInfo(String, boolean, Exception) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
- ShardStoreInfo(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
- shardStores(IndicesShardStoresRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
The shard stores info of one or more indices.
- shardStores(IndicesShardStoresRequest, ActionListener<IndicesShardStoresResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
The shard stores info of one or more indices.
- shardsWithState(String, ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
Determine the shards of an index with a specific state
- shardsWithState(ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- shardsWithState(ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- shardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNode
-
Determine the shards with a specific state
- ShardSyncedFlushRequest(StreamInput) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- ShardSyncedFlushRequest(ShardId, String, Engine.CommitId) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- ShardSyncedFlushResponse(String) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- ShardSyncedFlushResponse(StreamInput) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- shardTarget() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- shardTarget() - Method in class org.elasticsearch.search.internal.SearchContext
- ShardToolCli - Class in org.elasticsearch.index.shard
-
Class encapsulating and dispatching commands from the
elasticsearch-shard
command line tool - ShardUpgradeRequest - Class in org.elasticsearch.action.admin.indices.upgrade.post
- ShardUpgradeRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.ShardUpgradeRequest
- ShardUpgradeStatus - Class in org.elasticsearch.action.admin.indices.upgrade.get
- ShardUpgradeStatus(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.get.ShardUpgradeStatus
- ShardUtils - Class in org.elasticsearch.index.shard
- ShardValidateQueryRequest - Class in org.elasticsearch.action.admin.indices.validate.query
-
Internal validate request executed directly against a specific index shard.
- ShardValidateQueryRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- ShardValidateQueryRequest(ShardId, AliasFilter, ValidateQueryRequest) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- sharedDataFile() - Method in class org.elasticsearch.env.Environment
-
The shared data location
- sharedDataPath() - Method in class org.elasticsearch.env.NodeEnvironment
-
Returns shared data path for this node environment
- ShingleTokenFilterFactory - Class in org.elasticsearch.index.analysis
- ShingleTokenFilterFactory(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ShingleTokenFilterFactory
- ShingleTokenFilterFactory.Factory - Class in org.elasticsearch.index.analysis
- SHORT - Enum constant in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
- SHORT - Enum constant in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- shortName() - Method in enum class org.elasticsearch.common.Rounding.DateTimeUnit
- shortSummary() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
- shortSummary() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
A short description of the shard.
- shortSummary() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
- shortSummary() - Method in class org.elasticsearch.common.StopWatch
-
Return a short description of the total running time.
- shortToBytes(int) - Static method in class org.elasticsearch.common.Numbers
-
Converts an int to a byte array.
- should() - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Gets the list of clauses that should be matched by the returned documents.
- should(QueryBuilder) - Method in class org.elasticsearch.index.query.BoolQueryBuilder
-
Adds a clause that should be matched by the returned documents.
- shouldAutoCreate(String, ClusterState) - Method in class org.elasticsearch.action.support.AutoCreateIndex
-
Should the index be auto created?
- shouldAutoExpandToNode(IndexMetadata, DiscoveryNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDecider
-
Returns a
Decision
whether shards of the given index should be auto-expanded to this node at this state of theRoutingAllocation
. - shouldAutoExpandToNode(IndexMetadata, DiscoveryNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.AllocationDeciders
- shouldAutoExpandToNode(IndexMetadata, DiscoveryNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.FilterAllocationDecider
- shouldAutoExpandToNode(IndexMetadata, DiscoveryNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.NodeReplacementAllocationDecider
- shouldAutoExpandToNode(IndexMetadata, DiscoveryNode, RoutingAllocation) - Method in class org.elasticsearch.cluster.routing.allocation.decider.NodeShutdownAllocationDecider
-
Prevents indices from being auto-expanded to nodes which are in the process of shutting down, regardless of whether they're shutting down for restart or removal.
- shouldBootstrapNewHistoryUUID() - Method in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- shouldBootstrapNewHistoryUUID() - Method in class org.elasticsearch.cluster.routing.RecoverySource
- shouldCancelChildrenOnCancellation() - Method in class org.elasticsearch.action.search.SearchShardTask
- shouldCancelChildrenOnCancellation() - Method in class org.elasticsearch.tasks.CancellableTask
-
Returns whether this task's children need to be cancelled too.
- shouldCloseConnection(HttpRequest) - Static method in class org.elasticsearch.http.HttpUtils
- shouldDefer(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.DeferableBucketAggregator
-
This method should be overridden by subclasses that want to defer calculation of a child aggregation until a first pass is complete and a set of buckets has been pruned.
- shouldDefer(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregator
- shouldDefer(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator
- shouldDefer(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractRareTermsAggregator
- shouldDefer(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- shouldIgnoreOrRejectNewClusterState(Logger, ClusterState, ClusterState) - Static method in class org.elasticsearch.discovery.zen.ZenDiscovery
-
In the case we follow an elected master the new cluster state needs to have the same elected master and the new cluster state version needs to be equal or higher than our cluster state version.
- shouldIgnoreShardForNode(ShardId, String) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Returns whether the given node id should be ignored from consideration when
AllocationDeciders
is deciding whether to allocate the specified shard id to that node. - shouldMmap() - Method in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- shouldOpenMoreConnections() - Method in class org.elasticsearch.transport.ProxyConnectionStrategy
- shouldOpenMoreConnections() - Method in class org.elasticsearch.transport.RemoteConnectionStrategy
- shouldOpenMoreConnections() - Method in class org.elasticsearch.transport.SniffConnectionStrategy
- shouldPeriodicallyFlush() - Method in class org.elasticsearch.index.engine.Engine
-
Checks if this engine should be flushed periodically.
- shouldPeriodicallyFlush() - Method in class org.elasticsearch.index.engine.InternalEngine
- shouldPeriodicallyFlush() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- shouldRetry(Exception) - Method in class org.elasticsearch.action.support.RetryableAction
- shouldRollGeneration() - Method in class org.elasticsearch.index.translog.Translog
-
Tests whether or not the translog generation should be rolled to a new generation.
- shouldRollTranslogGeneration() - Method in class org.elasticsearch.index.engine.Engine
-
Tests whether or not the translog generation should be rolled to a new generation.
- shouldRollTranslogGeneration() - Method in class org.elasticsearch.index.engine.InternalEngine
- shouldRollTranslogGeneration() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- shouldSerialize(StreamOutput, T) - Static method in interface org.elasticsearch.cluster.ClusterState.FeatureAware
-
Tests whether or not the custom should be serialized.
- shouldTraceAction(String, String[], String[]) - Static method in class org.elasticsearch.transport.TransportService
- shouldUseFilterForMultitermQueries() - Method in class org.elasticsearch.index.analysis.PreConfiguredCharFilter
-
Can this
TokenFilter
be used in multi-term queries? - shouldUseFilterForMultitermQueries() - Method in class org.elasticsearch.index.analysis.PreConfiguredTokenFilter
-
Can this
TokenFilter
be used in multi-term queries? - SHOW_TERM_DOC_COUNT_ERROR - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- showDocCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- showTermDocCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator
- showTermDocCountError - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- showTermDocCountError() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Get whether doc count error will be return for individual terms
- showTermDocCountError(boolean) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Set whether doc count error will be return for individual terms
- SHRINK - Enum constant in enum class org.elasticsearch.action.admin.indices.shrink.ResizeType
- ShrinkAction - Class in org.elasticsearch.action.admin.indices.shrink
- shuffle() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- shuffle(List<?>) - Static method in class org.elasticsearch.common.Randomness
- shuffle(List<ShardRouting>) - Method in class org.elasticsearch.cluster.routing.ShardShuffler
-
Equivalent to calling
shuffle(shards, nextSeed())
. - shuffle(List<ShardRouting>, int) - Method in class org.elasticsearch.cluster.routing.RotationShardShuffler
- shuffle(List<ShardRouting>, int) - Method in class org.elasticsearch.cluster.routing.ShardShuffler
-
Return a shuffled view over the list of shards.
- ShuffleForcedMergePolicy - Class in org.apache.lucene.index
-
A
FilterMergePolicy
that interleaves eldest and newest segments picked byMergePolicy.findForcedMerges(org.apache.lucene.index.SegmentInfos, int, java.util.Map<org.apache.lucene.index.SegmentCommitInfo, java.lang.Boolean>, org.apache.lucene.index.MergePolicy.MergeContext)
andMergePolicy.findForcedDeletesMerges(org.apache.lucene.index.SegmentInfos, org.apache.lucene.index.MergePolicy.MergeContext)
. - ShuffleForcedMergePolicy(MergePolicy) - Constructor for class org.apache.lucene.index.ShuffleForcedMergePolicy
- shutdown() - Method in class org.elasticsearch.threadpool.ThreadPool
- SHUTDOWN - Enum constant in enum class org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices.IndexRemovalReason
-
The index is closed as part of the node shutdown process.
- ShutdownAwarePlugin - Interface in org.elasticsearch.plugins
-
A
ShutdownAwarePlugin
is a plugin that can be made aware of a shutdown. - shutdownNodes(ClusterState) - Static method in class org.elasticsearch.shutdown.PluginShutdownService
-
Return all nodes shutting down from the given cluster state
- shutdownNow() - Method in class org.elasticsearch.threadpool.ThreadPool
- ShutdownPersistentTasksStatus - Class in org.elasticsearch.cluster.metadata
- ShutdownPersistentTasksStatus() - Constructor for class org.elasticsearch.cluster.metadata.ShutdownPersistentTasksStatus
- ShutdownPersistentTasksStatus(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.ShutdownPersistentTasksStatus
- ShutdownPluginsStatus - Class in org.elasticsearch.cluster.metadata
- ShutdownPluginsStatus(boolean) - Constructor for class org.elasticsearch.cluster.metadata.ShutdownPluginsStatus
- ShutdownPluginsStatus(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.ShutdownPluginsStatus
- ShutdownShardMigrationStatus - Class in org.elasticsearch.cluster.metadata
- ShutdownShardMigrationStatus(SingleNodeShutdownMetadata.Status, long) - Constructor for class org.elasticsearch.cluster.metadata.ShutdownShardMigrationStatus
- ShutdownShardMigrationStatus(SingleNodeShutdownMetadata.Status, long, String) - Constructor for class org.elasticsearch.cluster.metadata.ShutdownShardMigrationStatus
- ShutdownShardMigrationStatus(SingleNodeShutdownMetadata.Status, long, String, ShardAllocationDecision) - Constructor for class org.elasticsearch.cluster.metadata.ShutdownShardMigrationStatus
- ShutdownShardMigrationStatus(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.ShutdownShardMigrationStatus
- shutdownTypeNodes(ClusterState, SingleNodeShutdownMetadata.Type...) - Static method in class org.elasticsearch.shutdown.PluginShutdownService
-
Return all nodes shutting down with the given shutdown types from the given cluster state
- SI - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- SiblingPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- SiblingPipelineAggregator(String, String[], Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.pipeline.SiblingPipelineAggregator
- sigma() - Method in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- sigma() - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregationBuilder
-
Get the value of sigma to use when calculating the standard deviation bounds
- sigma(double) - Method in class org.elasticsearch.search.aggregations.metrics.ExtendedStatsAggregationBuilder
- sigma(double) - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregationBuilder
-
Set the value of sigma to use when calculating the standard deviation bounds
- sigmoid(double, double, double) - Static method in class org.elasticsearch.script.ScoreScriptUtils
-
Calculate a sigmoid of
value
with scaling parametersk
anda
- signalShutdown(Collection<String>) - Method in interface org.elasticsearch.plugins.ShutdownAwarePlugin
-
A trigger to notify the plugin that a shutdown for the nodes has been triggered.
- signalShutdown(ClusterState) - Method in class org.elasticsearch.shutdown.PluginShutdownService
-
Signal to plugins the nodes that are currently shutting down
- significanceHeuristic - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- significanceHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- significanceHeuristic() - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- significanceHeuristic(SignificanceHeuristic) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- significanceHeuristic(SignificanceHeuristic) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- SignificanceHeuristic - Class in org.elasticsearch.search.aggregations.bucket.terms.heuristic
-
Heuristic for that
SignificantTerms
uses to pick out significant terms. - SignificanceHeuristic() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.heuristic.SignificanceHeuristic
- SignificanceHeuristicBuilder - Interface in org.elasticsearch.search.aggregations.bucket.terms.heuristic
- SignificanceHeuristicSpec(String, Writeable.Reader<T>, BiFunction<XContentParser, Void, T>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SignificanceHeuristicSpec
- SignificanceHeuristicSpec(ParseField, Writeable.Reader<T>, BiFunction<XContentParser, Void, T>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SignificanceHeuristicSpec
- SignificantLongTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Result of the running the significant terms aggregation on a numeric field.
- SignificantLongTerms(String, int, long, Map<String, Object>, DocValueFormat, long, long, SignificanceHeuristic, List<SignificantLongTerms.Bucket>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms
- SignificantLongTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms
-
Read from a stream.
- SignificantLongTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- significantlySmallerThanSinglePackedOrdinals(int, int, long, float) - Static method in class org.elasticsearch.index.fielddata.ordinals.MultiOrdinals
-
Return true if this impl is going to be smaller than
SinglePackedOrdinals
by at least 20%. - SignificantStringTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Result of the running the significant terms aggregation on a String field.
- SignificantStringTerms(String, int, long, Map<String, Object>, DocValueFormat, long, long, SignificanceHeuristic, List<SignificantStringTerms.Bucket>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms
- SignificantStringTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms
-
Read from a stream.
- SignificantStringTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- significantTerms(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
SignificantTerms
aggregation with the given name. - SignificantTerms - Interface in org.elasticsearch.search.aggregations.bucket.terms
-
An aggregation that collects significant terms in comparison to a background set.
- SignificantTerms.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.terms
- SignificantTermsAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.terms
- SignificantTermsAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- SignificantTermsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
-
Read from a Stream.
- SignificantTermsAggregationBuilder(SignificantTermsAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
- SignificantTermsAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.terms
- SignificantTermsAggregatorFactory.ExecutionMode - Enum Class in org.elasticsearch.search.aggregations.bucket.terms
- SignificantTermsHeuristicScoreScript - Class in org.elasticsearch.script
-
A script used in significant terms heuristic scoring.
- SignificantTermsHeuristicScoreScript() - Constructor for class org.elasticsearch.script.SignificantTermsHeuristicScoreScript
- SignificantTermsHeuristicScoreScript.Factory - Interface in org.elasticsearch.script
- significantText(String, String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
SignificantTextAggregationBuilder
aggregation with the given name and text field name - SignificantTextAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.terms
- SignificantTextAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- SignificantTextAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
-
Read from a stream.
- SignificantTextAggregationBuilder(SignificantTextAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- SignificantTextAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.terms
- SignificantTextAggregatorFactory(String, IncludeExclude, QueryBuilder, TermsAggregator.BucketCountThresholds, SignificanceHeuristic, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, String, String[], boolean, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregatorFactory
- similarity(Function<String, MappedFieldType>) - Method in class org.elasticsearch.index.similarity.SimilarityService
-
The similarity to use in searches, which takes into account per-field configuration.
- similarity(Function<FieldMapper, SimilarityProvider>) - Static method in class org.elasticsearch.index.mapper.TextParams
- SIMILARITY_SETTINGS_PREFIX - Static variable in class org.elasticsearch.index.IndexModule
- similarityLookupService() - Method in class org.elasticsearch.index.mapper.MappingParserContext
- SimilarityProvider - Class in org.elasticsearch.index.similarity
-
Wrapper around a
Similarity
and its name. - SimilarityProvider(String, Similarity) - Constructor for class org.elasticsearch.index.similarity.SimilarityProvider
- SimilarityScript - Class in org.elasticsearch.script
-
A script that is used to build
ScriptedSimilarity
instances. - SimilarityScript() - Constructor for class org.elasticsearch.script.SimilarityScript
- SimilarityScript.Factory - Interface in org.elasticsearch.script
- similarityService() - Method in class org.elasticsearch.index.IndexService
- SimilarityService - Class in org.elasticsearch.index.similarity
- SimilarityService(IndexSettings, ScriptService, Map<String, TriFunction<Settings, Version, ScriptService, Similarity>>) - Constructor for class org.elasticsearch.index.similarity.SimilarityService
- SimilarityWeightScript - Class in org.elasticsearch.script
-
A script that is used to compute scoring factors that are the same for all documents.
- SimilarityWeightScript() - Constructor for class org.elasticsearch.script.SimilarityWeightScript
- SimilarityWeightScript.Factory - Interface in org.elasticsearch.script
- Simple() - Constructor for class org.elasticsearch.action.support.ActionFilter.Simple
- SIMPLE - Enum constant in enum class org.elasticsearch.index.mapper.DynamicTemplate.MatchType
- SIMPLE - Enum constant in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- SIMPLE_MATCH_ONLY - Static variable in class org.elasticsearch.index.mapper.TextSearchInfo
-
Defines indexing information for fields that support only simple match text queries
- SIMPLE_MATCH_WITHOUT_TERMS - Static variable in class org.elasticsearch.index.mapper.TextSearchInfo
-
Defines indexing information for fields that support simple match text queries without using the terms index
- SimpleAnalyzerProvider - Class in org.elasticsearch.index.analysis
- SimpleAnalyzerProvider(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SimpleAnalyzerProvider
- SimpleFeatureFactory - Class in org.elasticsearch.common.geo
-
Transforms points and rectangles objects in WGS84 into mvt features.
- SimpleFeatureFactory(int, int, int, int) - Constructor for class org.elasticsearch.common.geo.SimpleFeatureFactory
- SimpleFragmentsBuilder - Class in org.elasticsearch.search.fetch.subphase.highlight
-
Direct Subclass of Lucene's org.apache.lucene.search.vectorhighlight.SimpleFragmentsBuilder that corrects offsets for broken analysis chains.
- SimpleFragmentsBuilder(MappedFieldType, boolean, String[], String[], BoundaryScanner) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.SimpleFragmentsBuilder
- SIMPLEFS - Enum constant in enum class org.elasticsearch.index.IndexModule.Type
- SimpleKey(String) - Constructor for class org.elasticsearch.common.settings.Setting.SimpleKey
- SimpleMappedFieldType - Class in org.elasticsearch.index.mapper
-
MappedFieldType
base impl for field types that are neither dates nor ranges. - SimpleMappedFieldType(String, boolean, boolean, boolean, TextSearchInfo, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.SimpleMappedFieldType
- simpleMatch(String[], String) - Static method in class org.elasticsearch.common.regex.Regex
-
Match a String against the given patterns, supporting the following simple pattern styles: "xxx*", "*xxx", "*xxx*" and "xxx*yyy" matches (with an arbitrary number of pattern parts), as well as direct equality.
- simpleMatch(String[], String[]) - Static method in class org.elasticsearch.common.regex.Regex
- simpleMatch(String, String) - Static method in class org.elasticsearch.common.regex.Regex
-
Match a String against the given pattern, supporting the following simple pattern styles: "xxx*", "*xxx", "*xxx*" and "xxx*yyy" matches (with an arbitrary number of pattern parts), as well as direct equality.
- simpleMatch(String, String, boolean) - Static method in class org.elasticsearch.common.regex.Regex
-
Match a String against the given pattern, supporting the following simple pattern styles: "xxx*", "*xxx", "*xxx*" and "xxx*yyy" matches (with an arbitrary number of pattern parts), as well as direct equality.
- simpleMatch(List<String>, String) - Static method in class org.elasticsearch.common.regex.Regex
-
Similar to
Regex.simpleMatch(String[], String)
, but accepts a list of strings instead of an array of strings for the patterns to match. - simpleMatchToAutomaton(String) - Static method in class org.elasticsearch.common.regex.Regex
-
Return an
Automaton
that matches the given pattern. - simpleMatchToAutomaton(String...) - Static method in class org.elasticsearch.common.regex.Regex
-
Return an Automaton that matches the union of the provided patterns.
- SimpleModel - Class in org.elasticsearch.search.aggregations.pipeline
-
Calculate a simple unweighted (arithmetic) moving average
- SimpleModel() - Constructor for class org.elasticsearch.search.aggregations.pipeline.SimpleModel
- SimpleModel(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.SimpleModel
-
Read from a stream.
- SimpleModel.SimpleModelBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- SimpleModelBuilder() - Constructor for class org.elasticsearch.search.aggregations.pipeline.SimpleModel.SimpleModelBuilder
- simpleName() - Method in class org.elasticsearch.index.mapper.Mapper
-
Returns the simple name, which identifies this mapper against other mappers at the same level in the mappers hierarchy TODO: make this protected once Mapper and FieldMapper are merged together
- SimpleQueryStringBuilder - Class in org.elasticsearch.index.query
-
SimpleQuery is a query parser that acts similar to a query_string query, but won't throw exceptions for any weird string syntax.
- SimpleQueryStringBuilder(String) - Constructor for class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Construct a new simple query with this query string.
- SimpleQueryStringBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Read from a stream.
- SimpleQueryStringFlag - Enum Class in org.elasticsearch.index.query
-
Flags for the XSimpleQueryString parser
- simpleQueryStringQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A query that acts similar to a query_string query, but won't throw exceptions for any weird string syntax.
- SimpleQueryStringQueryParser - Class in org.elasticsearch.index.search
-
Wrapper class for Lucene's SimpleQueryStringQueryParser that allows us to redefine different types of queries.
- SimpleQueryStringQueryParser(Map<String, Float>, int, SimpleQueryStringQueryParser.Settings, SearchExecutionContext) - Constructor for class org.elasticsearch.index.search.SimpleQueryStringQueryParser
-
Creates a new parser with custom flags used to enable/disable certain features.
- SimpleQueryStringQueryParser(Analyzer, Map<String, Float>, int, SimpleQueryStringQueryParser.Settings, SearchExecutionContext) - Constructor for class org.elasticsearch.index.search.SimpleQueryStringQueryParser
-
Creates a new parser with custom flags used to enable/disable certain features.
- SimpleQueryStringQueryParser.Settings - Class in org.elasticsearch.index.search
-
Class encapsulating the settings for the SimpleQueryString query, with their default values
- simpleString(String, String, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
-
Creates a new Setting instance with a String value
- simpleString(String, String, Setting.Validator<String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- simpleString(String, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- simpleString(String, Setting.Validator<String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- simpleString(String, Setting.Validator<String>, Setting<String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- simpleString(String, Setting<String>, Function<String, String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- simpleString(String, Setting<String>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- SimpleValue - Interface in org.elasticsearch.search.aggregations.pipeline
- SimpleVectorTileFormatter - Class in org.elasticsearch.common.geo
-
A facade for SimpleFeatureFactory that converts it into FormatterFactory for use in GeoPointFieldMapper
- SimpleVectorTileFormatter() - Constructor for class org.elasticsearch.common.geo.SimpleVectorTileFormatter
- SimulatedAnealingMinimizer - Class in org.elasticsearch.search.aggregations.pipeline
-
A cost minimizer which will fit a MovAvgModel to the data.
- SimulatedAnealingMinimizer() - Constructor for class org.elasticsearch.search.aggregations.pipeline.SimulatedAnealingMinimizer
- SimulateDocumentBaseResult - Class in org.elasticsearch.action.ingest
-
Holds the end result of what a pipeline did to sample document provided via the simulate api.
- SimulateDocumentBaseResult(Exception) - Constructor for class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- SimulateDocumentBaseResult(StreamInput) - Constructor for class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
-
Read from a stream.
- SimulateDocumentBaseResult(IngestDocument) - Constructor for class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- SimulateDocumentResult - Interface in org.elasticsearch.action.ingest
- SimulateDocumentVerboseResult - Class in org.elasticsearch.action.ingest
-
Holds the result of what a pipeline did to a sample document via the simulate api, but instead of
SimulateDocumentBaseResult
this result class holds the intermediate result each processor did to the sample document. - SimulateDocumentVerboseResult(List<SimulateProcessorResult>) - Constructor for class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
- SimulateDocumentVerboseResult(StreamInput) - Constructor for class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
-
Read from a stream.
- SimulateIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.post
- SimulateIndexTemplateRequest - Class in org.elasticsearch.action.admin.indices.template.post
- SimulateIndexTemplateRequest(String) - Constructor for class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateRequest
- SimulateIndexTemplateRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateRequest
- SimulateIndexTemplateResponse - Class in org.elasticsearch.action.admin.indices.template.post
-
Contains the information on what V2 templates would match a given index.
- SimulateIndexTemplateResponse(Template, Map<String, List<String>>) - Constructor for class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateResponse
- SimulateIndexTemplateResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateResponse
- simulatePipeline(SimulatePipelineRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Simulates an ingest pipeline
- simulatePipeline(SimulatePipelineRequest, ActionListener<SimulatePipelineResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Simulates an ingest pipeline
- SimulatePipelineAction - Class in org.elasticsearch.action.ingest
- SimulatePipelineAction() - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineAction
- SimulatePipelineRequest - Class in org.elasticsearch.action.ingest
- SimulatePipelineRequest(BytesReference, XContentType) - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineRequest
-
Creates a new request with the given source and its content type
- SimulatePipelineRequest.Fields - Class in org.elasticsearch.action.ingest
- SimulatePipelineRequestBuilder - Class in org.elasticsearch.action.ingest
- SimulatePipelineRequestBuilder(ElasticsearchClient, SimulatePipelineAction) - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineRequestBuilder
-
Create a new builder for
SimulatePipelineRequest
s - SimulatePipelineRequestBuilder(ElasticsearchClient, SimulatePipelineAction, BytesReference, XContentType) - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineRequestBuilder
-
Create a new builder for
SimulatePipelineRequest
s - SimulatePipelineResponse - Class in org.elasticsearch.action.ingest
- SimulatePipelineResponse(String, boolean, List<SimulateDocumentResult>) - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineResponse
- SimulatePipelineResponse(StreamInput) - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineResponse
- SimulatePipelineTransportAction - Class in org.elasticsearch.action.ingest
- SimulatePipelineTransportAction(ThreadPool, TransportService, ActionFilters, IngestService) - Constructor for class org.elasticsearch.action.ingest.SimulatePipelineTransportAction
- SimulateProcessorResult - Class in org.elasticsearch.action.ingest
- SimulateProcessorResult(String, String, String, Exception, Tuple<String, Boolean>) - Constructor for class org.elasticsearch.action.ingest.SimulateProcessorResult
- SimulateProcessorResult(String, String, String, Tuple<String, Boolean>) - Constructor for class org.elasticsearch.action.ingest.SimulateProcessorResult
- SimulateProcessorResult(String, String, String, IngestDocument, Exception, Tuple<String, Boolean>) - Constructor for class org.elasticsearch.action.ingest.SimulateProcessorResult
- SimulateProcessorResult(String, String, String, IngestDocument, Tuple<String, Boolean>) - Constructor for class org.elasticsearch.action.ingest.SimulateProcessorResult
- SimulateTemplateAction - Class in org.elasticsearch.action.admin.indices.template.post
-
An action for simulating the complete composed settings of the specified index template name, or index template configuration
- SimulateTemplateAction.Request - Class in org.elasticsearch.action.admin.indices.template.post
- single(Decision.Type, String, String, Object...) - Static method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
-
Creates a simple decision
- single(T) - Static method in class org.elasticsearch.common.collect.Iterators
-
Returns a single element iterator over the supplied value.
- Single(Decision.Type, String, String, Object...) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
-
Creates a new
Decision.Single
decision of a given type - SINGLE - Enum constant in enum class org.elasticsearch.common.unit.SizeUnit
- SINGLE_INSTANCE_AND_SCOPE - Static variable in class org.elasticsearch.common.inject.internal.AbstractBindingBuilder
- SINGLE_MAPPING_NAME - Static variable in class org.elasticsearch.index.mapper.MapperService
- SINGLE_NODE_DISCOVERY_TYPE - Static variable in class org.elasticsearch.discovery.DiscoveryModule
- SingleBucketAggregation - Interface in org.elasticsearch.search.aggregations.bucket
-
A single bucket aggregation
- SingleBucketAggregator - Interface in org.elasticsearch.search.aggregations.bucket
-
A bucket aggregator that doesn't create new buckets.
- SingleFeatureMigrationResult - Class in org.elasticsearch.upgrades
-
Holds the results of migrating a single feature.
- SingleFieldsVisitor - Class in org.elasticsearch.index.fieldvisitor
-
StoredFieldVisitor that loads a single field value.
- SingleFieldsVisitor(MappedFieldType, List<Object>) - Constructor for class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
-
Build the field visitor;
- SingleMetricAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.SingleMetricAggregationBuilder
- SingleMetricAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.SingleMetricAggregationBuilder
- SingleMetricAggregationBuilder(ValuesSourceAggregationBuilder.LeafOnly<VS, AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.SingleMetricAggregationBuilder
- SingleNodeShutdownMetadata - Class in org.elasticsearch.cluster.metadata
-
Contains data about a single node's shutdown readiness.
- SingleNodeShutdownMetadata(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- SingleNodeShutdownMetadata.Builder - Class in org.elasticsearch.cluster.metadata
- SingleNodeShutdownMetadata.Status - Enum Class in org.elasticsearch.cluster.metadata
-
Describes the status of a component of shutdown.
- SingleNodeShutdownMetadata.Type - Enum Class in org.elasticsearch.cluster.metadata
-
Describes the type of node shutdown - permanent (REMOVE) or temporary (RESTART).
- SingleObjectCache<T> - Class in org.elasticsearch.common.util
-
A very simple single object cache that allows non-blocking refresh calls triggered by expiry time.
- SingleObjectCache(TimeValue, T) - Constructor for class org.elasticsearch.common.util.SingleObjectCache
- SinglePackedOrdinals - Class in org.elasticsearch.index.fielddata.ordinals
- SinglePackedOrdinals(OrdinalsBuilder, float) - Constructor for class org.elasticsearch.index.fielddata.ordinals.SinglePackedOrdinals
- SingleResultDeduplicator<T> - Class in org.elasticsearch.action
-
Wraps an async action that consumes an
ActionListener
such that multiple invocations ofSingleResultDeduplicator.execute(ActionListener)
can share the result from a single call to the wrapped action. - SingleResultDeduplicator(ThreadContext, Consumer<ActionListener<T>>) - Constructor for class org.elasticsearch.action.SingleResultDeduplicator
- singles() - Method in class org.elasticsearch.common.unit.SizeValue
- singleSession() - Method in class org.elasticsearch.search.internal.LegacyReaderContext
- singleSession() - Method in class org.elasticsearch.search.internal.ReaderContext
-
Returns
true
for readers that are intended to use in a single query. - SingleShardOperationRequestBuilder<Request extends SingleShardRequest<Request>,
Response extends ActionResponse, RequestBuilder extends SingleShardOperationRequestBuilder<Request, Response, RequestBuilder>> - Class in org.elasticsearch.action.support.single.shard - SingleShardOperationRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardOperationRequestBuilder
- SingleShardRequest<Request extends SingleShardRequest<Request>> - Class in org.elasticsearch.action.support.single.shard
- SingleShardRequest() - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardRequest
- SingleShardRequest(String) - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardRequest
- SingleShardRequest(StreamInput) - Constructor for class org.elasticsearch.action.support.single.shard.SingleShardRequest
- singleton(String, boolean, boolean, Function<TokenStream, TokenStream>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredTokenFilter
-
Create a pre-configured token filter that may not vary at all.
- singleton(String, boolean, Function<Reader, Reader>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredCharFilter
-
Create a pre-configured char filter that may not vary at all.
- singleton(String, boolean, Function<TokenStream, TokenStream>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredTokenFilter
-
Create a pre-configured token filter that may not vary at all.
- singleton(String, Supplier<Tokenizer>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredTokenizer
-
Create a pre-configured tokenizer that may not vary at all.
- singleton(BinaryDocValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns a multi-valued view over the provided
BinaryDocValues
. - singleton(GeoPointValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns a multi-valued view over the provided
GeoPointValues
. - singleton(NumericDoubleValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns a multi-valued view over the provided
NumericDoubleValues
. - Singleton - Annotation Interface in org.elasticsearch.common.inject
-
Apply this to implementation classes when you want only one instance (per
Injector
) to be reused for all injections for that binding. - SINGLETON - Static variable in class org.elasticsearch.common.inject.Scopes
-
One instance per
Injector
. - SINGLETON_ANNOTATION - Static variable in class org.elasticsearch.common.inject.internal.Scoping
- SINGLETON_INSTANCE - Static variable in class org.elasticsearch.common.inject.internal.Scoping
- singletonWithVersion(String, boolean, BiFunction<Reader, Version, Reader>) - Static method in class org.elasticsearch.index.analysis.PreConfiguredCharFilter
-
Create a pre-configured char filter that may not vary at all, provide access to the elasticsearch version
- SingleValue(String, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
- SingleValue(String, AggregationContext, Aggregator, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregator.SingleValue
- SingleValue(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
-
Read from a stream.
- size - Variable in class org.elasticsearch.index.translog.Translog.Location
- size - Variable in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSource
- size - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion
- size - Variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- size() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- size() - Method in class org.elasticsearch.action.ResultDeduplicator
- size() - Method in class org.elasticsearch.action.search.SearchShardIterator
- size() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- size() - Method in class org.elasticsearch.action.termvectors.TermVectorsFields
- size() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
-
Return the number of groups
- size() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
-
Returns the number of this shards instances.
- size() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- size() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Returns the number of routing nodes
- size() - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
-
Returns the size of the non-ignored unassigned shards
- size() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
The number of shard routing instances.
- size() - Method in class org.elasticsearch.common.collect.CopyOnWriteHashMap
- size() - Method in class org.elasticsearch.common.collect.EvictingQueue
- size() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- size() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- size() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- size() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- size() - Method in class org.elasticsearch.common.inject.internal.Errors
- size() - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
-
Returns the current size of the buffer.
- size() - Method in class org.elasticsearch.common.lucene.ShardCoreKeyMap
-
Return the number of tracked segments.
- size() - Method in class org.elasticsearch.common.settings.Settings
-
Returns the number of settings in this settings object.
- size() - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
-
Return the number of longs in this hash table.
- size() - Method in interface org.elasticsearch.common.util.BigArray
-
Return the length of this array.
- size() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- size() - Method in interface org.elasticsearch.common.util.Countable
- size() - Method in class org.elasticsearch.common.util.LazyMap
- size() - Method in class org.elasticsearch.common.util.PlainIterator
- size() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingCollection
-
the number of nodes for which there are known pings
- size() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.BytesRefs
- size() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Booleans
- size() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Dates
- size() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Doubles
- size() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.GeoPoints
- size() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues.Longs
- size() - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType.IpScriptDocValues
- size() - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
-
Returns the number of files in this snapshot
- size() - Method in class org.elasticsearch.index.store.Store.RecoveryDiff
-
Returns the sum of the files in this diff.
- size() - Method in class org.elasticsearch.index.store.StoreStats
- size() - Method in class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan.SnapshotFilesToRecover
- size() - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
the number of ongoing recoveries
- size() - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- size() - Method in class org.elasticsearch.script.DynamicMap
- size() - Method in class org.elasticsearch.script.field.EmptyField
- size() - Method in interface org.elasticsearch.script.field.Field
-
Returns the number of values this field has.
- size() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- size() - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- size() - Method in class org.elasticsearch.search.aggregations.bucket.terms.BytesKeyedBucketOrds
-
The number of collected buckets.
- size() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromMany
- size() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromManySmall
- size() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.FromSingle
- size() - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds
-
The number of collected buckets.
- size() - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Returns the number of term buckets currently configured
- size() - Method in interface org.elasticsearch.search.aggregations.metrics.AbstractLinearCounting.HashesIterator
-
number of elements in the iterator
- size() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Gets the number of search hits to return.
- size() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the number of search hits to return.
- size() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- size() - Method in class org.elasticsearch.search.internal.SearchContext
- size() - Method in class org.elasticsearch.search.internal.SubSearchContext
- size() - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- size() - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- size() - Method in class org.elasticsearch.search.lookup.SourceLookup
- size() - Method in class org.elasticsearch.search.query.QuerySearchResult
-
Returns the maximum size of this results top docs.
- size() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
- size() - Method in class org.elasticsearch.search.suggest.Suggest
-
The number of suggestions in this
Suggest
result - size() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the
SuggestionBuilder.size()
parameter - size() - Method in class org.elasticsearch.transport.ClusterConnectionManager
-
Returns the number of nodes this manager is connected to.
- size() - Method in interface org.elasticsearch.transport.ConnectionManager
- size() - Method in class org.elasticsearch.transport.RemoteConnectionManager
- size(int) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- size(int) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Deprecated.please use maxDocs(int) instead.
- size(int) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
-
The number of composite buckets to return.
- size(int) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregationBuilder
- size(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregationBuilder
-
Sets the size - indicating how many term buckets should be returned (defaults to 10)
- size(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
-
Sets the size - indicating how many term buckets should be returned (defaults to 10)
- size(int) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Sets the size - indicating how many term buckets should be returned (defaults to 10)
- size(int) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
The number of search hits to return.
- size(int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
The number of search hits to return.
- size(int) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- size(int) - Method in class org.elasticsearch.search.internal.SearchContext
- size(int) - Method in class org.elasticsearch.search.internal.SubSearchContext
- size(int) - Method in class org.elasticsearch.search.query.QuerySearchResult
- size(int) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets the maximum suggestions to be returned per suggest text term.
- size(int) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
Sets the maximum suggestions to be returned per suggest text term.
- size(long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractLinearCounting
-
number of values in the counter.
- size(Integer) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- size(Iterable<?>) - Static method in class org.elasticsearch.common.util.iterable.Iterables
- size(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsFilter
- SIZE_ALL_MATCHES - Static variable in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
-
Deprecated.please use MAX_DOCS_ALL_MATCHES instead.
- SIZE_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- SIZE_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- SIZE_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- SIZE_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- sizeActive() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
- sizeActive() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
-
The number of active shard routing instances
- SizeBlockingQueue<E> - Class in org.elasticsearch.common.util.concurrent
-
A size based queue wrapping another blocking queue to provide (somewhat relaxed) capacity checks.
- SizeBlockingQueue(BlockingQueue<E>, int) - Constructor for class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- sizeContexts - Variable in class org.elasticsearch.script.ScriptService.ContextSettings
- SizedBucketAggregator - Interface in org.elasticsearch.search.aggregations.bucket.histogram
-
An aggregator capable of reporting bucket sizes in requested units.
- SizedBucketAggregatorBuilder - Interface in org.elasticsearch.search.aggregations.bucket.histogram
-
An aggregator capable of reporting bucket sizes in milliseconds.
- sizeInBytes - Variable in class org.elasticsearch.index.engine.Segment
- sizeInBytes() - Method in class org.elasticsearch.index.store.StoreStats
- sizeInBytes() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- sizeInBytes() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the size in bytes of the v files
- sizeInBytes() - Method in class org.elasticsearch.index.translog.TranslogReader
- sizeInBytes() - Method in class org.elasticsearch.index.translog.TranslogWriter
- sizeInBytesByMinGen(long) - Method in class org.elasticsearch.index.translog.Translog
-
Returns the size in bytes of the translog files at least the given generation
- sizeOfRelocatingShards(RoutingNode, boolean, String, ClusterInfo, Metadata, RoutingTable) - Static method in class org.elasticsearch.cluster.routing.allocation.decider.DiskThresholdDecider
-
Returns the size of all shards that are currently being relocated to the node, but may not be finished transferring yet.
- SizeUnit - Enum Class in org.elasticsearch.common.unit
- SizeValue - Class in org.elasticsearch.common.unit
- SizeValue(long) - Constructor for class org.elasticsearch.common.unit.SizeValue
- SizeValue(long, SizeUnit) - Constructor for class org.elasticsearch.common.unit.SizeValue
- SizeValue(StreamInput) - Constructor for class org.elasticsearch.common.unit.SizeValue
- skip(int) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- skip(long) - Method in class org.elasticsearch.common.io.stream.ByteBufferStreamInput
- skip(long) - Method in class org.elasticsearch.common.io.stream.InputStreamStreamInput
- skip(long) - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamInput
- SKIP - Enum constant in enum class org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
- skipBytes(long) - Method in class org.elasticsearch.common.io.stream.ByteArrayStreamInput
- skipDueToVersionConflict(VersionConflictEngineException, boolean, long) - Static method in class org.elasticsearch.index.engine.InternalEngine.IndexingStrategy
- skipDueToVersionConflict(VersionConflictEngineException, long, boolean) - Static method in class org.elasticsearch.index.engine.InternalEngine.DeletionStrategy
- skipDuplicates - Variable in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- skipDuplicates() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Returns whether duplicate suggestions should be filtered out.
- skipDuplicates(boolean) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
-
Should duplicates be filtered or not.
- skipOperatorOnlyState() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- skipOperatorOnlyState(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- SKIPPED - Static variable in class org.elasticsearch.snapshots.SnapshotInfo.IndexSnapshotDetails
- SKIPPED_FIELD - Static variable in class org.elasticsearch.rest.action.RestActions
- skippedOperations() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
-
The number of operations have been skipped (overridden or trimmed) in the snapshot so far.
- skipSources(Class<?>...) - Method in interface org.elasticsearch.common.inject.Binder
-
Returns a binder that skips
classesToSkip
when identify the calling code. - skipSources(Class<?>...) - Method in interface org.elasticsearch.common.inject.PrivateBinder
- skipStackTrace() - Method in class org.elasticsearch.rest.BytesRestResponse
- skipTranslogRecovery() - Method in class org.elasticsearch.index.engine.Engine
-
Do not replay translog operations, but make the engine be ready.
- skipTranslogRecovery() - Method in class org.elasticsearch.index.engine.InternalEngine
- skipTranslogRecovery() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- slice() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the slice used to filter the search hits, the top hits and the aggregations.
- slice(int, int) - Method in class org.elasticsearch.common.bytes.BytesArray
- slice(int, int) - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Slice the bytes from the
from
index up tolength
. - slice(int, int) - Method in class org.elasticsearch.common.bytes.CompositeBytesReference
- slice(int, int) - Method in class org.elasticsearch.common.bytes.PagedBytesReference
- slice(int, int) - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- slice(String, long, long) - Method in class org.elasticsearch.common.lucene.store.ByteArrayIndexInput
- slice(SliceBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
- slice(SliceBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets a filter that will restrict the search hits, the top hits and the aggregations to a slice of the results of the main query.
- SLICE - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- SLICE_ID_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- SliceBuilder - Class in org.elasticsearch.search.slice
-
A slice builder allowing to split a scroll in multiple partitions.
- SliceBuilder(int, int) - Constructor for class org.elasticsearch.search.slice.SliceBuilder
-
Build a slice using the default strategy.
- SliceBuilder(String, int, int) - Constructor for class org.elasticsearch.search.slice.SliceBuilder
-
Build a slice on a particular field.
- SliceBuilder(StreamInput) - Constructor for class org.elasticsearch.search.slice.SliceBuilder
- SlicedInputStream - Class in org.elasticsearch.index.snapshots.blobstore
-
A
SlicedInputStream
is a logical concatenation one or more input streams. - SlicedInputStream(int) - Constructor for class org.elasticsearch.index.snapshots.blobstore.SlicedInputStream
-
Creates a new SlicedInputStream
- SliceQuery - Class in org.elasticsearch.search.slice
-
An abstract
Query
that defines an hash function to partition the documents in multiple slices. - SliceQuery(String, int, int) - Constructor for class org.elasticsearch.search.slice.SliceQuery
- SLICES_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- SLM_POLICY_FILTERING_VERSION - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- slop() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Get the slop factor for phrase queries.
- slop() - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Get the slop factor for phrase queries.
- slop() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- slop() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder
- slop(int) - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Sets a slop factor for phrase queries
- slop(int) - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Sets a slop factor for phrase queries
- slop(int) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Set the phrase slop if evaluated to a phrase query type.
- SLOP - Enum constant in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- SLOP_FIELD - Static variable in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- SLOW_OPERATION_THRESHOLD_SETTING - Static variable in class org.elasticsearch.transport.TransportSettings
- SLOW_PATH_LOGGING_THRESHOLD_SETTING - Static variable in class org.elasticsearch.monitor.fs.FsHealthService
- SLOW_SCHEDULER_TASK_WARN_THRESHOLD_SETTING - Static variable in class org.elasticsearch.threadpool.ThreadPool
- SLOW_WRITE_LOGGING_THRESHOLD - Static variable in class org.elasticsearch.gateway.PersistedClusterStateService
- SlowLogLevel - Enum Class in org.elasticsearch.index
- SMOOTHING_MODEL_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- smoothingModel() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Gets the
SmoothingModel
- smoothingModel(SmoothingModel) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
Sets an explicit smoothing model used for this suggester.
- SmoothingModel - Class in org.elasticsearch.search.suggest.phrase
- SmoothingModel() - Constructor for class org.elasticsearch.search.suggest.phrase.SmoothingModel
- snapshot() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
The snapshot name
- snapshot() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns the name of the snapshot.
- snapshot() - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
-
Returns snapshot
- snapshot() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- snapshot() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- snapshot() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns snapshot name
- snapshot() - Method in class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
-
Returns snapshot name
- snapshot() - Method in class org.elasticsearch.snapshots.InternalSnapshotsInfoService.SnapshotShard
- snapshot() - Method in class org.elasticsearch.snapshots.SnapshotInfo
- snapshot() - Method in class org.elasticsearch.snapshots.UpdateIndexShardSnapshotStatusRequest
- snapshot(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Sets the snapshot name
- snapshot(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sets the name of the snapshot.
- snapshot(Collection<String>) - Method in class org.elasticsearch.cluster.metadata.DataStream
-
Reconciles this data stream with a list of indices available in a snapshot.
- snapshot(Metadata, List<String>, List<String>) - Static method in class org.elasticsearch.cluster.metadata.Metadata
-
Reconciles the cluster state metadata taken at the end of a snapshot with the data streams and indices contained in the snapshot.
- snapshot(Snapshot) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- Snapshot - Class in org.elasticsearch.snapshots
-
Basic information about a snapshot - a SnapshotId and the repository that the snapshot belongs to.
- Snapshot(String, SnapshotId) - Constructor for class org.elasticsearch.snapshots.Snapshot
-
Constructs a snapshot.
- Snapshot(StreamInput) - Constructor for class org.elasticsearch.snapshots.Snapshot
-
Constructs a snapshot from the stream input.
- SNAPSHOT - Enum constant in enum class org.elasticsearch.cluster.metadata.Metadata.XContentContext
- SNAPSHOT - Enum constant in enum class org.elasticsearch.cluster.routing.RecoverySource.Type
- SNAPSHOT - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- SNAPSHOT_ALREADY_EXISTS_EXCEPTION_DESC - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- SNAPSHOT_ALREADY_IN_PROGRESS_EXCEPTION_DESC - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- SNAPSHOT_FILE_DOWNLOAD_THROTTLING_SUPPORTED_VERSION - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
- SNAPSHOT_FORMAT - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- SNAPSHOT_INFO_PARSER - Static variable in class org.elasticsearch.snapshots.SnapshotInfo
- SNAPSHOT_META - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- SNAPSHOT_NAME_FORMAT - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- SNAPSHOT_ONLY_FORMAT_PARAMS - Static variable in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- SNAPSHOT_PARTIAL_SETTING - Static variable in class org.elasticsearch.snapshots.SearchableSnapshotsSettings
- SNAPSHOT_PREFIX - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- SNAPSHOT_RECOVERIES_SUPPORTED_VERSION - Static variable in class org.elasticsearch.indices.recovery.RecoverySettings
- SnapshotCreationException - Exception in org.elasticsearch.snapshots
-
Deprecated.This exception isn't thrown anymore. It's only here for BwC.
- SnapshotCreationException(String, SnapshotId, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotCreationException
-
Deprecated.
- SnapshotCreationException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotCreationException
-
Deprecated.
- SnapshotDeletionsInProgress - Class in org.elasticsearch.cluster
-
A class that represents the snapshot deletions that are in progress in the cluster.
- SnapshotDeletionsInProgress(StreamInput) - Constructor for class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- SnapshotDeletionsInProgress.Entry - Class in org.elasticsearch.cluster
-
A class representing a snapshot deletion request entry in the cluster state.
- SnapshotDeletionsInProgress.State - Enum Class in org.elasticsearch.cluster
- SnapshotDetails(SnapshotState, Version, long, long, String) - Constructor for class org.elasticsearch.repositories.RepositoryData.SnapshotDetails
- SnapshotException - Exception in org.elasticsearch.snapshots
-
Generic snapshot exception
- SnapshotException(String, String, String) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
- SnapshotException(String, String, String, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
- SnapshotException(String, SnapshotId, String, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
- SnapshotException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
- SnapshotException(Snapshot, String) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
- SnapshotException(Snapshot, String, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotException
- SnapshotFeatureInfo - Class in org.elasticsearch.snapshots
- SnapshotFeatureInfo(String, List<String>) - Constructor for class org.elasticsearch.snapshots.SnapshotFeatureInfo
- SnapshotFeatureInfo(StreamInput) - Constructor for class org.elasticsearch.snapshots.SnapshotFeatureInfo
- SnapshotFiles - Class in org.elasticsearch.index.snapshots.blobstore
-
Contains a list of files participating in a snapshot
- SnapshotFiles(String, List<BlobStoreIndexShardSnapshot.FileInfo>, String) - Constructor for class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
- SnapshotFilesProvider - Class in org.elasticsearch.indices.recovery
- SnapshotFilesProvider(RepositoriesService) - Constructor for class org.elasticsearch.indices.recovery.SnapshotFilesProvider
- SnapshotFilesToRecover(IndexId, String, List<BlobStoreIndexShardSnapshot.FileInfo>) - Constructor for class org.elasticsearch.indices.recovery.plan.ShardRecoveryPlan.SnapshotFilesToRecover
- snapshotId - Variable in class org.elasticsearch.repositories.blobstore.FileRestoreContext
- snapshotId() - Method in class org.elasticsearch.repositories.SnapshotShardContext
- snapshotId() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns snapshot id
- SnapshotId - Class in org.elasticsearch.snapshots
-
SnapshotId - snapshot name + snapshot UUID
- SnapshotId(String, String) - Constructor for class org.elasticsearch.snapshots.SnapshotId
-
Constructs a new snapshot
- SnapshotId(StreamInput) - Constructor for class org.elasticsearch.snapshots.SnapshotId
-
Constructs a new snapshot from a input stream
- snapshotIds() - Method in class org.elasticsearch.repositories.GetSnapshotInfoContext
- snapshotIndexMetadataIdentifier(SnapshotId, IndexId) - Method in class org.elasticsearch.repositories.IndexMetaDataGenerations
-
Gets the
IndexMetadata
identifier for the given snapshot if the snapshot contains the referenced index, otherwise it returnsnull
. - SnapshotIndexShardStage - Enum Class in org.elasticsearch.action.admin.cluster.snapshots.status
- SnapshotIndexShardStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- SnapshotIndexShardStatus(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
- SnapshotIndexStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Represents snapshot status of all shards in the index
- SnapshotIndexStatus(String, Map<Integer, SnapshotIndexShardStatus>, SnapshotShardsStats, SnapshotStats) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
- snapshotInfo() - Method in class org.elasticsearch.repositories.FinalizeSnapshotContext
- SnapshotInfo - Class in org.elasticsearch.snapshots
-
Information about a snapshot
- SnapshotInfo(Snapshot, List<String>, List<String>, List<SnapshotFeatureInfo>, String, long, int, List<SnapshotShardFailure>, Boolean, Map<String, Object>, long, Map<String, SnapshotInfo.IndexSnapshotDetails>) - Constructor for class org.elasticsearch.snapshots.SnapshotInfo
- SnapshotInfo(Snapshot, List<String>, List<String>, List<SnapshotFeatureInfo>, String, Version, long, long, int, int, List<SnapshotShardFailure>, Boolean, Map<String, Object>, SnapshotState, Map<String, SnapshotInfo.IndexSnapshotDetails>) - Constructor for class org.elasticsearch.snapshots.SnapshotInfo
- SnapshotInfo(Snapshot, List<String>, List<String>, List<SnapshotFeatureInfo>, SnapshotState) - Constructor for class org.elasticsearch.snapshots.SnapshotInfo
- SnapshotInfo(Snapshot, List<String>, List<String>, List<SnapshotFeatureInfo>, Version, SnapshotState) - Constructor for class org.elasticsearch.snapshots.SnapshotInfo
- SnapshotInfo.IndexSnapshotDetails - Class in org.elasticsearch.snapshots
- SnapshotInfo.SnapshotInfoBuilder - Class in org.elasticsearch.snapshots
- SnapshotInfoBuilder() - Constructor for class org.elasticsearch.snapshots.SnapshotInfo.SnapshotInfoBuilder
- SnapshotInProgressAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
This
AllocationDecider
prevents shards that are currently been snapshotted to be moved to other nodes. - SnapshotInProgressAllocationDecider() - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.SnapshotInProgressAllocationDecider
- SnapshotInProgressException - Exception in org.elasticsearch.snapshots
-
Thrown on the attempt to execute an action that requires that no snapshot is in progress.
- SnapshotInProgressException(String) - Constructor for exception org.elasticsearch.snapshots.SnapshotInProgressException
- SnapshotInProgressException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotInProgressException
- SnapshotMissingException - Exception in org.elasticsearch.snapshots
-
Thrown if requested snapshot doesn't exist
- SnapshotMissingException(String, String) - Constructor for exception org.elasticsearch.snapshots.SnapshotMissingException
- SnapshotMissingException(String, SnapshotId, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotMissingException
- SnapshotMissingException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotMissingException
- snapshotName() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.After
- SnapshotRecoverySource(String, Snapshot, Version, IndexId) - Constructor for class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- SnapshotRestoreException - Exception in org.elasticsearch.snapshots
-
Snapshot restore exception
- SnapshotRestoreException(String, String, String) - Constructor for exception org.elasticsearch.snapshots.SnapshotRestoreException
- SnapshotRestoreException(StreamInput) - Constructor for exception org.elasticsearch.snapshots.SnapshotRestoreException
- SnapshotRestoreException(Snapshot, String) - Constructor for exception org.elasticsearch.snapshots.SnapshotRestoreException
- SnapshotRestoreException(Snapshot, String, Throwable) - Constructor for exception org.elasticsearch.snapshots.SnapshotRestoreException
- snapshots() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- snapshots() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
-
Returns snapshot names
- snapshots() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Returns the names of the snapshots.
- snapshots() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Returns the names of the snapshots.
- snapshots() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
-
Returns list of snapshots
- snapshots(int) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- snapshots(String...) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
-
Sets snapshot names
- snapshots(String[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Sets the list of snapshots to be returned
- snapshots(String[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Sets the list of snapshots to be returned
- snapshots(Snapshot[]) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.Request
- snapshotsFromXContent(XContentParser, long, boolean) - Static method in class org.elasticsearch.repositories.RepositoryData
-
Reads an instance of
RepositoryData
from x-content, loading the snapshots and indices metadata. - snapshotShard(SnapshotShardContext) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- snapshotShard(SnapshotShardContext) - Method in class org.elasticsearch.repositories.FilterRepository
- snapshotShard(SnapshotShardContext) - Method in interface org.elasticsearch.repositories.Repository
-
Creates a snapshot of the shard referenced by the given
SnapshotShardContext
. - SnapshotShard(Snapshot, IndexId, ShardId) - Constructor for class org.elasticsearch.snapshots.InternalSnapshotsInfoService.SnapshotShard
- SnapshotShardContext - Class in org.elasticsearch.repositories
-
Context holding the state for creating a shard snapshot via
Repository.snapshotShard(SnapshotShardContext)
. - SnapshotShardContext(Store, MapperService, SnapshotId, IndexId, Engine.IndexCommitRef, String, IndexShardSnapshotStatus, Version, Map<String, Object>, ActionListener<ShardSnapshotResult>) - Constructor for class org.elasticsearch.repositories.SnapshotShardContext
- SnapshotShardFailure - Exception in org.elasticsearch.snapshots
-
Stores information about failures that occurred during shard snapshotting process
- SnapshotShardFailure(String, ShardId, String) - Constructor for exception org.elasticsearch.snapshots.SnapshotShardFailure
-
Constructs new snapshot shard failure object
- snapshotShardSizeInfo() - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
- SnapshotShardSizeInfo - Class in org.elasticsearch.snapshots
- SnapshotShardSizeInfo(ImmutableOpenMap<InternalSnapshotsInfoService.SnapshotShard, Long>) - Constructor for class org.elasticsearch.snapshots.SnapshotShardSizeInfo
- snapshotShardSizes() - Method in class org.elasticsearch.snapshots.EmptySnapshotsInfoService
- snapshotShardSizes() - Method in class org.elasticsearch.snapshots.InternalSnapshotsInfoService
- snapshotShardSizes() - Method in interface org.elasticsearch.snapshots.SnapshotsInfoService
- SnapshotShardsService - Class in org.elasticsearch.snapshots
-
This service runs on data nodes and controls currently running shard snapshots on these nodes.
- SnapshotShardsService(Settings, ClusterService, RepositoriesService, TransportService, IndicesService) - Constructor for class org.elasticsearch.snapshots.SnapshotShardsService
- SnapshotShardsStats - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Status of a snapshot shards
- SnapshotShardsStats(int, int, int, int, int, int) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
- SnapshotsInfoService - Interface in org.elasticsearch.snapshots
- SnapshotsInProgress - Class in org.elasticsearch.cluster
-
Meta data about snapshots that are currently executing
- SnapshotsInProgress(StreamInput) - Constructor for class org.elasticsearch.cluster.SnapshotsInProgress
- SnapshotsInProgress.Entry - Class in org.elasticsearch.cluster
- SnapshotsInProgress.ShardSnapshotStatus - Class in org.elasticsearch.cluster
- SnapshotsInProgress.ShardState - Enum Class in org.elasticsearch.cluster
- SnapshotsInProgress.State - Enum Class in org.elasticsearch.cluster
- SnapshotsRecoveryPlannerService - Class in org.elasticsearch.indices.recovery.plan
- SnapshotsRecoveryPlannerService(ShardSnapshotsService) - Constructor for class org.elasticsearch.indices.recovery.plan.SnapshotsRecoveryPlannerService
- SnapshotsService - Class in org.elasticsearch.snapshots
-
Service responsible for creating snapshots.
- SnapshotsService(Settings, ClusterService, IndexNameExpressionResolver, RepositoriesService, TransportService, ActionFilters, Map<String, SystemIndices.Feature>) - Constructor for class org.elasticsearch.snapshots.SnapshotsService
- snapshotsStatus(SnapshotsStatusRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshot status.
- snapshotsStatus(SnapshotsStatusRequest, ActionListener<SnapshotsStatusResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Get snapshot status.
- SnapshotsStatusAction - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Snapshots status action
- snapshotsStatusRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Get status of snapshots
- SnapshotsStatusRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Get snapshot status request
- SnapshotsStatusRequest() - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
- SnapshotsStatusRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Constructs a new get snapshots request with given repository name
- SnapshotsStatusRequest(String, String[]) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
-
Constructs a new get snapshots request with given repository name and list of snapshots
- SnapshotsStatusRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
- SnapshotsStatusRequestBuilder - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Snapshots status request builder
- SnapshotsStatusRequestBuilder(ElasticsearchClient, SnapshotsStatusAction) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
-
Constructs the new snapshot status request
- SnapshotsStatusRequestBuilder(ElasticsearchClient, SnapshotsStatusAction, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequestBuilder
-
Constructs the new snapshot status request with specified repository
- SnapshotsStatusResponse - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Snapshot status response
- SnapshotsStatusResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse
- SnapshotState - Enum Class in org.elasticsearch.snapshots
-
Represents the state that a snapshot can be in
- SnapshotStats - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- SnapshotStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Status of a snapshot
- snapshotStoreMetadata() - Method in class org.elasticsearch.index.shard.IndexShard
-
gets a
Store.MetadataSnapshot
for the current directory. - snapshotsToXContent(XContentBuilder, Version) - Method in class org.elasticsearch.repositories.RepositoryData
-
Writes the snapshots metadata and the related indices metadata to x-content.
- snapshotsToXContent(XContentBuilder, Version, boolean) - Method in class org.elasticsearch.repositories.RepositoryData
-
Writes the snapshots metadata and the related indices metadata to x-content.
- SnapshottableFeature(String, String) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse.SnapshottableFeature
- SnapshottableFeature(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse.SnapshottableFeature
- SnapshottableFeaturesAction - Class in org.elasticsearch.action.admin.cluster.snapshots.features
- snapshottingDataStreams(ClusterState, Set<String>) - Static method in class org.elasticsearch.snapshots.SnapshotsService
-
Returns the data streams that are currently being snapshotted (with partial == false) and that are contained in the indices-to-check set.
- snapshottingIndices(ClusterState, Set<Index>) - Static method in class org.elasticsearch.snapshots.SnapshotsService
-
Returns the indices that are currently being snapshotted (with partial == false) and that are contained in the indices-to-check set.
- SnapshotUtils - Class in org.elasticsearch.snapshots
-
Snapshot utilities
- SnapshotUtils() - Constructor for class org.elasticsearch.snapshots.SnapshotUtils
- snapshotUuid() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- snapshotUuid(String) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Sometimes a client has identified precisely which snapshot is to be restored via a separate mechanism and wishes to guarantee that this is the snapshot that this request restores.
- SniffConnectionStrategy - Class in org.elasticsearch.transport
- SniffConnectionStrategy.SniffModeInfo - Class in org.elasticsearch.transport
- SniffModeInfo(List<String>, int, int) - Constructor for class org.elasticsearch.transport.SniffConnectionStrategy.SniffModeInfo
- Snippet - Class in org.apache.lucene.search.uhighlight
-
Represents a scored highlighted snippet.
- Snippet(String, float, boolean) - Constructor for class org.apache.lucene.search.uhighlight.Snippet
- SOFT_DELETES_FIELD - Static variable in class org.elasticsearch.common.lucene.Lucene
- sort - Variable in class org.apache.lucene.search.grouping.CollapsingTopDocsCollector
- sort - Variable in class org.elasticsearch.search.sort.SortAndFormats
- sort() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- sort() - Method in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
-
Sort values that are stored between offsets
0
andSortingBinaryDocValues.count
ofSortingBinaryDocValues.values
. - sort() - Method in class org.elasticsearch.index.fielddata.SortingNumericDocValues
-
Sort values that are stored between offsets
0
andSortingNumericDocValues.count
ofSortingNumericDocValues.values
. - sort() - Method in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
-
Sort values that are stored between offsets
0
andSortingNumericDoubleValues.docValueCount()
ofSortingNumericDoubleValues.values
. - sort() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- sort() - Method in class org.elasticsearch.search.internal.SearchContext
- sort() - Method in class org.elasticsearch.search.internal.SubSearchContext
- sort() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- sort() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the sort setting.
- sort(ObjectArrayList<byte[]>) - Static method in class org.elasticsearch.common.util.CollectionUtils
- sort(String) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Add a sort against the given field name.
- sort(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Add a sort against the given field name.
- sort(String) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets how to sort the suggest terms per suggest text token.
- sort(String, SortOrder) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Adds a sort against the given field name and the sort ordering.
- sort(String, SortOrder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a sort against the given field name and the sort ordering.
- sort(Comparator<? super T>) - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
- sort(Comparator<O>) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- sort(Comparator<ShardRouting>) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- sort(List<SortBuilder<?>>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets the sort builders for this request.
- sort(BytesRefArray, int[]) - Static method in class org.elasticsearch.common.util.CollectionUtils
- sort(GetSnapshotsRequest.SortBy) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- sort(SortAndFormats) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- sort(SortAndFormats) - Method in class org.elasticsearch.search.internal.SearchContext
- sort(SortAndFormats) - Method in class org.elasticsearch.search.internal.SubSearchContext
- sort(SortBuilder<?>) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Adds a sort builder.
- sort(SortBuilder<?>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a sort builder.
- sort(SortBy) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- sort(SortBy) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets how to sort the suggest terms per suggest text token.
- SORT_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- SORT_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- SORT_MODE - Static variable in class org.elasticsearch.search.sort.FieldSortBuilder
- sortableLongBitsToDoubles(SortedNumericDocValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Given a
SortedNumericDocValues
, return aSortedNumericDoubleValues
instance that will translate long values to doubles usingNumericUtils.sortableLongToDouble(long)
. - sortAddresses(List<InetAddress>) - Static method in class org.elasticsearch.common.network.NetworkUtils
-
Deprecated.remove this when multihoming is really correct
- sortAndCreate(List<ShardIt>) - Static method in class org.elasticsearch.cluster.routing.GroupShardsIterator
-
Constructs a new sorted GroupShardsIterator from the given list.
- sortAndDedup(ObjectArrayList<byte[]>) - Static method in class org.elasticsearch.common.util.CollectionUtils
- sortAndDedup(BytesRefArray, int[]) - Static method in class org.elasticsearch.common.util.CollectionUtils
- SortAndFormats - Class in org.elasticsearch.search.sort
- SortAndFormats(Sort, DocValueFormat[]) - Constructor for class org.elasticsearch.search.sort.SortAndFormats
- SortBuilder<T extends SortBuilder<T>> - Class in org.elasticsearch.search.sort
- SortBuilder() - Constructor for class org.elasticsearch.search.sort.SortBuilder
- SortBuilders - Class in org.elasticsearch.search.sort
-
A set of static factory methods for
SortBuilder
s. - SortBuilders() - Constructor for class org.elasticsearch.search.sort.SortBuilders
- sortBundles(Set<PluginsService.Bundle>) - Static method in class org.elasticsearch.plugins.PluginsService
-
Return the given bundles, sorted in dependency loading order.
- SortBy - Enum Class in org.elasticsearch.search.suggest
-
An enum representing the valid sorting options
- sortComparator() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- sortComparator() - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- SortedBinaryDocValues - Class in org.elasticsearch.index.fielddata
-
A list of per-document binary values, sorted according to
BytesRef.compareTo(BytesRef)
. - SortedBinaryDocValues() - Constructor for class org.elasticsearch.index.fielddata.SortedBinaryDocValues
- sortedDifference(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, returned as a sorted set.
- SortedNumericDoubleValues - Class in org.elasticsearch.index.fielddata
-
Clone of
SortedNumericDocValues
for double values. - SortedNumericDoubleValues() - Constructor for class org.elasticsearch.index.fielddata.SortedNumericDoubleValues
-
Sole constructor.
- SortedNumericIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
-
FieldData backed by
LeafReader.getSortedNumericDocValues(String)
- SortedNumericIndexFieldData(String, IndexNumericFieldData.NumericType) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData
- SortedNumericIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
- SortedNumericIndexFieldData.NanoSecondFieldData - Class in org.elasticsearch.index.fielddata.plain
-
A small helper class that can be configured to load nanosecond field data either in nanosecond resolution retaining the original values or in millisecond resolution converting the nanosecond values to milliseconds
- SortedSetBytesLeafFieldData - Class in org.elasticsearch.index.fielddata.plain
-
An
LeafFieldData
implementation that uses LuceneSortedSetDocValues
. - SortedSetOrdinalsIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- SortedSetOrdinalsIndexFieldData(IndexFieldDataCache, String, ValuesSourceType, CircuitBreakerService, Function<SortedSetDocValues, ScriptDocValues<?>>) - Constructor for class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData
- SortedSetOrdinalsIndexFieldData.Builder - Class in org.elasticsearch.index.fielddata.plain
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.BinaryScriptFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.GeoPointScriptFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in interface org.elasticsearch.index.fielddata.IndexFieldData
-
Returns the
SortField
to use for sorting. - sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.IndexNumericFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData.Consumer
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.ConstantIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.PagedBytesIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.plain.StringBinaryIndexFieldData
- sortField(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldData
- sortField(IndexNumericFieldData.NumericType, Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested, boolean) - Method in class org.elasticsearch.index.fielddata.IndexNumericFieldData
-
Returns the
SortField
to used for sorting. - SortFieldAndFormat - Class in org.elasticsearch.search.sort
- SortFieldAndFormat(SortField, DocValueFormat) - Constructor for class org.elasticsearch.search.sort.SortFieldAndFormat
- SortingBinaryDocValues - Class in org.elasticsearch.index.fielddata
-
Base class for building
SortedBinaryDocValues
instances based on unsorted content. - SortingBinaryDocValues() - Constructor for class org.elasticsearch.index.fielddata.SortingBinaryDocValues
- SortingNumericDocValues - Class in org.elasticsearch.index.fielddata
-
Base class for building
SortedNumericDocValues
instances based on unsorted content. - SortingNumericDocValues() - Constructor for class org.elasticsearch.index.fielddata.SortingNumericDocValues
- SortingNumericDocValues(LongConsumer) - Constructor for class org.elasticsearch.index.fielddata.SortingNumericDocValues
- SortingNumericDoubleValues - Class in org.elasticsearch.index.fielddata
-
Base class for building
SortedNumericDoubleValues
instances based on unsorted content. - SortingNumericDoubleValues() - Constructor for class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
- sortMissingFirst(Object) - Static method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
-
Whether missing values should be sorted first.
- sortMissingLast(Object) - Static method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
-
Whether missing values should be sorted last, this is the default.
- sortMode - Variable in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- sortMode() - Method in class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- sortMode() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Returns what values to pick in the case a document contains multiple values for the targeted sort field.
- sortMode() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns which distance to use for sorting in the case a document contains multiple geo points.
- sortMode() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Get the sort mode.
- sortMode(SortMode) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Defines what values to pick in the case a document contains multiple values for the targeted sort field.
- sortMode(SortMode) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Defines which distance to use for sorting in the case a document contains multiple geo points.
- sortMode(SortMode) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Defines which distance to use for sorting in the case a document contains multiple values.
ForScriptSortBuilder.ScriptSortType.STRING
, the set of possible values is restricted toSortMode.MIN
andSortMode.MAX
- SortMode - Enum Class in org.elasticsearch.search.sort
-
Elasticsearch supports sorting by array or multi-valued fields.
- SORTMODE_FIELD - Static variable in class org.elasticsearch.search.sort.ScriptSortBuilder
- sortNodeDecisions(List<NodeAllocationResult>) - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
-
Sorts a list of node level decisions by the decision type, then by weight ranking, and finally by node id.
- sortOrder() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- sortOrder(HotThreads.SortOrder) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- sortOrder(HotThreads.SortOrder) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- SortOrder - Enum Class in org.elasticsearch.search.sort
-
A sorting order.
- sortRequiresCustomComparator() - Method in class org.elasticsearch.index.fielddata.BooleanScriptFieldData
- sortRequiresCustomComparator() - Method in class org.elasticsearch.index.fielddata.DateScriptFieldData
- sortRequiresCustomComparator() - Method in class org.elasticsearch.index.fielddata.DoubleScriptFieldData
- sortRequiresCustomComparator() - Method in class org.elasticsearch.index.fielddata.IndexNumericFieldData
-
Does
IndexNumericFieldData.sortField(org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType, java.lang.Object, org.elasticsearch.search.MultiValueMode, org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource.Nested, boolean)
require a custom comparator because of the way the data is stored in doc values (true
) or are the docs values stored such that they can be sorted without decoding (false
). - sortRequiresCustomComparator() - Method in class org.elasticsearch.index.fielddata.LongScriptFieldData
- sortRequiresCustomComparator() - Method in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData
- sorts() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Gets the bytes representing the sort builders for this request.
- sorts() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the sort builders for this request.
- sorts(List<SortBuilder<?>>) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Adds a sort builder.
- sortValue(String) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- sortValue(String) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Get value to use when sorting by this aggregation.
- sortValue(String) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
- sortValue(String) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.SingleValue
- sortValue(AggregationPath.PathElement, Iterator<AggregationPath.PathElement>) - Method in class org.elasticsearch.search.aggregations.bucket.InternalSingleBucketAggregation
- sortValue(AggregationPath.PathElement, Iterator<AggregationPath.PathElement>) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Get value to use when sorting by a descendant of this aggregation.
- sortValue(AggregationPath.PathElement, Iterator<AggregationPath.PathElement>) - Method in class org.elasticsearch.search.aggregations.InternalAggregations
-
Get value to use when sorting by a descendant of the aggregation containing this.
- sortValue(AggregationPath.PathElement, Iterator<AggregationPath.PathElement>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalMultiValueAggregation
- sortValue(AggregationPath.PathElement, Iterator<AggregationPath.PathElement>) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation
- SortValue - Class in org.elasticsearch.search.sort
-
A
Comparable
,DocValueFormat
aware wrapper around a sort value. - sortValueFormats() - Method in class org.elasticsearch.search.query.QuerySearchResult
- sortValues(Object[], DocValueFormat[]) - Method in class org.elasticsearch.search.SearchHit
- sortValues(SearchSortValues) - Method in class org.elasticsearch.search.SearchHit
- source - Variable in class org.elasticsearch.cluster.service.SourcePrioritizedRunnable
- source - Variable in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- source - Variable in class org.elasticsearch.index.translog.Translog.Source
- source() - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
- source() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- source() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
- source() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The mapping source definition.
- source() - Method in class org.elasticsearch.action.index.IndexRequest
-
The source of the document to index, recopied to a new array if it is unsafe.
- source() - Method in class org.elasticsearch.action.search.SearchRequest
-
The search source to execute.
- source() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
The source that caused this cluster event to be raised.
- source() - Method in class org.elasticsearch.cluster.metadata.MappingMetadata
- source() - Method in class org.elasticsearch.cluster.service.SourcePrioritizedRunnable
- source() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- source() - Method in class org.elasticsearch.index.engine.Engine.Index
- source() - Method in class org.elasticsearch.index.engine.Engine.Searcher
-
The source that caused this searcher to be acquired.
- source() - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- source() - Method in class org.elasticsearch.index.get.GetResult
-
The source of the document if exists.
- source() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- source() - Method in class org.elasticsearch.index.mapper.SourceToParse
- source() - Method in class org.elasticsearch.index.query.WrapperQueryBuilder
- source() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
The search used to find documents to process.
- source() - Method in class org.elasticsearch.index.seqno.RetentionLease
-
The source of this retention lease.
- source() - Method in class org.elasticsearch.index.translog.Translog.Index
- source() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- source() - Method in class org.elasticsearch.search.internal.SearchContext
- source() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- source() - Method in class org.elasticsearch.search.lookup.LeafSearchLookup
- source() - Method in class org.elasticsearch.search.lookup.SearchLookup
- source() - Method in class org.elasticsearch.search.lookup.SourceLookup
-
Return the source as a map that will be unchanged when the lookup moves to a different document.
- source(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the document to index in bytes form (assumed to be safe to be used from different threads).
- source(byte[], XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(byte[], XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(byte[], XContentType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the document to index in bytes form.
- source(Object...) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
A specialized simplified mapping source method, takes the form of simple properties definition: ("field1", "type=string,store=true").
- source(Object...) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the content source to index using the default content type (
Requests.INDEX_CONTENT_TYPE
) - source(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
- source(String...) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Set the source indices.
- source(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The mapping source definition.
- source(String, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(String, XContentType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the document source to index.
- source(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The mapping source definition.
- source(Map<String, ?>) - Method in class org.elasticsearch.action.index.IndexRequest
-
Index the Map in
Requests.INDEX_CONTENT_TYPE
format - source(Map<String, ?>, DeprecationHandler) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(Map<String, ?>, XContentType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Index the Map as the provided content type.
- source(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Parses repository definition.
- source(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Parses snapshot definition.
- source(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Parses restore definition
- source(Map<String, Object>) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The mapping source definition.
- source(BytesReference, XContentType) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(BytesReference, XContentType) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the document to index in bytes form.
- source(SearchSourceBuilder) - Method in class org.elasticsearch.action.search.SearchRequest
-
The source of the search request.
- source(SearchSourceBuilder) - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- source(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the settings and mappings as a single source.
- source(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The mapping source definition.
- source(XContentBuilder) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
-
The template source definition.
- source(XContentBuilder) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the content source to index.
- source(XContentType, Object...) - Method in class org.elasticsearch.action.index.IndexRequest
-
Sets the content source to index.
- Source(BytesReference, String) - Constructor for class org.elasticsearch.index.translog.Translog.Source
- SOURCE - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- SOURCE_PARSE_FIELD - Static variable in class org.elasticsearch.script.Script
-
Standard
ParseField
for source on the inner level. - SOURCE_PARSE_FIELD - Static variable in class org.elasticsearch.script.StoredScriptSource
-
Standard
ParseField
for source on the inner level. - sourceAsMap() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetadata
-
Returns the mappings as a map.
- sourceAsMap() - Method in class org.elasticsearch.action.index.IndexRequest
- sourceAsMap() - Method in class org.elasticsearch.cluster.metadata.MappingMetadata
-
Converts the serialized compressed form of the mappings into a parsed map.
- sourceAsMap() - Method in class org.elasticsearch.index.get.GetResult
-
The source of the document (As a map).
- sourceAsMap(BytesReference) - Static method in class org.elasticsearch.search.lookup.SourceLookup
-
Get the source as a
Map
of java objects. - sourceAsString() - Method in class org.elasticsearch.index.get.GetResult
-
The source of the document (as a string).
- sourceContentType() - Method in class org.elasticsearch.search.lookup.SourceLookup
- SourceFieldMapper - Class in org.elasticsearch.index.mapper
- SourceFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- SourceFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- sourceFieldNames(List<String>) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
-
Selects the fields to load from _source JSON and analyze.
- sourceIndexName - Variable in class org.elasticsearch.action.admin.indices.rollover.MetadataRolloverService.RolloverResult
- sourceLookup - Variable in class org.elasticsearch.script.AbstractFieldScript
- sourceLookup() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
-
This lookup provides access to the source for the given hit document.
- SourceLookup - Class in org.elasticsearch.search.lookup
- SourceLookup() - Constructor for class org.elasticsearch.search.lookup.SourceLookup
- sourceMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- sourceMetaSnapshot() - Method in class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- sourceNode - Variable in class org.elasticsearch.cluster.coordination.ApplyCommitRequest
- sourceNode - Variable in class org.elasticsearch.discovery.zen.MasterFaultDetection.MasterPingRequest
- sourceNode() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- sourceNode() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- sourceOnly(String) - Static method in class org.elasticsearch.index.mapper.BooleanScriptFieldType
- sourceOnly(String) - Static method in class org.elasticsearch.index.mapper.DoubleScriptFieldType
- sourceOnly(String) - Static method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- sourceOnly(String) - Static method in class org.elasticsearch.index.mapper.LongScriptFieldType
- sourceOnly(String, DateFormatter) - Static method in class org.elasticsearch.index.mapper.DateScriptFieldType
- sourcePath(String) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- sourcePaths(String) - Method in class org.elasticsearch.index.mapper.MappingLookup
-
Given a concrete field name, return its paths in the _source.
- SourcePrioritizedRunnable - Class in org.elasticsearch.cluster.service
-
PrioritizedRunnable that also has a source string
- SourcePrioritizedRunnable(Priority, String) - Constructor for class org.elasticsearch.cluster.service.SourcePrioritizedRunnable
- SourceProvider - Class in org.elasticsearch.common.inject.internal
-
Provides access to the calling line of code.
- SourceProvider() - Constructor for class org.elasticsearch.common.inject.internal.SourceProvider
- sourceRef() - Method in class org.elasticsearch.index.get.GetResult
-
Returns bytes reference, also un compress the source if needed.
- sourceRef(BytesReference) - Method in class org.elasticsearch.search.SearchHit
-
Sets representation, might be compressed....
- sourceRequested() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- sourceRequested() - Method in class org.elasticsearch.search.internal.SearchContext
-
A shortcut function to see whether there is a fetchSourceContext and it says the source is requested.
- sourceRequested() - Method in class org.elasticsearch.search.internal.SubSearchContext
- sources() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
-
Gets the list of
CompositeValuesSourceBuilder
for this aggregation. - SOURCES_FIELD_NAME - Static variable in class org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregationBuilder
- SourceScoreOrderFragmentsBuilder - Class in org.elasticsearch.search.fetch.subphase.highlight
- SourceScoreOrderFragmentsBuilder(MappedFieldType, SearchExecutionContext, boolean, SourceLookup, String[], String[], BoundaryScanner) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.SourceScoreOrderFragmentsBuilder
- SourceSimpleFragmentsBuilder - Class in org.elasticsearch.search.fetch.subphase.highlight
- SourceSimpleFragmentsBuilder(MappedFieldType, SearchExecutionContext, boolean, SourceLookup, String[], String[], BoundaryScanner) - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.SourceSimpleFragmentsBuilder
- sourceThrottleTimeInNanos() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- sourceThrottling() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- sourceToParse() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- SourceToParse - Class in org.elasticsearch.index.mapper
- SourceToParse(String, String, String, BytesReference, XContentType) - Constructor for class org.elasticsearch.index.mapper.SourceToParse
- SourceToParse(String, String, String, BytesReference, XContentType, String, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.SourceToParse
- SourceToParse.Origin - Enum Class in org.elasticsearch.index.mapper
- SourceValueFetcher - Class in org.elasticsearch.index.mapper
-
An implementation of
ValueFetcher
that knows how to extract values from the document source. - SourceValueFetcher(String, SearchExecutionContext) - Constructor for class org.elasticsearch.index.mapper.SourceValueFetcher
- SourceValueFetcher(String, SearchExecutionContext, Object) - Constructor for class org.elasticsearch.index.mapper.SourceValueFetcher
- SourceValueFetcher(Set<String>, Object) - Constructor for class org.elasticsearch.index.mapper.SourceValueFetcher
- SPACE - Static variable in class org.elasticsearch.common.logging.Loggers
- spaceify(int, String, StringBuilder) - Static method in class org.elasticsearch.common.Strings
- SpanBooleanQueryRewriteWithMaxClause - Class in org.elasticsearch.common.lucene.search
-
A span rewrite method that extracts the first
maxExpansions
terms that match theMultiTermQuery
in the terms dictionary. - SpanBooleanQueryRewriteWithMaxClause() - Constructor for class org.elasticsearch.common.lucene.search.SpanBooleanQueryRewriteWithMaxClause
- SpanBooleanQueryRewriteWithMaxClause(int, boolean) - Constructor for class org.elasticsearch.common.lucene.search.SpanBooleanQueryRewriteWithMaxClause
- spanContainingQuery(SpanQueryBuilder, SpanQueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a new
span_containing
builder. - SpanContainingQueryBuilder - Class in org.elasticsearch.index.query
-
Builder for
SpanContainingQuery
. - SpanContainingQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanContainingQueryBuilder
-
Read from a stream.
- SpanContainingQueryBuilder(SpanQueryBuilder, SpanQueryBuilder) - Constructor for class org.elasticsearch.index.query.SpanContainingQueryBuilder
- spanFirstQuery(SpanQueryBuilder, int) - Static method in class org.elasticsearch.index.query.QueryBuilders
- SpanFirstQueryBuilder - Class in org.elasticsearch.index.query
- SpanFirstQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanFirstQueryBuilder
-
Read from a stream.
- SpanFirstQueryBuilder(SpanQueryBuilder, int) - Constructor for class org.elasticsearch.index.query.SpanFirstQueryBuilder
-
Query that matches spans queries defined in
matchBuilder
whose end position is less than or equal toend
. - SpanGapQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
-
Constructs a new SpanGapQueryBuilder term query.
- SpanGapQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
-
Read from a stream.
- SpanMatchNoDocsQuery - Class in org.apache.lucene.queries
-
A
SpanQuery
that matches no documents. - SpanMatchNoDocsQuery(String, String) - Constructor for class org.apache.lucene.queries.SpanMatchNoDocsQuery
- spanMultiTermQueryBuilder(MultiTermQueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a
SpanQueryBuilder
which allows having a sub query which implementsMultiTermQueryBuilder
. - SpanMultiTermQueryBuilder - Class in org.elasticsearch.index.query
-
Query that allows wrapping a
MultiTermQueryBuilder
(one of wildcard, fuzzy, prefix, term, range or regexp query) as aSpanQueryBuilder
so it can be nested. - SpanMultiTermQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
-
Read from a stream.
- SpanMultiTermQueryBuilder(MultiTermQueryBuilder) - Constructor for class org.elasticsearch.index.query.SpanMultiTermQueryBuilder
- spanNearQuery(SpanQueryBuilder, int) - Static method in class org.elasticsearch.index.query.QueryBuilders
- SpanNearQueryBuilder - Class in org.elasticsearch.index.query
-
Matches spans which are near one another.
- SpanNearQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanNearQueryBuilder
-
Read from a stream.
- SpanNearQueryBuilder(SpanQueryBuilder, int) - Constructor for class org.elasticsearch.index.query.SpanNearQueryBuilder
- SpanNearQueryBuilder.SpanGapQueryBuilder - Class in org.elasticsearch.index.query
-
SpanGapQueryBuilder enables gaps in a SpanNearQuery.
- spanNotQuery(SpanQueryBuilder, SpanQueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
- SpanNotQueryBuilder - Class in org.elasticsearch.index.query
- SpanNotQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanNotQueryBuilder
-
Read from a stream.
- SpanNotQueryBuilder(SpanQueryBuilder, SpanQueryBuilder) - Constructor for class org.elasticsearch.index.query.SpanNotQueryBuilder
-
Construct a span query matching spans from
include
which have no overlap with spans fromexclude
. - spanOrQuery(SpanQueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
- SpanOrQueryBuilder - Class in org.elasticsearch.index.query
-
Span query that matches the union of its clauses.
- SpanOrQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanOrQueryBuilder
-
Read from a stream.
- SpanOrQueryBuilder(SpanQueryBuilder) - Constructor for class org.elasticsearch.index.query.SpanOrQueryBuilder
- spanPrefixQuery(String, SpanMultiTermQueryWrapper.SpanRewriteMethod, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- spanPrefixQuery(String, SpanMultiTermQueryWrapper.SpanRewriteMethod, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- spanPrefixQuery(String, SpanMultiTermQueryWrapper.SpanRewriteMethod, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- SpanQueryBuilder - Interface in org.elasticsearch.index.query
-
Marker interface for a specific type of
QueryBuilder
that allows to build span queries. - SpanQueryBuilder.SpanQueryBuilderUtil - Class in org.elasticsearch.index.query
- spanRewriteMethod - Variable in class org.elasticsearch.index.search.MatchQueryParser
- spanTermQuery(String, double) - Static method in class org.elasticsearch.index.query.QueryBuilders
- spanTermQuery(String, float) - Static method in class org.elasticsearch.index.query.QueryBuilders
- spanTermQuery(String, int) - Static method in class org.elasticsearch.index.query.QueryBuilders
- spanTermQuery(String, long) - Static method in class org.elasticsearch.index.query.QueryBuilders
- spanTermQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
- SpanTermQueryBuilder - Class in org.elasticsearch.index.query
-
A Span Query that matches documents containing a term.
- SpanTermQueryBuilder(String, double) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
- SpanTermQueryBuilder(String, float) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
- SpanTermQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
- SpanTermQueryBuilder(String, long) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
- SpanTermQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
- SpanTermQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
- SpanTermQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanTermQueryBuilder
-
Read from a stream.
- spanWithinQuery(SpanQueryBuilder, SpanQueryBuilder) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Creates a new
span_within
builder. - SpanWithinQueryBuilder - Class in org.elasticsearch.index.query
-
Builder for
SpanWithinQuery
. - SpanWithinQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.SpanWithinQueryBuilder
-
Read from a stream.
- SpanWithinQueryBuilder(SpanQueryBuilder, SpanQueryBuilder) - Constructor for class org.elasticsearch.index.query.SpanWithinQueryBuilder
-
Query that returns spans from
little
that are contained in a spans frombig
. - spare - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- SpatialStrategy - Enum Class in org.elasticsearch.common.geo
- SpecialPermission - Class in org.elasticsearch
-
Elasticsearch-specific permission to check before entering
AccessController.doPrivileged()
blocks. - SpecialPermission() - Constructor for class org.elasticsearch.SpecialPermission
-
Creates a new SpecialPermission object.
- SpecialPermission(String, String) - Constructor for class org.elasticsearch.SpecialPermission
-
Creates a new SpecialPermission object.
- SphericalMercatorUtils - Class in org.elasticsearch.common.geo
-
Utility functions to transforms WGS84 coordinates into spherical mercator.
- spiUrls - Variable in class org.elasticsearch.plugins.PluginsService.Bundle
- split(String, String) - Static method in class org.elasticsearch.common.Strings
-
Split a String at the first occurrence of the delimiter.
- SPLIT - Enum constant in enum class org.elasticsearch.action.admin.indices.shrink.ResizeType
- splitCombinedPatterns(String) - Static method in interface org.elasticsearch.common.time.DateFormatter
- splitSmart(String, String, boolean) - Static method in class org.elasticsearch.common.Strings
-
Splits a backslash escaped string on the separator.
- splitStringByCommaToArray(String) - Static method in class org.elasticsearch.common.Strings
-
Split the specified string by commas to an array.
- SQRT - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- SQUARE - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- stack - Variable in class org.elasticsearch.search.profile.AbstractInternalProfileTree
-
A temporary stack used to record where we are in the dependency tree.
- STACK_TRACE - Static variable in exception org.elasticsearch.ElasticsearchException
- stackTrace(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
- StackTraceElements - Class in org.elasticsearch.common.inject.internal
-
Creates stack trace elements for members.
- StackTraceElements() - Constructor for class org.elasticsearch.common.inject.internal.StackTraceElements
- Stage - Enum Class in org.elasticsearch.common.inject
-
The stage we're running in.
- STALE_STATE_CONFIG_NODE_ID - Static variable in class org.elasticsearch.gateway.GatewayMetaState
-
Fake node ID for a voting configuration written by a master-ineligible data node to indicate that its on-disk state is potentially stale (since it is written asynchronously after application, rather than before acceptance).
- StaleShard - Class in org.elasticsearch.cluster.routing.allocation
-
A class that represents a stale shard copy.
- StaleShard(ShardId, String) - Constructor for class org.elasticsearch.cluster.routing.allocation.StaleShard
- STALLED - Enum constant in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Status
- STANDARD - Enum constant in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- STANDARD - Enum constant in enum class org.elasticsearch.indices.analysis.PreBuiltTokenizers
- STANDARD - Static variable in class org.elasticsearch.script.ClassPermission
- STANDARD_ANALYZER - Static variable in class org.elasticsearch.common.lucene.Lucene
- STANDARD_CLASSES - Static variable in class org.elasticsearch.script.ClassPermission
-
Typical set of classes for scripting: basic data types, math, dates, and simple collections
- StandardAnalyzerProvider - Class in org.elasticsearch.index.analysis
- StandardAnalyzerProvider(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StandardAnalyzerProvider
- StandardTokenizerFactory - Class in org.elasticsearch.index.analysis
- StandardTokenizerFactory(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StandardTokenizerFactory
- start - Variable in class org.elasticsearch.script.ScriptException.Position
- start() - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.AsyncAction
- start() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction.AsyncBroadcastAction
- start() - Method in class org.elasticsearch.cluster.coordination.ClusterFormationFailureHelper
- start() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
- start() - Method in interface org.elasticsearch.common.component.LifecycleComponent
- start() - Method in class org.elasticsearch.common.StopWatch
-
Start an unnamed task.
- start() - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
- start() - Method in interface org.elasticsearch.discovery.zen.ZenPing
- start() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource
- start() - Method in class org.elasticsearch.indices.recovery.MultiChunkTransfer
- start() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- start() - Method in class org.elasticsearch.node.Node
-
Start the node.
- start() - Method in class org.elasticsearch.repositories.FilterRepository
- start() - Method in class org.elasticsearch.search.profile.Timer
-
Start the timer.
- start(String) - Method in class org.elasticsearch.common.StopWatch
-
Start a named task.
- start(Set<DiscoveryNode>) - Method in class org.elasticsearch.cluster.coordination.Publication
- start(ClusterState, Iterable<DiscoveryNode>) - Method in class org.elasticsearch.cluster.coordination.PreVoteCollector
-
Start a new pre-voting round.
- start(Settings, TransportService, ClusterService, MetaStateService, IndexMetadataVerifier, MetadataUpgrader, PersistedClusterStateService) - Method in class org.elasticsearch.gateway.GatewayMetaState
- START_JOIN_ACTION_NAME - Static variable in class org.elasticsearch.cluster.coordination.JoinHelper
- START_RECOVERY - Static variable in class org.elasticsearch.indices.recovery.PeerRecoverySourceService.Actions
- START_TIME - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.SortBy
- startBanOnChildTasks(long, String, Runnable) - Method in class org.elasticsearch.tasks.TaskManager
-
Start rejecting new child requests as the parent task was cancelled.
- startClone(Snapshot, SnapshotId, Map<String, IndexId>, long, long, Version) - Static method in class org.elasticsearch.cluster.SnapshotsInProgress
-
Creates the initial snapshot clone entry
- startConstruction() - Method in class org.elasticsearch.common.inject.internal.ConstructionContext
- started() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard is in started mode.
- started() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- started() - Method in class org.elasticsearch.common.component.Lifecycle
-
Returns
true
if the state is started. - STARTED - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Index files are being copied
- STARTED - Enum constant in enum class org.elasticsearch.cluster.RestoreInProgress.State
-
Started state
- STARTED - Enum constant in enum class org.elasticsearch.cluster.routing.ShardRoutingState
-
The shard is started.
- STARTED - Enum constant in enum class org.elasticsearch.cluster.SnapshotDeletionsInProgress.State
-
Delete is physically executing on the repository.
- STARTED - Enum constant in enum class org.elasticsearch.cluster.SnapshotsInProgress.State
- STARTED - Enum constant in enum class org.elasticsearch.common.component.Lifecycle.State
- STARTED - Enum constant in enum class org.elasticsearch.index.shard.IndexShardState
- STARTED - Enum constant in enum class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Index files are being copied
- STARTED - Enum constant in enum class org.elasticsearch.persistent.AllocatedPersistentTask.State
- STARTED_AT_MILLIS_FIELD - Static variable in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- STARTED_AT_READABLE_FIELD - Static variable in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- startedAt - Variable in class org.elasticsearch.repositories.RepositoryInfo
- startedEntry(String, long) - Static method in class org.elasticsearch.cluster.RepositoryCleanupInProgress
- startedEntry(Snapshot, boolean, boolean, Map<String, IndexId>, List<String>, long, long, ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>, Map<String, Object>, Version, List<SnapshotFeatureInfo>) - Static method in class org.elasticsearch.cluster.SnapshotsInProgress
-
Creates the initial
SnapshotsInProgress.Entry
when starting a snapshot, if no shard-level snapshot work is to be done the resulting entry will be in stateSnapshotsInProgress.State.SUCCESS
right away otherwise it will be in stateSnapshotsInProgress.State.STARTED
. - StartedShardEntry(ShardId, String, long, String, ShardLongFieldRange) - Constructor for class org.elasticsearch.cluster.action.shard.ShardStateAction.StartedShardEntry
- startElectionContext() - Method in class org.elasticsearch.discovery.zen.NodeJoinController
-
Accumulates any future incoming join request.
- startElectionScheduler(TimeValue, Runnable) - Method in class org.elasticsearch.cluster.coordination.ElectionSchedulerFactory
-
Start the process to schedule repeated election attempts.
- startHeaders() - Method in class org.elasticsearch.common.Table
- startHeadersWithTimestamp() - Method in class org.elasticsearch.common.Table
- startingSeqNo() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- startInitialJoin() - Method in class org.elasticsearch.cluster.coordination.Coordinator
- startInitialJoin() - Method in interface org.elasticsearch.discovery.Discovery
-
Triggers the first join cycle
- startInitialJoin() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- StartJoinRequest - Class in org.elasticsearch.cluster.coordination
-
Represents the action of requesting a join vote (see
Join
) from a node. - StartJoinRequest(DiscoveryNode, long) - Constructor for class org.elasticsearch.cluster.coordination.StartJoinRequest
- StartJoinRequest(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.StartJoinRequest
- startLagDetector(long) - Method in class org.elasticsearch.cluster.coordination.LagDetector
- startLoadingStoredFields() - Method in class org.elasticsearch.search.fetch.FetchProfiler
- startNanoTime - Variable in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- startNewSequence() - Method in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
-
Reset the sequence detection logic to avoid any continuation of the immediately previous bytes.
- startNextReader() - Method in class org.elasticsearch.search.fetch.FetchProfiler
- startNextScroll(TimeValue) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource
- StartPersistentTaskAction - Class in org.elasticsearch.persistent
-
This action can be used to add the record for the persistent action to the cluster state.
- StartPersistentTaskAction.Request - Class in org.elasticsearch.persistent
- StartPersistentTaskAction.RequestBuilder - Class in org.elasticsearch.persistent
- StartPersistentTaskAction.TransportAction - Class in org.elasticsearch.persistent
- startProbe(TransportAddress) - Method in class org.elasticsearch.discovery.PeerFinder
- startProfilingFetchPhase() - Method in class org.elasticsearch.search.profile.Profilers
-
Build a profiler for the fetch phase.
- startRecovery(IndexShard, DiscoveryNode, PeerRecoveryTargetService.RecoveryListener) - Method in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService
- startRecovery(IndexShard, DiscoveryNode, SnapshotFilesProvider, PeerRecoveryTargetService.RecoveryListener, TimeValue, Releasable) - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection
-
Starts are new recovery for the given shard, source node and state
- startRecovery(RecoveryState, PeerRecoveryTargetService, PeerRecoveryTargetService.RecoveryListener, RepositoriesService, BiConsumer<String, MappingMetadata>, IndicesService) - Method in class org.elasticsearch.index.shard.IndexShard
- StartRecoveryRequest - Class in org.elasticsearch.indices.recovery
-
Represents a request for starting a peer recovery.
- StartRecoveryRequest(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.StartRecoveryRequest
- StartRecoveryRequest(ShardId, String, DiscoveryNode, DiscoveryNode, Store.MetadataSnapshot, boolean, long, long, boolean) - Constructor for class org.elasticsearch.indices.recovery.StartRecoveryRequest
-
Construct a request for starting a peer recovery.
- startRelocationHandoff(String) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Initiates a relocation handoff and returns the corresponding primary context.
- startRewriteTime() - Method in class org.elasticsearch.search.profile.query.QueryProfiler
-
Begin timing the rewrite phase of a request.
- startRow() - Method in class org.elasticsearch.common.Table
- startShard(Logger, ShardRouting, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
-
Applies the relevant logic to start an initializing shard.
- startTime - Variable in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- startTime() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- startTime() - Method in class org.elasticsearch.index.engine.Engine.Operation
-
Returns operation start time in nanoseconds.
- startTime() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns snapshot start time
- startTime() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
-
Returns start time in millis
- startTime() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns time when snapshot started; a value of
0L
will be returned ifSnapshotInfo.state()
returnsnull
. - startTrackingCancellableChannelTask(TcpChannel, CancellableTask) - Method in class org.elasticsearch.tasks.TaskManager
-
Start tracking a cancellable task with its tcp channel, so if the channel gets closed we can get a set of pending tasks associated that channel and cancel them as these results won't be retrieved by the parent task.
- startUtcMillis() - Method in class org.elasticsearch.common.LocalTimeOffset.Transition
-
The time that this offset started in milliseconds since epoch.
- startVerification() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- startVerification() - Method in class org.elasticsearch.repositories.FilterRepository
- startVerification() - Method in interface org.elasticsearch.repositories.Repository
-
Verifies repository on the master node and returns the verification token.
- stashAndMergeHeaders(Map<String, String>) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Removes the current context and resets a new context that contains a merge of the current headers and the given headers.
- stashContext() - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Removes the current context and resets a default context.
- stashWithOrigin(String) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Removes the current context and resets a default context marked with as originating from the supplied string.
- state - Variable in class org.elasticsearch.index.shard.IndexShard
- state - Variable in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- state - Variable in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- state() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
-
The new cluster state that caused this change event.
- state() - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
-
Returns current restore state
- state() - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Returns current state
- state() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard state.
- state() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
-
The current cluster state.
- state() - Method in class org.elasticsearch.cluster.service.ClusterService
-
The currently applied cluster state.
- state() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- state() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- state() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- state() - Method in class org.elasticsearch.common.component.Lifecycle
- state() - Method in class org.elasticsearch.index.shard.IndexShard
- state() - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.Shard
-
Returns the latest internal shard state.
- state() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- state() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns snapshot state;
null
if the state is unknown. - state(ClusterStateRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
The state of the cluster.
- state(ClusterStateRequest, ActionListener<ClusterStateResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
The state of the cluster.
- state(IndexMetadata.State) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- STATE - Enum constant in enum class org.elasticsearch.transport.TransportRequestOptions.Type
- STATE_DIR_NAME - Static variable in class org.elasticsearch.gateway.MetadataStateFormat
- STATE_FILE_EXTENSION - Static variable in class org.elasticsearch.gateway.MetadataStateFormat
- STATE_NOT_RECOVERED_BLOCK - Static variable in class org.elasticsearch.gateway.GatewayService
- statefulFactoryClazz - Variable in class org.elasticsearch.script.ScriptContext
-
A factory class for construct script instances.
- stateIdentifier() - Method in class org.elasticsearch.repositories.SnapshotShardContext
- stateUUID - Variable in class org.elasticsearch.discovery.zen.PublishClusterStateAction.CommitClusterStateRequest
- stateUUID() - Method in class org.elasticsearch.cluster.ClusterState
-
This stateUUID is automatically generated for for each version of cluster state.
- stateUUID(String) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- stateWithoutSnapshot(ClusterState, Snapshot) - Static method in class org.elasticsearch.snapshots.SnapshotsService
-
Computes the cluster state resulting from removing a given snapshot create operation from the given state.
- StaticInjectionRequest - Class in org.elasticsearch.common.inject.spi
-
A request to inject the static fields and methods of a type.
- stats() - Method in class org.elasticsearch.cluster.coordination.Coordinator
- stats() - Method in class org.elasticsearch.cluster.coordination.PublicationTransportHandler
- stats() - Method in interface org.elasticsearch.common.blobstore.BlobStore
-
Returns statistics on the count of operations that have been performed on this blob store
- stats() - Method in class org.elasticsearch.common.breaker.PreallocatedCircuitBreakerService
- stats() - Method in class org.elasticsearch.common.cache.Cache
-
The cache statistics tracking hits, misses and evictions.
- stats() - Method in interface org.elasticsearch.discovery.Discovery
- stats() - Method in class org.elasticsearch.discovery.zen.PendingClusterStatesQueue
- stats() - Method in class org.elasticsearch.discovery.zen.PublishClusterStateAction
- stats() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
- stats() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
- stats() - Method in interface org.elasticsearch.http.HttpServerTransport
- stats() - Method in class org.elasticsearch.index.cache.request.ShardRequestCache
- stats() - Method in class org.elasticsearch.index.get.ShardGetService
- stats() - Method in class org.elasticsearch.index.IndexingPressure
- stats() - Method in class org.elasticsearch.index.translog.Translog
-
return stats
- stats() - Method in class org.elasticsearch.index.warmer.ShardIndexWarmerService
- stats() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
- stats() - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- stats() - Method in class org.elasticsearch.indices.breaker.NoneCircuitBreakerService
- stats() - Method in class org.elasticsearch.ingest.IngestService
- stats() - Method in class org.elasticsearch.monitor.fs.FsService
- stats() - Method in class org.elasticsearch.monitor.jvm.JvmService
- stats() - Method in class org.elasticsearch.monitor.os.OsService
- stats() - Method in class org.elasticsearch.monitor.process.ProcessService
- stats() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- stats() - Method in interface org.elasticsearch.repositories.Repository
-
Returns stats on the repository usage
- stats() - Method in class org.elasticsearch.script.ScriptCache
- stats() - Method in class org.elasticsearch.script.ScriptMetrics
- stats() - Method in class org.elasticsearch.script.ScriptService
- stats() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
The stats groups this request will be aggregated under.
- stats() - Method in class org.elasticsearch.threadpool.ThreadPool
- stats() - Method in class org.elasticsearch.transport.TransportService
- stats(long, LongUnaryOperator) - Method in class org.elasticsearch.index.store.Store
- stats(String) - Method in class org.elasticsearch.common.breaker.PreallocatedCircuitBreakerService
- stats(String) - Method in class org.elasticsearch.indices.breaker.CircuitBreakerService
- stats(String) - Method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- stats(String) - Method in class org.elasticsearch.indices.breaker.NoneCircuitBreakerService
- stats(String) - Method in class org.elasticsearch.script.ScriptCache
- stats(String) - Method in class org.elasticsearch.script.ScriptMetrics
- stats(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Stats
aggregation with the given name. - stats(String...) - Method in class org.elasticsearch.index.fielddata.ShardFieldData
- stats(String...) - Method in class org.elasticsearch.index.search.stats.ShardFieldUsageTracker
-
Returns field usage stats for the given fields.
- stats(String...) - Method in class org.elasticsearch.index.search.stats.ShardSearchStats
-
Returns the stats, including group specific stats.
- stats(List<String>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
The stats groups this request will be aggregated under.
- stats(CommonStatsFlags) - Method in class org.elasticsearch.indices.IndicesService
- stats(CommonStatsFlags, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean) - Method in class org.elasticsearch.node.NodeService
- stats(IndicesStatsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices stats.
- stats(IndicesStatsRequest, ActionListener<IndicesStatsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Indices stats.
- stats(FsInfo) - Method in class org.elasticsearch.monitor.fs.FsProbe
- Stats - Interface in org.elasticsearch.search.aggregations.metrics
-
Statistics over a set of values (either aggregated over field data or scripts)
- Stats(long, long, long, long) - Constructor for class org.elasticsearch.ingest.IngestStats.Stats
- Stats(long, long, long, long, long, long, long, long, boolean, long) - Constructor for class org.elasticsearch.index.shard.IndexingStats.Stats
- Stats(long, long, long, long, long, long, long, long, long, long, long, long) - Constructor for class org.elasticsearch.index.search.stats.SearchStats.Stats
- Stats(long, long, ByteSizeValue, ByteSizeValue) - Constructor for class org.elasticsearch.action.admin.indices.rollover.Condition.Stats
- Stats(String, int, int, int, long, int, long) - Constructor for class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- Stats(Map<String, ClusterApplierRecordingService.Stats.Recording>) - Constructor for class org.elasticsearch.cluster.service.ClusterApplierRecordingService.Stats
- Stats(StreamInput) - Constructor for class org.elasticsearch.cluster.service.ClusterApplierRecordingService.Stats
- Stats(StreamInput) - Constructor for class org.elasticsearch.index.shard.IndexingStats.Stats
- Stats(StreamInput) - Constructor for class org.elasticsearch.ingest.IngestStats.Stats
-
Read from a stream.
- Stats(StreamInput) - Constructor for class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- STATS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- StatsAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- StatsAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- StatsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
-
Read from a stream.
- StatsAggregationBuilder(StatsAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.StatsAggregationBuilder
- statsBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- StatsBucket - Interface in org.elasticsearch.search.aggregations.pipeline
-
Statistics over a set of buckets
- StatsBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- StatsBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.StatsBucketPipelineAggregationBuilder
- StatsBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.StatsBucketPipelineAggregationBuilder
-
Read from a stream.
- StatsBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- StatsBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.StatsBucketPipelineAggregator
- statsSnapshot() - Method in class org.elasticsearch.repositories.blobstore.MeteredBlobStoreRepository
- statsSnapshotForArchival(long) - Method in class org.elasticsearch.repositories.blobstore.MeteredBlobStoreRepository
- StatsTracker - Class in org.elasticsearch.transport
- StatsTracker() - Constructor for class org.elasticsearch.transport.StatsTracker
- status - Variable in exception org.elasticsearch.action.ShardOperationFailedException
- status - Variable in class org.elasticsearch.transport.NetworkMessage
- status() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- status() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
-
Returns HTTP status
RestStatus.ACCEPTED
if snapshot is still in progressRestStatus.OK
if snapshot was successful or partially successfulRestStatus.INTERNAL_SERVER_ERROR
if snapshot failed completely - status() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- status() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeSnapshotStatus
- status() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptContextResponse
- status() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptLanguageResponse
- status() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- status() - Method in class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesResponse
- status() - Method in class org.elasticsearch.action.bulk.BulkItemResponse
- status() - Method in class org.elasticsearch.action.bulk.BulkResponse
- status() - Method in class org.elasticsearch.action.delete.DeleteResponse
- status() - Method in class org.elasticsearch.action.DocWriteResponse
-
returns the rest status for this response (based on
ReplicationResponse.ShardInfo.status()
- status() - Method in class org.elasticsearch.action.explain.ExplainResponse
- status() - Method in class org.elasticsearch.action.index.IndexResponse
- status() - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- status() - Method in exception org.elasticsearch.action.NoShardAvailableActionException
- status() - Method in exception org.elasticsearch.action.RoutingMissingException
- status() - Method in class org.elasticsearch.action.search.ClearScrollResponse
- status() - Method in class org.elasticsearch.action.search.ClosePointInTimeResponse
- status() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- status() - Method in class org.elasticsearch.action.search.SearchResponse
- status() - Method in exception org.elasticsearch.action.ShardOperationFailedException
-
The status of the failure.
- status() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- status() - Method in exception org.elasticsearch.action.UnavailableShardsException
- status() - Method in class org.elasticsearch.action.update.UpdateResponse
- status() - Method in exception org.elasticsearch.client.transport.NoNodeAvailableException
- status() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- status() - Method in exception org.elasticsearch.cluster.block.ClusterBlockException
- status() - Method in exception org.elasticsearch.cluster.metadata.ProcessClusterEventTimeoutException
- status() - Method in exception org.elasticsearch.common.breaker.CircuitBreakingException
- status() - Method in exception org.elasticsearch.common.io.stream.NotSerializableExceptionWrapper
- status() - Method in exception org.elasticsearch.common.ParsingException
- status() - Method in interface org.elasticsearch.common.xcontent.StatusToXContentObject
-
Returns the REST status to make sure it is returned correctly
- status() - Method in exception org.elasticsearch.discovery.MasterNotDiscoveredException
- status() - Method in exception org.elasticsearch.ElasticsearchException
-
Returns the rest status code associated with this exception.
- status() - Method in exception org.elasticsearch.ElasticsearchParseException
- status() - Method in exception org.elasticsearch.ElasticsearchStatusException
- status() - Method in exception org.elasticsearch.index.engine.DocumentMissingException
- status() - Method in exception org.elasticsearch.index.engine.DocumentSourceMissingException
- status() - Method in exception org.elasticsearch.index.engine.VersionConflictEngineException
- status() - Method in exception org.elasticsearch.index.mapper.MapperParsingException
- status() - Method in exception org.elasticsearch.index.mapper.StrictDynamicMappingException
- status() - Method in exception org.elasticsearch.index.query.QueryShardException
- status() - Method in exception org.elasticsearch.index.shard.IllegalIndexShardStateException
- status() - Method in exception org.elasticsearch.indices.IndexClosedException
- status() - Method in exception org.elasticsearch.indices.IndexPrimaryShardNotAllocatedException
- status() - Method in exception org.elasticsearch.indices.IndexTemplateMissingException
- status() - Method in exception org.elasticsearch.indices.InvalidAliasNameException
- status() - Method in exception org.elasticsearch.indices.InvalidIndexNameException
- status() - Method in exception org.elasticsearch.indices.InvalidIndexTemplateException
- status() - Method in exception org.elasticsearch.indices.InvalidTypeNameException
- status() - Method in exception org.elasticsearch.indices.TypeMissingException
- status() - Method in exception org.elasticsearch.repositories.RepositoryMissingException
- status() - Method in exception org.elasticsearch.repositories.RepositoryVerificationException
- status() - Method in class org.elasticsearch.repositories.SnapshotShardContext
- status() - Method in exception org.elasticsearch.ResourceAlreadyExistsException
- status() - Method in exception org.elasticsearch.ResourceNotFoundException
- status() - Method in class org.elasticsearch.rest.BytesRestResponse
- status() - Method in class org.elasticsearch.rest.RestResponse
-
The rest status code.
- status() - Method in exception org.elasticsearch.script.ScriptException
- status() - Method in exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
- status() - Method in exception org.elasticsearch.search.SearchContextMissingException
- status() - Method in exception org.elasticsearch.search.SearchParseException
- status() - Method in exception org.elasticsearch.snapshots.ConcurrentSnapshotExecutionException
- status() - Method in exception org.elasticsearch.snapshots.InvalidSnapshotNameException
- status() - Method in class org.elasticsearch.snapshots.RestoreInfo
-
REST status of the operation
- status() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns snapshot REST status
- status() - Method in exception org.elasticsearch.snapshots.SnapshotInProgressException
- status() - Method in exception org.elasticsearch.snapshots.SnapshotMissingException
- status() - Method in class org.elasticsearch.snapshots.UpdateIndexShardSnapshotStatusRequest
- status() - Method in exception org.elasticsearch.tasks.TaskCancelledException
- status() - Method in exception org.elasticsearch.transport.TcpTransport.HttpRequestOnTransportException
- status(int, int, ShardOperationFailedException...) - Static method in enum class org.elasticsearch.rest.RestStatus
- status(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
- Status(Integer, long, long, long, long, int, long, long, long, long, TimeValue, float, String, TimeValue) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- Status(String) - Constructor for class org.elasticsearch.action.support.replication.ReplicationTask.Status
- Status(String, int, int, int) - Constructor for class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- Status(List<BulkByScrollTask.StatusOrException>, String) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.Status
-
Constructor merging many statuses.
- Status(StreamInput) - Constructor for class org.elasticsearch.action.support.replication.ReplicationTask.Status
- Status(StreamInput) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- Status(StreamInput) - Constructor for class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- Status(StreamInput) - Constructor for class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- Status(AllocatedPersistentTask.State) - Constructor for class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- STATUS_FIELD - Static variable in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- STATUS_FIELD - Static variable in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- STATUS_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- StatusBuilder() - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.StatusBuilder
- StatusInfo - Class in org.elasticsearch.monitor
-
Class that represents the Health status for a node as determined by
NodeHealthService
and provides additional info explaining the reasons - StatusInfo(StatusInfo.Status, String) - Constructor for class org.elasticsearch.monitor.StatusInfo
- StatusInfo.Status - Enum Class in org.elasticsearch.monitor
- StatusOrException(Exception) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- StatusOrException(StreamInput) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
-
Read from a stream.
- StatusOrException(BulkByScrollTask.Status) - Constructor for class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- StatusToXContentObject - Interface in org.elasticsearch.common.xcontent
-
Objects that can both render themselves in as json/yaml/etc and can provide a
RestStatus
for their response. - stay(Decision) - Static method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Creates a move decision for the shard being able to remain on its current node, so the shard won't be forced to move to another node.
- stdDev(double[], double) - Static method in class org.elasticsearch.search.aggregations.pipeline.MovingFunctions
-
Calculate a standard deviation over the values using the provided average.
- stdDeviation - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- stdDeviationBoundLower - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- stdDeviationBoundLowerPopulation - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- stdDeviationBoundLowerSampling - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- stdDeviationBoundUpper - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- stdDeviationBoundUpperPopulation - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- stdDeviationBoundUpperSampling - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- stdDeviationPopulation - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- stdDeviationSampling - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- StepListener<Response> - Class in org.elasticsearch.action
-
A
StepListener
provides a simple way to write a flow consisting of multiple asynchronous steps without having nested callbacks. - StepListener() - Constructor for class org.elasticsearch.action.StepListener
- STILL_ALLOCATED - Enum constant in enum class org.elasticsearch.indices.IndicesService.ShardDeletionCheckResult
- stop() - Method in class org.elasticsearch.cluster.coordination.ClusterFormationFailureHelper
- stop() - Method in class org.elasticsearch.common.component.AbstractLifecycleComponent
- stop() - Method in interface org.elasticsearch.common.component.LifecycleComponent
- stop() - Method in class org.elasticsearch.common.StopWatch
-
Stop the current task.
- stop() - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
-
stops all pinging
- stop() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- stop() - Method in class org.elasticsearch.repositories.FilterRepository
- stop() - Method in class org.elasticsearch.search.profile.Timer
-
Stop the timer.
- stop() - Method in class org.elasticsearch.watcher.WatcherHandle
- stop(String) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection
- STOP - Enum constant in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- StopAnalyzerProvider - Class in org.elasticsearch.index.analysis
- StopAnalyzerProvider(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StopAnalyzerProvider
- stopAndAddRewriteTime() - Method in class org.elasticsearch.search.profile.query.QueryProfiler
-
Stop recording the current rewrite and add it's time to the total tally, returning the cumulative time so far.
- stopCachedTimeThread() - Method in class org.elasticsearch.threadpool.ThreadPool
- stopElectionContext(String) - Method in class org.elasticsearch.discovery.zen.NodeJoinController
-
Stopped accumulating joins.
- stopInternal() - Method in class org.elasticsearch.http.AbstractHttpServerTransport
-
Called to tear down internal resources
- stopInternal() - Method in class org.elasticsearch.transport.TcpTransport
-
Called to tear down internal resources
- stopLoadingStoredFields() - Method in class org.elasticsearch.search.fetch.FetchProfiler
- stopNextReader() - Method in class org.elasticsearch.search.fetch.FetchProfiler
- stopped() - Method in class org.elasticsearch.common.component.Lifecycle
-
Returns
true
if the state is stopped. - stopped(long) - Method in class org.elasticsearch.repositories.RepositoryInfo
- STOPPED - Enum constant in enum class org.elasticsearch.common.component.Lifecycle.State
- stoppedAt - Variable in class org.elasticsearch.repositories.RepositoryInfo
- stoppedOrClosed() - Method in class org.elasticsearch.common.component.Lifecycle
- stopTime - Variable in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- stopTime() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
-
Returns stop time in millis
- StopTokenFilterFactory - Class in org.elasticsearch.index.analysis
- StopTokenFilterFactory(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StopTokenFilterFactory
- Stopwatch - Class in org.elasticsearch.common.inject.internal
-
Enables simple performance monitoring.
- Stopwatch() - Constructor for class org.elasticsearch.common.inject.internal.Stopwatch
- StopWatch - Class in org.elasticsearch.common
-
Simple stop watch, allowing for timing of a number of tasks, exposing total running time and running time for each named task.
- StopWatch() - Constructor for class org.elasticsearch.common.StopWatch
-
Construct a new stop watch.
- StopWatch(String) - Constructor for class org.elasticsearch.common.StopWatch
-
Construct a new stop watch with the given id.
- StopWatch.TaskInfo - Class in org.elasticsearch.common
-
Inner class to hold data about one task executed within the stop watch.
- stopWords() - Method in class org.elasticsearch.index.analysis.StopTokenFilterFactory
- stopWords() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- stopWords(String...) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Set the set of stopwords.
- stopWords(List<String>) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- store - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- store - Variable in class org.elasticsearch.index.engine.Engine
- store() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- store() - Method in class org.elasticsearch.index.shard.IndexShard
- store() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- store() - Method in class org.elasticsearch.repositories.SnapshotShardContext
- store(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- store(boolean) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.Builder
- Store - Class in org.elasticsearch.index.store
-
A Store provides plain access to files written by an elasticsearch index shard.
- Store - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- Store(ShardId, IndexSettings, Directory, ShardLock) - Constructor for class org.elasticsearch.index.store.Store
- Store(ShardId, IndexSettings, Directory, ShardLock, Store.OnClose) - Constructor for class org.elasticsearch.index.store.Store
- STORE_SIZE - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- STORE_SIZE_IN_BYTES - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- Store.MetadataSnapshot - Class in org.elasticsearch.index.store
-
Represents a snapshot of the current directory build from the latest Lucene commit.
- Store.OnClose - Interface in org.elasticsearch.index.store
-
A listener that is executed once the store is closed and all references to it are released
- Store.RecoveryDiff - Class in org.elasticsearch.index.store
-
A class representing the diff between a recovery source and recovery target
- STORED - Enum constant in enum class org.elasticsearch.script.ScriptType
-
STORED scripts are saved as part of the
ClusterState
based on user requests. - STORED_FIELDS - Enum constant in enum class org.elasticsearch.index.search.stats.FieldUsageStats.UsageContext
- STORED_FIELDS - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- STORED_FIELDS - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- STORED_FIELDS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- STORED_FIELDS_IN_BYTES - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- storedField(String) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Adds a stored field to load and return (note, it must be stored) as part of the search request.
- storedField(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Adds a stored field to load and return as part of the search request.
- storedFields() - Method in class org.elasticsearch.action.explain.ExplainRequest
- storedFields() - Method in class org.elasticsearch.action.get.GetRequest
-
Explicitly specify the stored fields that will be returned.
- storedFields() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- storedFields() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Gets the stored fields context
- storedFields() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the stored fields context.
- storedFields(String[]) - Method in class org.elasticsearch.action.explain.ExplainRequest
- storedFields(String...) - Method in class org.elasticsearch.action.get.GetRequest
-
Explicitly specify the stored fields that will be returned.
- storedFields(String...) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- storedFields(String...) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Adds stored fields to load and return (note, it must be stored) as part of the search request.
- storedFields(List<String>) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Sets the stored fields to load and return as part of the search request.
- storedFields(List<String>) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Sets the stored fields to load and return as part of the search request.
- storedFields(StoredFieldsContext) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicates how the stored fields should be fetched.
- storedFieldsContext() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- storedFieldsContext() - Method in class org.elasticsearch.search.internal.SearchContext
- storedFieldsContext() - Method in class org.elasticsearch.search.internal.SubSearchContext
- storedFieldsContext(StoredFieldsContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- storedFieldsContext(StoredFieldsContext) - Method in class org.elasticsearch.search.internal.SearchContext
- storedFieldsContext(StoredFieldsContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
- StoredFieldsContext - Class in org.elasticsearch.search.fetch
-
Context used to fetch the
stored_fields
. - StoredFieldsContext(StreamInput) - Constructor for class org.elasticsearch.search.fetch.StoredFieldsContext
- StoredFieldsContext(StoredFieldsContext) - Constructor for class org.elasticsearch.search.fetch.StoredFieldsContext
- StoredScriptSource - Class in org.elasticsearch.script
-
StoredScriptSource
represents user-defined parameters for a script saved in theClusterState
. - StoredScriptSource(String, String, Map<String, String>) - Constructor for class org.elasticsearch.script.StoredScriptSource
-
Standard StoredScriptSource constructor.
- StoredScriptSource(StreamInput) - Constructor for class org.elasticsearch.script.StoredScriptSource
-
Reads a
StoredScriptSource
from a stream. - StoredValueFetcher - Class in org.elasticsearch.index.mapper
-
Value fetcher that loads from stored values.
- StoredValueFetcher(SearchLookup, String) - Constructor for class org.elasticsearch.index.mapper.StoredValueFetcher
- storeException() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- StoreFileMetadata - Class in org.elasticsearch.index.store
- StoreFileMetadata(String, long, String, String) - Constructor for class org.elasticsearch.index.store.StoreFileMetadata
- StoreFileMetadata(String, long, String, String, BytesRef, BytesRef) - Constructor for class org.elasticsearch.index.store.StoreFileMetadata
- StoreFileMetadata(StreamInput) - Constructor for class org.elasticsearch.index.store.StoreFileMetadata
-
Read from a stream.
- storeFilesMetadata() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodeStoreFilesMetadata
- StoreFilesMetadata(StreamInput) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
- StoreFilesMetadata(ShardId, Store.MetadataSnapshot, List<RetentionLease>) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
- storeParam(Function<FieldMapper, Boolean>, boolean) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- storeResult(TaskResult, ActionListener<Void>) - Method in class org.elasticsearch.tasks.TaskResultsService
- storeResult(Task, Exception, ActionListener<Response>) - Method in class org.elasticsearch.tasks.TaskManager
-
Stores the task failure
- storeResult(Task, Response, ActionListener<Response>) - Method in class org.elasticsearch.tasks.TaskManager
-
Stores the task result
- storeScript(String, StoredScriptSource) - Method in class org.elasticsearch.script.ScriptMetadata.Builder
-
Add a new script to the existing stored scripts based on a user-specified id.
- storeStats() - Method in class org.elasticsearch.index.shard.IndexShard
- StoreStats - Class in org.elasticsearch.index.store
- StoreStats() - Constructor for class org.elasticsearch.index.store.StoreStats
- StoreStats(long, long, long) - Constructor for class org.elasticsearch.index.store.StoreStats
- StoreStats(StreamInput) - Constructor for class org.elasticsearch.index.store.StoreStats
- StoreStatus(DiscoveryNode, String, IndicesShardStoresResponse.StoreStatus.AllocationStatus, Exception) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
- StoreStatus(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
- strategy() - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- strategy(SpatialStrategy) - Method in class org.elasticsearch.index.query.GeoShapeQueryBuilder
-
Defines which spatial strategy will be used for building the geo shape Query.
- STRATEGY_FIELD - Static variable in class org.elasticsearch.index.query.GeoShapeQueryBuilder
- strategyMustBeRebuilt(Settings) - Method in class org.elasticsearch.transport.ProxyConnectionStrategy
- strategyMustBeRebuilt(Settings) - Method in class org.elasticsearch.transport.RemoteConnectionStrategy
- strategyMustBeRebuilt(Settings) - Method in class org.elasticsearch.transport.SniffConnectionStrategy
- strategyType() - Method in class org.elasticsearch.transport.ProxyConnectionStrategy
- strategyType() - Method in class org.elasticsearch.transport.RemoteConnectionStrategy
- strategyType() - Method in class org.elasticsearch.transport.SniffConnectionStrategy
- stream() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
Returns a sequential unordered stream of the map entries.
- streamInput() - Method in class org.elasticsearch.common.bytes.AbstractBytesReference
- streamInput() - Method in class org.elasticsearch.common.bytes.BytesArray
- streamInput() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
A stream input of the bytes.
- streamInput() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- StreamInput - Class in org.elasticsearch.common.io.stream
-
A stream from this node to another node.
- StreamInput() - Constructor for class org.elasticsearch.common.io.stream.StreamInput
- StreamOutput - Class in org.elasticsearch.common.io.stream
-
A stream from another node to this node.
- StreamOutput() - Constructor for class org.elasticsearch.common.io.stream.StreamOutput
- Streams - Class in org.elasticsearch.common.io
-
Simple utility methods for file and stream copying.
- Streams() - Constructor for class org.elasticsearch.common.io.Streams
- Streams() - Constructor for class org.elasticsearch.common.rounding.Rounding.Streams
-
Deprecated.
- Streams() - Constructor for class org.elasticsearch.search.aggregations.InternalOrder.Streams
- STRICT - Enum constant in enum class org.elasticsearch.index.mapper.ObjectMapper.Dynamic
- STRICT - Enum constant in enum class org.elasticsearch.index.query.GeoValidationMethod
- STRICT_BASIC_WEEK_DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_BASIC_WEEK_DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_BASIC_WEEK_DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_DATE_HOUR - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_DATE_HOUR_MINUTE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_DATE_HOUR_MINUTE_SECOND - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_DATE_HOUR_MINUTE_SECOND_FRACTION - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_DATE_HOUR_MINUTE_SECOND_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_DATE_OPTIONAL_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_DATE_OPTIONAL_TIME_NANOS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_EXPAND_OPEN - Static variable in class org.elasticsearch.action.support.IndicesOptions
- STRICT_EXPAND_OPEN_CLOSED - Static variable in class org.elasticsearch.action.support.IndicesOptions
- STRICT_EXPAND_OPEN_CLOSED_HIDDEN - Static variable in class org.elasticsearch.action.support.IndicesOptions
- STRICT_EXPAND_OPEN_FORBID_CLOSED - Static variable in class org.elasticsearch.action.support.IndicesOptions
- STRICT_EXPAND_OPEN_FORBID_CLOSED_IGNORE_THROTTLED - Static variable in class org.elasticsearch.action.support.IndicesOptions
- STRICT_EXPAND_OPEN_HIDDEN - Static variable in class org.elasticsearch.action.support.IndicesOptions
- STRICT_EXPAND_OPEN_HIDDEN_FORBID_CLOSED - Static variable in class org.elasticsearch.action.support.IndicesOptions
- STRICT_HOUR - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_HOUR_MINUTE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_HOUR_MINUTE_SECOND - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_HOUR_MINUTE_SECOND_FRACTION - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_HOUR_MINUTE_SECOND_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_ORDINAL_DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_ORDINAL_DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_ORDINAL_DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_SINGLE_INDEX_NO_EXPAND_FORBID_CLOSED - Static variable in class org.elasticsearch.action.support.IndicesOptions
- STRICT_T_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_T_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_WEEK_DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_WEEK_DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_WEEK_DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_WEEKYEAR - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_WEEKYEAR_WEEK - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_WEEKYEAR_WEEK_DAY - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_YEAR - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_YEAR_MONTH - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- STRICT_YEAR_MONTH_DAY - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- strictCookies() - Method in class org.elasticsearch.http.HttpPipelinedRequest
- strictCookies() - Method in interface org.elasticsearch.http.HttpRequest
- StrictDynamicMappingException - Exception in org.elasticsearch.index.mapper
- StrictDynamicMappingException(String, String) - Constructor for exception org.elasticsearch.index.mapper.StrictDynamicMappingException
- StrictDynamicMappingException(StreamInput) - Constructor for exception org.elasticsearch.index.mapper.StrictDynamicMappingException
- strictExpand() - Static method in class org.elasticsearch.action.support.IndicesOptions
- strictExpandHidden() - Static method in class org.elasticsearch.action.support.IndicesOptions
- strictExpandOpen() - Static method in class org.elasticsearch.action.support.IndicesOptions
- strictExpandOpenAndForbidClosed() - Static method in class org.elasticsearch.action.support.IndicesOptions
- strictExpandOpenAndForbidClosedIgnoreThrottled() - Static method in class org.elasticsearch.action.support.IndicesOptions
- strictExpandOpenHidden() - Static method in class org.elasticsearch.action.support.IndicesOptions
- StrictISODateTimeFormat - Class in org.joda.time.format
-
Factory that creates instances of DateTimeFormatter based on the ISO8601 standard.
- StrictISODateTimeFormat() - Constructor for class org.joda.time.format.StrictISODateTimeFormat
-
Constructor.
- strictSingleIndexNoExpandForbidClosed() - Static method in class org.elasticsearch.action.support.IndicesOptions
- string() - Method in class org.elasticsearch.common.compress.CompressedXContent
- string() - Method in class org.elasticsearch.common.text.Text
-
Returns a
String
view of the data. - STRING - Enum constant in enum class org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- STRING - Enum constant in enum class org.elasticsearch.search.aggregations.support.ValueType
- STRING - Enum constant in enum class org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
-
script sort for a string value
- STRING_DISTANCE_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- stringArrayParam(String, boolean, Function<FieldMapper, List<String>>, List<String>) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- StringBinaryIndexFieldData - Class in org.elasticsearch.index.fielddata.plain
- StringBinaryIndexFieldData(String, ValuesSourceType) - Constructor for class org.elasticsearch.index.fielddata.plain.StringBinaryIndexFieldData
- stringDistance - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- stringDistance() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- stringDistance() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the string distance implementation setting.
- stringDistance(String) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
Sets what string distance implementation to use for comparing how similar suggested terms are.
- stringDistance(StringDistance) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- stringDistance(TermSuggestionBuilder.StringDistanceImpl) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Sets what string distance implementation to use for comparing how similar suggested terms are.
- stringEncode(long) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
-
Encode to a geotile string from the geotile based long format
- stringField(FieldInfo, byte[]) - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- stringField(FieldInfo, byte[]) - Method in class org.elasticsearch.index.fieldvisitor.SingleFieldsVisitor
- stringField(FieldInfo, byte[]) - Method in class org.elasticsearch.search.internal.FilterFieldNamesProvidingStoredFieldsVisitor
- stringField(FieldInfo, byte[]) - Method in class org.elasticsearch.search.internal.FilterStoredFieldVisitor
- StringFieldScript - Class in org.elasticsearch.script
- StringFieldScript(String, Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.StringFieldScript
- StringFieldScript.Emit - Class in org.elasticsearch.script
- StringFieldScript.Factory - Interface in org.elasticsearch.script
- StringFieldScript.LeafFactory - Interface in org.elasticsearch.script
- StringFieldType - Class in org.elasticsearch.index.mapper
-
Base class for
MappedFieldType
implementations that use the same representation for internal index terms as the external representation so that partial matching queries such as prefix, wildcard and fuzzy queries can be implemented. - StringFieldType(String, boolean, boolean, boolean, TextSearchInfo, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.StringFieldType
- StringFilter() - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude.StringFilter
- StringLiteralDeduplicator - Class in org.elasticsearch.common.util
-
A cache in front of Java's string interning.
- StringLiteralDeduplicator() - Constructor for class org.elasticsearch.common.util.StringLiteralDeduplicator
- stringParam(String, boolean, Function<FieldMapper, String>, String) - Static method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
-
Defines a parameter that takes a string value
- StringRareTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
- StringRareTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms
-
Read from a stream.
- StringRareTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- StringRareTermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
-
An aggregator that finds "rare" string values (e.g.
- Strings - Class in org.elasticsearch.common.inject.internal
-
String utilities.
- Strings - Class in org.elasticsearch.common
- Strings(SortedBinaryDocValues) - Constructor for class org.elasticsearch.index.fielddata.ScriptDocValues.Strings
- StringScriptDocValues - Class in org.elasticsearch.index.fielddata
- StringScriptFieldData - Class in org.elasticsearch.index.fielddata
- StringScriptFieldData.Builder - Class in org.elasticsearch.index.fielddata
- StringScriptFieldExistsQuery - Class in org.elasticsearch.search.runtime
- StringScriptFieldExistsQuery(Script, StringFieldScript.LeafFactory, String) - Constructor for class org.elasticsearch.search.runtime.StringScriptFieldExistsQuery
- StringScriptFieldFuzzyQuery - Class in org.elasticsearch.search.runtime
- StringScriptFieldPrefixQuery - Class in org.elasticsearch.search.runtime
- StringScriptFieldPrefixQuery(Script, StringFieldScript.LeafFactory, String, String, boolean) - Constructor for class org.elasticsearch.search.runtime.StringScriptFieldPrefixQuery
- StringScriptFieldRangeQuery - Class in org.elasticsearch.search.runtime
- StringScriptFieldRangeQuery(Script, StringFieldScript.LeafFactory, String, String, String, boolean, boolean) - Constructor for class org.elasticsearch.search.runtime.StringScriptFieldRangeQuery
- StringScriptFieldRegexpQuery - Class in org.elasticsearch.search.runtime
- StringScriptFieldRegexpQuery(Script, StringFieldScript.LeafFactory, String, String, int, int, int) - Constructor for class org.elasticsearch.search.runtime.StringScriptFieldRegexpQuery
- StringScriptFieldTermQuery - Class in org.elasticsearch.search.runtime
- StringScriptFieldTermQuery(Script, StringFieldScript.LeafFactory, String, String, boolean) - Constructor for class org.elasticsearch.search.runtime.StringScriptFieldTermQuery
- StringScriptFieldTermsQuery - Class in org.elasticsearch.search.runtime
- StringScriptFieldTermsQuery(Script, StringFieldScript.LeafFactory, String, Set<String>) - Constructor for class org.elasticsearch.search.runtime.StringScriptFieldTermsQuery
- StringScriptFieldWildcardQuery - Class in org.elasticsearch.search.runtime
- StringScriptFieldWildcardQuery(Script, StringFieldScript.LeafFactory, String, String, boolean) - Constructor for class org.elasticsearch.search.runtime.StringScriptFieldWildcardQuery
- StringSetValueSerializer() - Constructor for class org.elasticsearch.cluster.DiffableUtils.StringSetValueSerializer
- StringSortScript - Class in org.elasticsearch.script
- StringSortScript(Map<String, Object>, DocReader) - Constructor for class org.elasticsearch.script.StringSortScript
- StringSortScript.Factory - Interface in org.elasticsearch.script
-
A factory to construct stateful
StringSortScript
factories for a specific index. - StringSortScript.LeafFactory - Interface in org.elasticsearch.script
-
A factory to construct
StringSortScript
instances. - StringTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Result of the
TermsAggregator
when the field is a String. - StringTerms(String, BucketOrder, BucketOrder, int, long, Map<String, Object>, DocValueFormat, int, boolean, long, List<StringTerms.Bucket>, Long) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
- StringTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTerms
-
Read from a stream.
- StringTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- StringTermsAggregatorFromFilters - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Adapts a
terms
aggregation into afilters
aggregation. - StringTermsAggregatorFromFilters(Aggregator, AggregatorFactories, CheckedFunction<AggregatorFactories, FilterByFilterAggregator, IOException>, boolean, DocValueFormat, BucketOrder, TermsAggregator.BucketCountThresholds, TermsEnum) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.StringTermsAggregatorFromFilters
- stringValue() - Method in class org.elasticsearch.index.mapper.CustomDocValuesField
- strip8Prefix(String) - Static method in interface org.elasticsearch.common.time.DateFormatter
- stripWhitespace(String) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Accepts a JSON string, parses it and prints it without pretty-printing it.
- StupidBackoff - Class in org.elasticsearch.search.suggest.phrase
-
A "stupid-backoff" smoothing model similar to Katz's Backoff.
- StupidBackoff(double) - Constructor for class org.elasticsearch.search.suggest.phrase.StupidBackoff
-
Creates a Stupid-Backoff smoothing model.
- StupidBackoff(StreamInput) - Constructor for class org.elasticsearch.search.suggest.phrase.StupidBackoff
-
Read from a stream.
- subAggregation(AggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- subAggregation(AggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Add a sub aggregation to this builder.
- subAggregation(AggregationBuilder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- subAggregation(PipelineAggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Add a sub aggregation to this aggregation.
- subAggregation(PipelineAggregationBuilder) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Add a sub aggregation to this builder.
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
-
Registers sub-factories with this factory.
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Internal: Registers sub-factories with this factory.
- subAggregations(AggregatorFactories.Builder) - Method in interface org.elasticsearch.search.aggregations.BaseAggregationBuilder
-
Set the sub aggregations if this aggregation supports sub aggregations.
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantTextAggregationBuilder
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder.LeafOnly
- subAggregations(AggregatorFactories.Builder) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder.LeafOnly
- subAggregator(String) - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- subAggregator(String) - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Return the sub aggregator with the provided name.
- subAggregator(String) - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- subAggregator(String) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- subAggregator(String) - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- subAggregators - Variable in class org.elasticsearch.search.aggregations.AggregatorBase
- subAggregators() - Method in class org.elasticsearch.search.aggregations.AdaptingAggregator
- subAggregators() - Method in class org.elasticsearch.search.aggregations.Aggregator
-
Get the aggregators running under this one.
- subAggregators() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- subAggregators() - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector.WrappedAggregator
- subAggregators() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- subBucketOrdinal(long, int) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- subclassesOf(Class<?>) - Static method in class org.elasticsearch.common.inject.matcher.Matchers
-
Returns a matcher which matches subclasses of the given type (as well as the given type).
- submit(ClusterService) - Method in class org.elasticsearch.upgrades.MigrationResultsUpdateTask
-
Submit the update task so that it will actually be executed.
- submitRequest(DiscoveryNode, String, TransportRequest, TransportRequestOptions, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- submitRequest(DiscoveryNode, String, TransportRequest, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
- submitStateUpdateTask(String, T) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Submits a cluster state update task; unlike
ClusterService.submitStateUpdateTask(String, Object, ClusterStateTaskConfig, ClusterStateTaskExecutor, ClusterStateTaskListener)
, submitted updates will not be batched. - submitStateUpdateTask(String, T) - Method in class org.elasticsearch.cluster.service.MasterService
-
Submits a cluster state update task; unlike
MasterService.submitStateUpdateTask(String, Object, ClusterStateTaskConfig, ClusterStateTaskExecutor, ClusterStateTaskListener)
, submitted updates will not be batched. - submitStateUpdateTask(String, T, ClusterStateTaskConfig, ClusterStateTaskExecutor<T>, ClusterStateTaskListener) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Submits a cluster state update task; submitted updates will be batched across the same instance of executor.
- submitStateUpdateTask(String, T, ClusterStateTaskConfig, ClusterStateTaskExecutor<T>, ClusterStateTaskListener) - Method in class org.elasticsearch.cluster.service.MasterService
-
Submits a cluster state update task; submitted updates will be batched across the same instance of executor.
- submitStateUpdateTasks(String, Map<T, ClusterStateTaskListener>, ClusterStateTaskConfig, ClusterStateTaskExecutor<T>) - Method in class org.elasticsearch.cluster.service.ClusterService
-
Submits a batch of cluster state update tasks; submitted updates are guaranteed to be processed together, potentially with more tasks of the same executor.
- submitStateUpdateTasks(String, Map<T, ClusterStateTaskListener>, ClusterStateTaskConfig, ClusterStateTaskExecutor<T>) - Method in class org.elasticsearch.cluster.service.MasterService
-
Submits a batch of cluster state update tasks; submitted updates are guaranteed to be processed together, potentially with more tasks of the same executor.
- submitTasks(List<? extends TaskBatcher.BatchedTask>, TimeValue) - Method in class org.elasticsearch.cluster.service.TaskBatcher
- submitToExecutor(AbstractRunnable) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing
- subOne(long) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- subSearchContext() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext.ProductionAggregationContext
- subSearchContext() - Method in class org.elasticsearch.search.aggregations.support.AggregationContext
-
Build a SubSearchContext to power an aggregation fetching top hits.
- SubSearchContext - Class in org.elasticsearch.search.internal
- SubSearchContext(SearchContext) - Constructor for class org.elasticsearch.search.internal.SubSearchContext
- subSequence(int, int) - Method in class org.elasticsearch.common.settings.SecureString
- subsetDf - Variable in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- subsetSize - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- subsetSize - Variable in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- subsetSize - Variable in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms
- substring(String, int, int) - Static method in class org.elasticsearch.common.Strings
-
Return substring(beginIndex, endIndex) that is impervious to string length.
- substringMatch(CharSequence, int, CharSequence) - Static method in class org.elasticsearch.common.Strings
-
Test whether the given string matches the given substring at the given index.
- subTree(String) - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.PipelineTree
-
Get the sub-tree at for the named sub-aggregation or
PipelineAggregator.PipelineTree.EMPTY
if there are no pipeline aggragations for that sub-aggregator. - subtypeNotProvided(Class<? extends Provider<?>>, Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
- subtypeOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a type that represents an unknown type that extends
bound
. - succeeded() - Method in class org.elasticsearch.upgrades.SingleFeatureMigrationResult
-
Returns
true
if the migration of this feature's data succeeded, orfalse
otherwise. - success() - Static method in class org.elasticsearch.bootstrap.BootstrapCheck.BootstrapCheckResult
- success() - Static method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.TaskResult
- success() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- success() - Static method in class org.elasticsearch.upgrades.SingleFeatureMigrationResult
-
Creates a record indicating that migration succeeded.
- success(int, DocWriteRequest.OpType, DocWriteResponse) - Static method in class org.elasticsearch.action.bulk.BulkItemResponse
- success(String) - Static method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus
-
Create a feature status for a successful reset operation
- success(String, ShardSnapshotResult) - Static method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- success(T) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult.Builder
- SUCCESS - Enum constant in enum class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus.Status
- SUCCESS - Enum constant in enum class org.elasticsearch.cluster.RestoreInProgress.State
-
Restore finished successfully
- SUCCESS - Enum constant in enum class org.elasticsearch.cluster.SnapshotsInProgress.ShardState
- SUCCESS - Enum constant in enum class org.elasticsearch.cluster.SnapshotsInProgress.State
- SUCCESS - Enum constant in enum class org.elasticsearch.index.engine.Engine.Result.Type
- SUCCESS - Enum constant in enum class org.elasticsearch.index.engine.Engine.SyncedFlushResult
- SUCCESS - Enum constant in enum class org.elasticsearch.snapshots.SnapshotState
-
Snapshot process completed successfully
- successes(Iterable<T>) - Method in class org.elasticsearch.cluster.ClusterStateTaskExecutor.ClusterTasksResult.Builder
- successful - Variable in class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
-
Set to true once no more calls to
ChunkedBlobOutputStream.write(int)
are expected and the blob has been received byChunkedBlobOutputStream.write(int)
in full so thatChunkedBlobOutputStream.close()
knows whether to clean up existing chunks or finish a chunked write. - SUCCESSFUL_FIELD - Static variable in class org.elasticsearch.rest.action.RestActions
- SuccessfullyProcessed - Interface in org.elasticsearch.index.reindex
-
Implemented by
WorkerBulkByScrollTaskState
andBulkByScrollTask.Status
to consistently implementSuccessfullyProcessed.getSuccessfullyProcessed()
. - successfulShards() - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
-
total number of shards which were successfully sync-flushed
- successfulShards() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- successfulShards() - Method in class org.elasticsearch.snapshots.RestoreInfo
-
Number of successful shards
- successfulShards() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns total number of shards that were successfully snapshotted; a value of
0
will be returned ifSnapshotInfo.state()
returnsnull
. - suggest - Variable in class org.elasticsearch.action.search.SearchResponseSections
- suggest() - Method in class org.elasticsearch.action.search.SearchResponseSections
- suggest() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the suggester builder for this request.
- suggest() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- suggest() - Method in class org.elasticsearch.search.internal.SearchContext
- suggest() - Method in class org.elasticsearch.search.query.QuerySearchResult
- suggest(String, Iterable<String>) - Static method in class org.elasticsearch.common.xcontent.SuggestingErrorOnUnknown
-
Builds suggestions for an unknown field, returning an empty string if there aren't any suggestions or " did you mean " and then the list of suggestions.
- suggest(Suggest) - Method in class org.elasticsearch.search.query.QuerySearchResult
- suggest(SuggestBuilder) - Method in class org.elasticsearch.action.search.SearchRequestBuilder
-
Delegates to
SearchSourceBuilder.suggest(SuggestBuilder)
- suggest(SuggestBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- suggest(SuggestionSearchContext) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- suggest(SuggestionSearchContext) - Method in class org.elasticsearch.search.internal.SearchContext
- suggest(SuggestionSearchContext) - Method in class org.elasticsearch.search.internal.SubSearchContext
- Suggest - Class in org.elasticsearch.search.suggest
-
Top level suggest result, containing the result for each suggestion.
- Suggest(List<Suggest.Suggestion<? extends Suggest.Suggestion.Entry<? extends Suggest.Suggestion.Entry.Option>>>) - Constructor for class org.elasticsearch.search.suggest.Suggest
- Suggest(StreamInput) - Constructor for class org.elasticsearch.search.suggest.Suggest
- SUGGEST_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- Suggest.Suggestion<T extends Suggest.Suggestion.Entry> - Class in org.elasticsearch.search.suggest
-
The suggestion responses corresponding with the suggestions in the request.
- Suggest.Suggestion.Entry<O extends Suggest.Suggestion.Entry.Option> - Class in org.elasticsearch.search.suggest
-
Represents a part from the suggest text with suggested options.
- Suggest.Suggestion.Entry.Option - Class in org.elasticsearch.search.suggest
-
Contains the suggested text with its document frequency and score.
- SuggestBuilder - Class in org.elasticsearch.search.suggest
-
Defines how to perform suggesting.
- SuggestBuilder() - Constructor for class org.elasticsearch.search.suggest.SuggestBuilder
-
Build an empty SuggestBuilder.
- SuggestBuilder(StreamInput) - Constructor for class org.elasticsearch.search.suggest.SuggestBuilder
-
Read from a stream.
- SuggestBuilders - Class in org.elasticsearch.search.suggest
-
A static factory for building suggester lookup queries
- SuggestBuilders() - Constructor for class org.elasticsearch.search.suggest.SuggestBuilders
- Suggester<T extends SuggestionSearchContext.SuggestionContext> - Class in org.elasticsearch.search.suggest
- Suggester() - Constructor for class org.elasticsearch.search.suggest.Suggester
- SuggesterSpec(String, Writeable.Reader<T>, CheckedFunction<XContentParser, T, IOException>, Writeable.Reader<? extends Suggest.Suggestion>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SuggesterSpec
-
Specification of custom
Suggester
. - SuggesterSpec(ParseField, Writeable.Reader<T>, CheckedFunction<XContentParser, T, IOException>, Writeable.Reader<? extends Suggest.Suggestion>) - Constructor for class org.elasticsearch.plugins.SearchPlugin.SuggesterSpec
-
Specification of custom
Suggester
. - SuggestingErrorOnUnknown - Class in org.elasticsearch.common.xcontent
- SuggestingErrorOnUnknown() - Constructor for class org.elasticsearch.common.xcontent.SuggestingErrorOnUnknown
- Suggestion(String, int) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion
- Suggestion(StreamInput) - Constructor for class org.elasticsearch.search.suggest.Suggest.Suggestion
- SUGGESTION_NAME - Static variable in class org.elasticsearch.search.suggest.completion.CompletionSuggestionBuilder
- SUGGESTION_NAME - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- SUGGESTION_NAME - Static variable in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
- SuggestionBuilder<T extends SuggestionBuilder<T>> - Class in org.elasticsearch.search.suggest
-
Base class for the different suggestion implementations.
- SuggestionBuilder(String) - Constructor for class org.elasticsearch.search.suggest.SuggestionBuilder
-
Creates a new suggestion.
- SuggestionBuilder(String, SuggestionBuilder<?>) - Constructor for class org.elasticsearch.search.suggest.SuggestionBuilder
-
internal copy constructor that copies over all class fields from second SuggestionBuilder except field name.
- SuggestionBuilder(StreamInput) - Constructor for class org.elasticsearch.search.suggest.SuggestionBuilder
-
Read from a stream.
- SuggestionContext(Suggester<?>, SearchExecutionContext) - Constructor for class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- suggestions() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext
- SuggestionSearchContext - Class in org.elasticsearch.search.suggest
- SuggestionSearchContext() - Constructor for class org.elasticsearch.search.suggest.SuggestionSearchContext
- SuggestionSearchContext.SuggestionContext - Class in org.elasticsearch.search.suggest
- suggestMode() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- suggestMode() - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Get the suggest mode setting.
- suggestMode(String) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
-
The global suggest mode controls what suggested terms are included or controls for what suggest text tokens, terms should be suggested for.
- suggestMode(SuggestMode) - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- suggestMode(TermSuggestionBuilder.SuggestMode) - Method in class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
The global suggest mode controls what suggested terms are included or controls for what suggest text tokens, terms should be suggested for.
- SUGGESTMODE_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- SuggestPhase - Class in org.elasticsearch.search.suggest
-
Suggest phase of a search request, used to collect suggestions
- SuggestPhase() - Constructor for class org.elasticsearch.search.suggest.SuggestPhase
- suggestShardSideQueueSize(int) - Static method in class org.elasticsearch.search.aggregations.bucket.BucketUtils
-
Heuristic used to determine the size of shard-side PriorityQueues when selecting the top N terms from a distributed index.
- sum - Variable in class org.elasticsearch.search.aggregations.metrics.InternalStats
- sum - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- sum - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- sum() - Method in class org.elasticsearch.common.metrics.MeanMetric
- sum() - Method in class org.elasticsearch.script.ScriptCacheStats
-
The sum of all script stats, either the general stats or the sum of all stats of the context stats.
- sum(double[]) - Static method in class org.elasticsearch.search.aggregations.pipeline.MovingFunctions
-
Find the sum of a window of values If all values are missing/null/NaN, the return value will be 0.0
- sum(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Sum
aggregation with the given name. - Sum - Interface in org.elasticsearch.search.aggregations.metrics
-
An aggregation that computes the sum of the values in the current bucket.
- SUM - Enum constant in enum class org.elasticsearch.common.lucene.search.function.CombineFunction
- SUM - Enum constant in enum class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- SUM - Enum constant in enum class org.elasticsearch.search.MultiValueMode
-
Pick the sum of all the values.
- SUM - Enum constant in enum class org.elasticsearch.search.sort.SortMode
-
Use the sum of all values as sort value.
- SUM_OF_OTHER_DOC_COUNTS - Static variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- SumAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- SumAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
- SumAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
-
Read from a stream.
- SumAggregationBuilder(SumAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.SumAggregationBuilder
- SumAggregator - Class in org.elasticsearch.search.aggregations.metrics
- sumBucket(String, String) - Static method in class org.elasticsearch.search.aggregations.PipelineAggregatorBuilders
- SumBucketPipelineAggregationBuilder - Class in org.elasticsearch.search.aggregations.pipeline
- SumBucketPipelineAggregationBuilder(String, String) - Constructor for class org.elasticsearch.search.aggregations.pipeline.SumBucketPipelineAggregationBuilder
- SumBucketPipelineAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.SumBucketPipelineAggregationBuilder
-
Read from a stream.
- SumBucketPipelineAggregator - Class in org.elasticsearch.search.aggregations.pipeline
- SumBucketPipelineAggregator(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.pipeline.SumBucketPipelineAggregator
-
Read from a stream.
- summary - Enum constant in enum class org.elasticsearch.index.mapper.TimeSeriesParams.MetricType
- sumOfSquares - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- sumOtherDocCount - Variable in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms
- SunThreadInfo - Class in org.elasticsearch.monitor.jvm
- SunThreadInfo() - Constructor for class org.elasticsearch.monitor.jvm.SunThreadInfo
- supersedes(ClusterState) - Method in class org.elasticsearch.cluster.ClusterState
-
a cluster state supersedes another state if they are from the same master and the version of this state is higher than that of the other state.
- supersetDf - Variable in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- supersetSize - Variable in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- supersetSize - Variable in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- supersetSize - Variable in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms
- supertypeOf(Type) - Static method in class org.elasticsearch.common.inject.util.Types
-
Returns a type that represents an unknown supertype of
bound
. - supplier - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder
- supply(ActionListener<T>, CheckedSupplier<T, Exception>) - Static method in class org.elasticsearch.action.ActionRunnable
-
Creates a
Runnable
that invokes the given listener with the return of the given supplier. - SUPPORT_URL_REPO - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Setting to disable writing the
index.latest
blob which enables the contents of this repository to be used with a url-repository. - SUPPORTS_V6 - Static variable in class org.elasticsearch.common.network.NetworkUtils
-
Deprecated.transition mechanism only, do not use
- supportsContentStream() - Method in class org.elasticsearch.rest.action.document.RestBulkAction
- supportsContentStream() - Method in class org.elasticsearch.rest.action.search.RestMultiSearchAction
- supportsContentStream() - Method in class org.elasticsearch.rest.BaseRestHandler.Wrapper
- supportsContentStream() - Method in class org.elasticsearch.rest.DeprecationRestHandler
- supportsContentStream() - Method in interface org.elasticsearch.rest.RestHandler
-
Indicates if the RestHandler supports content as a stream.
- supportsDiffableValues() - Method in class org.elasticsearch.cluster.DiffableUtils.DiffableValueSerializer
- supportsDiffableValues() - Method in class org.elasticsearch.cluster.DiffableUtils.NonDiffableValueSerializer
- supportsDiffableValues() - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Whether this serializer supports diffable values
- supportsGlobalOrdinalsMapping() - Method in interface org.elasticsearch.index.fielddata.IndexOrdinalsFieldData
-
Whether this field data is able to provide a mapping between global and segment ordinals, by returning the underlying
OrdinalMap
. - supportsGlobalOrdinalsMapping() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData.Consumer
- supportsGlobalOrdinalsMapping() - Method in class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsIndexFieldData
- supportsGlobalOrdinalsMapping() - Method in class org.elasticsearch.index.fielddata.plain.AbstractIndexOrdinalsFieldData
- supportsGlobalOrdinalsMapping() - Method in class org.elasticsearch.index.fielddata.plain.SortedSetOrdinalsIndexFieldData
- supportsGlobalOrdinalsMapping() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldData
- supportsGlobalOrdinalsMapping() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals.FieldData
- supportsGlobalOrdinalsMapping() - Method in class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
-
Whether this values source is able to provide a mapping between global and segment ordinals, by returning the underlying
OrdinalMap
. - supportsVersion(Diff<T>, Version) - Method in class org.elasticsearch.cluster.NamedDiffableValueSerializer
- supportsVersion(Diff<V>, Version) - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Whether this serializer supports the version of the output stream
- supportsVersion(T, Version) - Method in class org.elasticsearch.cluster.NamedDiffableValueSerializer
- supportsVersion(V, Version) - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Whether this serializer supports the version of the output stream
- supportURLRepo - Variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- supportURLRepo() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- SuppressLoggerChecks - Annotation Interface in org.elasticsearch.common
-
Annotation to suppress logging usage checks errors inside a whole class or a method.
- SURVIVOR - Static variable in class org.elasticsearch.monitor.jvm.GcNames
- swap(long, long) - Method in interface org.elasticsearch.search.sort.BucketedSort.ExtraData
-
Swap the position of two bits of extra data.
- swap(long, long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForDoubles
- swap(long, long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForFloats
- swap(long, long) - Method in class org.elasticsearch.search.sort.BucketedSort.ForLongs
- swap(long, long) - Method in class org.elasticsearch.search.sort.BucketedSort
-
Swap the data at two indices.
- Swap(long, long) - Constructor for class org.elasticsearch.monitor.os.OsStats.Swap
- Swap(StreamInput) - Constructor for class org.elasticsearch.monitor.os.OsStats.Swap
- switchDoc(LuceneDocument) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Return a new context that has the provided document as the current document.
- SWITCHING_PROTOCOLS - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server understands and is willing to comply with the client's request, via the Upgrade message header field (section 14.42), for a change in the application protocol being used on this connection.
- switchParser(XContentParser) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
-
Deprecated.we are actively deprecating and removing the ability to pass complex objects to multifields, so try and avoid using this method
- sync() - Method in class org.elasticsearch.index.shard.IndexShard
- sync() - Method in class org.elasticsearch.index.translog.Translog
-
Sync's the translog.
- sync() - Method in class org.elasticsearch.index.translog.TranslogWriter
-
write all buffered ops to disk and fsync file.
- sync(ResyncReplicationRequest, Task, String, long, ActionListener<ResyncReplicationResponse>) - Method in class org.elasticsearch.action.resync.TransportResyncReplicationAction
- sync(ResyncReplicationRequest, Task, String, long, ActionListener<ResyncReplicationResponse>) - Method in interface org.elasticsearch.index.shard.PrimaryReplicaSyncer.SyncAction
- sync(ShardId, String, long, RetentionLeases, ActionListener<ReplicationResponse>) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncer
- sync(ShardId, String, long, RetentionLeases, ActionListener<ReplicationResponse>) - Method in interface org.elasticsearch.index.seqno.RetentionLeaseSyncer.SyncAction
- sync(Translog.Location, Consumer<Exception>) - Method in class org.elasticsearch.index.shard.IndexShard
-
Syncs the given location with the underlying storage unless already synced.
- SYNC_COMMIT_ID - Static variable in class org.elasticsearch.index.engine.Engine
- SYNC_PLUGINS_ACTION - Static variable in class org.elasticsearch.bootstrap.plugins.PluginsManager
- SYNCED_FLUSH_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.indices.flush.SyncedFlushService
- syncedFlush(SyncedFlushRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly sync flush one or more indices (write sync id to shards for faster recovery).
- syncedFlush(SyncedFlushRequest, ActionListener<SyncedFlushResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly sync flush one or more indices (write sync id to shards for faster recovery).
- SyncedFlushAction - Class in org.elasticsearch.action.admin.indices.flush
- syncedFlushRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates a synced flush indices request.
- SyncedFlushRequest - Class in org.elasticsearch.action.admin.indices.flush
-
A synced flush request to sync flush one or more indices.
- SyncedFlushRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequest
-
Constructs a new synced flush request against one or more indices.
- SyncedFlushRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequest
- SyncedFlushRequestBuilder - Class in org.elasticsearch.action.admin.indices.flush
- SyncedFlushRequestBuilder(ElasticsearchClient, SyncedFlushAction) - Constructor for class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequestBuilder
- SyncedFlushResponse - Class in org.elasticsearch.action.admin.indices.flush
-
The result of performing a sync flush operation on all shards of multiple indices
- SyncedFlushResponse(Map<String, List<ShardsSyncedFlushResult>>) - Constructor for class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
- SyncedFlushResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
- SyncedFlushService - Class in org.elasticsearch.indices.flush
- SyncedFlushService(IndicesService, ClusterService, TransportService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.indices.flush.SyncedFlushService
- SyncedFlushService.InFlightOpsRequest - Class in org.elasticsearch.indices.flush
- SyncedFlushService.PreShardSyncedFlushRequest - Class in org.elasticsearch.indices.flush
- SyncedFlushService.ShardSyncedFlushRequest - Class in org.elasticsearch.indices.flush
- SyncedFlushService.ShardSyncedFlushResponse - Class in org.elasticsearch.indices.flush
-
Response for third step of synced flush (writing the sync id) for one shard copy
- syncFlush(String, Engine.CommitId) - Method in class org.elasticsearch.index.engine.Engine
-
Attempts to do a special commit where the given syncID is put into the commit data.
- syncFlush(String, Engine.CommitId) - Method in class org.elasticsearch.index.engine.InternalEngine
- syncFlush(String, Engine.CommitId) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- syncFlush(String, Engine.CommitId) - Method in class org.elasticsearch.index.shard.IndexShard
- syncId() - Method in class org.elasticsearch.index.engine.CommitStats
-
The synced-flush id of the commit if existed.
- syncId() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- syncId() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- syncId() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
- syncNeeded() - Method in class org.elasticsearch.index.translog.Translog
-
Returns
true
if an fsync is required to ensure durability of the translogs operations or it's metadata. - syncNeeded() - Method in class org.elasticsearch.index.translog.TranslogWriter
-
Returns
true
if there are buffered operations that have not been flushed and fsynced to disk or if the latest global checkpoint has not yet been fsynced - syncOperationResultOrThrow(Engine.Result, Translog.Location) - Static method in class org.elasticsearch.action.support.replication.TransportWriteAction
-
Syncs operation result to the translog or throws a shard not available failure
- syncPlugins(Environment) - Static method in class org.elasticsearch.bootstrap.plugins.PluginsManager
-
Synchronizes the currently-installed plugins.
- syncRetentionLeases() - Method in class org.elasticsearch.index.shard.IndexShard
-
Syncs the current retention leases to all replicas.
- syncTranslog() - Method in class org.elasticsearch.index.engine.Engine
- syncTranslog() - Method in class org.elasticsearch.index.engine.InternalEngine
- syncTranslog() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- SYS_PROP_REWRITE_SORT - Static variable in class org.elasticsearch.search.query.QueryPhase
- system(boolean) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- SYSTEM_CALL_FILTER_SETTING - Static variable in class org.elasticsearch.bootstrap.BootstrapSettings
- SYSTEM_CRITICAL_READ - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- SYSTEM_CRITICAL_WRITE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- SYSTEM_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- SYSTEM_INDEX_ACCESS_CONTROL_HEADER_KEY - Static variable in class org.elasticsearch.indices.SystemIndices
- SYSTEM_INDEX_ENFORCEMENT_VERSION - Static variable in class org.elasticsearch.cluster.metadata.IndexNameExpressionResolver
- SYSTEM_INDEX_UPGRADE_TASK_NAME - Static variable in class org.elasticsearch.upgrades.SystemIndexMigrationTaskParams
- SYSTEM_READ - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- SYSTEM_WRITE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- systemDataStreamDescriptor() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- systemDataStreamDescriptor(SystemDataStreamDescriptor) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- SystemDataStreamDescriptor - Class in org.elasticsearch.indices
-
Describes a
DataStream
that is reserved for use by a system component. - SystemDataStreamDescriptor(String, String, SystemDataStreamDescriptor.Type, ComposableIndexTemplate, Map<String, ComponentTemplate>, List<String>, ExecutorNames) - Constructor for class org.elasticsearch.indices.SystemDataStreamDescriptor
-
Creates a new descriptor for a system data descriptor
- SystemDataStreamDescriptor.Type - Enum Class in org.elasticsearch.indices
- SystemIndexDescriptor - Class in org.elasticsearch.indices
-
A system index descriptor describes one or more system indices.
- SystemIndexDescriptor(String, String) - Constructor for class org.elasticsearch.indices.SystemIndexDescriptor
-
Creates a descriptor for system indices matching the supplied pattern.
- SystemIndexDescriptor(String, String, SystemIndexDescriptor.Type, List<String>) - Constructor for class org.elasticsearch.indices.SystemIndexDescriptor
-
Creates a descriptor for system indices matching the supplied pattern.
- SystemIndexDescriptor.Builder - Class in org.elasticsearch.indices
-
Provides a fluent API for building a
SystemIndexDescriptor
. - SystemIndexDescriptor.Type - Enum Class in org.elasticsearch.indices
-
The specific type of system index that this descriptor represents.
- SystemIndexManager - Class in org.elasticsearch.indices
-
This class ensures that all system indices have up-to-date mappings, provided those indices can be automatically managed.
- SystemIndexManager(SystemIndices, Client) - Constructor for class org.elasticsearch.indices.SystemIndexManager
-
Creates a new manager
- SystemIndexMetadataUpdateTask() - Constructor for class org.elasticsearch.cluster.metadata.SystemIndexMetadataUpgradeService.SystemIndexMetadataUpdateTask
- SystemIndexMetadataUpgradeService - Class in org.elasticsearch.cluster.metadata
-
A service responsible for updating the metadata used by system indices.
- SystemIndexMetadataUpgradeService(SystemIndices, ClusterService) - Constructor for class org.elasticsearch.cluster.metadata.SystemIndexMetadataUpgradeService
- SystemIndexMetadataUpgradeService.SystemIndexMetadataUpdateTask - Class in org.elasticsearch.cluster.metadata
- SystemIndexMigrationExecutor - Class in org.elasticsearch.upgrades
-
Starts the process of migrating system indices.
- SystemIndexMigrationExecutor(Client, ClusterService, SystemIndices, MetadataUpdateSettingsService, MetadataCreateIndexService, IndexScopedSettings) - Constructor for class org.elasticsearch.upgrades.SystemIndexMigrationExecutor
- SystemIndexMigrationTaskParams - Class in org.elasticsearch.upgrades
-
The params used to initialize
SystemIndexMigrator
when it's initially kicked off. - SystemIndexMigrationTaskParams() - Constructor for class org.elasticsearch.upgrades.SystemIndexMigrationTaskParams
- SystemIndexMigrationTaskParams(StreamInput) - Constructor for class org.elasticsearch.upgrades.SystemIndexMigrationTaskParams
- SystemIndexMigrationTaskState - Class in org.elasticsearch.upgrades
-
Contains the current state of system index migration progress.
- SystemIndexMigrationTaskState(String, String, Map<String, Object>) - Constructor for class org.elasticsearch.upgrades.SystemIndexMigrationTaskState
- SystemIndexMigrationTaskState(StreamInput) - Constructor for class org.elasticsearch.upgrades.SystemIndexMigrationTaskState
- SystemIndexMigrator - Class in org.elasticsearch.upgrades
-
This is where the logic to actually perform the migration lives -
SystemIndexMigrator.run(SystemIndexMigrationTaskState)
will be invoked when the migration process is started, plus any time the node running the migration drops from the cluster/crashes/etc. - SystemIndexMigrator(Client, long, String, String, TaskId, SystemIndexMigrationTaskParams, Map<String, String>, ClusterService, SystemIndices, MetadataUpdateSettingsService, MetadataCreateIndexService, IndexScopedSettings) - Constructor for class org.elasticsearch.upgrades.SystemIndexMigrator
- SystemIndexPlugin - Interface in org.elasticsearch.plugins
-
Plugin for defining system indices.
- systemIndices - Variable in class org.elasticsearch.action.support.replication.TransportWriteAction
- SystemIndices - Class in org.elasticsearch.indices
-
This class holds the
SystemIndexDescriptor
objects that represent system indices the node knows about. - SystemIndices(List<SystemIndices.Feature>) - Constructor for class org.elasticsearch.indices.SystemIndices
-
Initialize the SystemIndices object
- SystemIndices.Feature - Class in org.elasticsearch.indices
-
Class holding a description of a stateful feature.
- SystemIndices.Feature.MigrationCompletionHandler - Interface in org.elasticsearch.indices
-
Type for the handler that's invoked when all of a feature's system indices have been migrated.
- SystemIndices.Feature.MigrationPreparationHandler - Interface in org.elasticsearch.indices
-
Type for the handler that's invoked prior to migrating a Feature's system indices.
- SystemIndices.SystemIndexAccessLevel - Enum Class in org.elasticsearch.indices
T
- T_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- T_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- Table - Class in org.elasticsearch.common
- Table() - Constructor for class org.elasticsearch.common.Table
- Table.Cell - Class in org.elasticsearch.common
- tag - Variable in class org.elasticsearch.ingest.AbstractProcessor
- TAG_KEY - Static variable in class org.elasticsearch.ingest.ConfigurationUtils
- tagsSchema(String) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Set a tag scheme that encapsulates a built in pre and post tags.
- take() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- takeBreakerReleaseControl() - Method in class org.elasticsearch.transport.InboundMessage
- TAR - Enum constant in enum class org.elasticsearch.Build.Type
- target() - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
- target() - Method in class org.elasticsearch.indices.recovery.RecoveriesCollection.RecoveryRef
- TARGET_NODE_NAME_FIELD - Static variable in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- targetAllocationId() - Method in class org.elasticsearch.indices.recovery.ReestablishRecoveryRequest
- targetAllocationId() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- targetMatches(DiscoveryNode) - Method in class org.elasticsearch.cluster.coordination.Join
- targetNode - Variable in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- targetNode() - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection.PingRequest
- targetNode() - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- targetNode() - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- targetThrottling() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- task - Variable in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
-
the task object that is wrapped
- task - Variable in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor.Pending
- Task - Class in org.elasticsearch.tasks
-
Current task information
- Task(long, String, String, String, TaskId, long, long, Map<String, String>) - Constructor for class org.elasticsearch.tasks.Task
- Task(long, String, String, String, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.tasks.Task
- Task(DiscoveryNode, String) - Constructor for class org.elasticsearch.cluster.coordination.JoinTaskExecutor.Task
- Task(DiscoveryNode, String) - Constructor for class org.elasticsearch.cluster.coordination.NodeRemovalClusterStateTaskExecutor.Task
- TASK_FAILURES - Static variable in class org.elasticsearch.action.support.tasks.BaseTasksResponse
- TASK_INDEX - Static variable in class org.elasticsearch.tasks.TaskResultsService
- TASK_RESULT_MAPPING_VERSION_META_FIELD - Static variable in class org.elasticsearch.tasks.TaskResultsService
- TASK_TYPE - Static variable in class org.elasticsearch.tasks.TaskResultsService
- Task.Status - Interface in org.elasticsearch.tasks
-
Report of the internal status of a task.
- TaskAwareRequest - Interface in org.elasticsearch.tasks
-
An interface for a request that can be used to register a task manager task
- TaskBatcher - Class in org.elasticsearch.cluster.service
-
Batching support for
PrioritizedEsThreadPoolExecutor
Tasks that share the same batching key are batched (seeTaskBatcher.BatchedTask.batchingKey
) - TaskBatcher(Logger, PrioritizedEsThreadPoolExecutor) - Constructor for class org.elasticsearch.cluster.service.TaskBatcher
- TaskBatcher.BatchedTask - Class in org.elasticsearch.cluster.service
-
Represents a runnable task that supports batching.
- TaskCancellationService - Class in org.elasticsearch.tasks
- TaskCancellationService(TransportService) - Constructor for class org.elasticsearch.tasks.TaskCancellationService
- TaskCancelledException - Exception in org.elasticsearch.tasks
-
A generic exception that can be thrown by a task when it's cancelled by the task manager API
- TaskCancelledException(String) - Constructor for exception org.elasticsearch.tasks.TaskCancelledException
- TaskCancelledException(StreamInput) - Constructor for exception org.elasticsearch.tasks.TaskCancelledException
- TaskGroup - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
-
Information about a currently running task and all its subtasks.
- TaskGroup(TaskInfo, List<TaskGroup>) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup
- TaskGroup.Builder - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
- taskId() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexClusterStateUpdateRequest
- taskId() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockClusterStateUpdateRequest
- taskId(long) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexClusterStateUpdateRequest
- taskId(long) - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockClusterStateUpdateRequest
- TaskId - Class in org.elasticsearch.tasks
-
Task id that consists of node id and id of the task on the node
- TaskId(String) - Constructor for class org.elasticsearch.tasks.TaskId
- TaskId(String, long) - Constructor for class org.elasticsearch.tasks.TaskId
- taskInfo() - Method in class org.elasticsearch.common.StopWatch
-
Return an array of the data for tasks performed.
- taskInfo(String, boolean) - Method in class org.elasticsearch.tasks.Task
-
Build a version of the task status you can throw over the wire and back to the user.
- taskInfo(String, String, Task.Status) - Method in class org.elasticsearch.tasks.Task
-
Build a proper
TaskInfo
for this task. - TaskInfo - Class in org.elasticsearch.tasks
-
Information about a currently running task.
- TaskInfo(StreamInput) - Constructor for class org.elasticsearch.tasks.TaskInfo
-
Read from a stream.
- TaskInfo(TaskId, String, String, String, Task.Status, long, long, boolean, boolean, TaskId, Map<String, String>) - Constructor for class org.elasticsearch.tasks.TaskInfo
- taskInfoGivenSubtaskInfo(String, List<TaskInfo>) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask
-
Build the status for this task given a snapshot of the information of running slices.
- TaskListener<Response> - Interface in org.elasticsearch.tasks
-
Listener for Task success or failure.
- taskManager - Variable in class org.elasticsearch.action.support.TransportAction
- taskManager - Variable in class org.elasticsearch.transport.TransportService
- TaskManager - Class in org.elasticsearch.tasks
-
Task Manager service for keeping track of currently running tasks on the nodes
- TaskManager(Settings, ThreadPool, Set<String>) - Constructor for class org.elasticsearch.tasks.TaskManager
- taskMap() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- taskOperation(CancelTasksRequest, CancellableTask, ActionListener<TaskInfo>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.TransportCancelTasksAction
- taskOperation(ListTasksRequest, Task, ActionListener<TaskInfo>) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
- taskOperation(TasksRequest, OperationTask, ActionListener<TaskResponse>) - Method in class org.elasticsearch.action.support.tasks.TransportTasksAction
-
Perform the required operation on the task.
- TaskOperationFailure - Class in org.elasticsearch.action
-
Information about task operation failures The class is final due to serialization limitations
- TaskOperationFailure(String, long, Exception) - Constructor for class org.elasticsearch.action.TaskOperationFailure
- TaskOperationFailure(StreamInput) - Constructor for class org.elasticsearch.action.TaskOperationFailure
-
Read from a stream.
- TaskResult - Class in org.elasticsearch.tasks
-
Information about a running task or a task that stored its result.
- TaskResult(boolean, TaskInfo) - Constructor for class org.elasticsearch.tasks.TaskResult
-
Construct a TaskResult for a task for which we don't have a result or error.
- TaskResult(boolean, TaskInfo, BytesReference, BytesReference) - Constructor for class org.elasticsearch.tasks.TaskResult
- TaskResult(StreamInput) - Constructor for class org.elasticsearch.tasks.TaskResult
-
Read from a stream.
- TaskResult(TaskInfo, Exception) - Constructor for class org.elasticsearch.tasks.TaskResult
-
Construct a TaskResult for a task that completed with an error.
- TaskResult(TaskInfo, ToXContent) - Constructor for class org.elasticsearch.tasks.TaskResult
-
Construct a TaskResult for a task that completed successfully.
- TaskResultsService - Class in org.elasticsearch.tasks
-
Service that can store task results.
- TaskResultsService(Client, ThreadPool) - Constructor for class org.elasticsearch.tasks.TaskResultsService
- tasks() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- TASKS_DESCRIPTOR - Static variable in class org.elasticsearch.tasks.TaskResultsService
- TASKS_FEATURE_NAME - Static variable in class org.elasticsearch.tasks.TaskResultsService
- TASKS_ORIGIN - Static variable in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskAction
- TasksRequestBuilder<Request extends BaseTasksRequest<Request>,
Response extends BaseTasksResponse, RequestBuilder extends TasksRequestBuilder<Request, Response, RequestBuilder>> - Class in org.elasticsearch.action.support.tasks -
Builder for task-based requests
- TasksRequestBuilder(ElasticsearchClient, ActionType<Response>, Request) - Constructor for class org.elasticsearch.action.support.tasks.TasksRequestBuilder
- TaskTransportChannel - Class in org.elasticsearch.transport
- TB - Enum constant in enum class org.elasticsearch.common.unit.ByteSizeUnit
- TCP_CONNECT_TIMEOUT - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_CONNECT_TIMEOUT - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_KEEP_ALIVE - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_KEEP_ALIVE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_KEEP_ALIVE_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_KEEP_COUNT - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_KEEP_COUNT - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_KEEP_COUNT_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_KEEP_IDLE - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_KEEP_IDLE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_KEEP_IDLE_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_KEEP_INTERVAL - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_KEEP_INTERVAL - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_KEEP_INTERVAL_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_NO_DELAY - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_NO_DELAY - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_NO_DELAY_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_RECEIVE_BUFFER_SIZE - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_RECEIVE_BUFFER_SIZE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_RECEIVE_BUFFER_SIZE_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_REUSE_ADDRESS - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_REUSE_ADDRESS - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_REUSE_ADDRESS_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_SEND_BUFFER_SIZE - Static variable in class org.elasticsearch.common.network.NetworkService
- TCP_SEND_BUFFER_SIZE - Static variable in class org.elasticsearch.transport.TransportSettings
- TCP_SEND_BUFFER_SIZE_PROFILE - Static variable in class org.elasticsearch.transport.TransportSettings
- TcpChannel - Interface in org.elasticsearch.transport
-
This is a tcp channel representing a single channel connection to another node.
- TcpChannel.ChannelStats - Class in org.elasticsearch.transport
- TcpHeader - Class in org.elasticsearch.transport
- TcpHeader() - Constructor for class org.elasticsearch.transport.TcpHeader
- tcpKeepAlive - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- tcpKeepCount - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- tcpKeepIdle - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- tcpKeepInterval - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- tcpNoDelay - Variable in class org.elasticsearch.transport.TcpTransport.ProfileSettings
- TcpServerChannel - Interface in org.elasticsearch.transport
-
This is a tcp channel representing a server channel listening for new connections.
- TcpTransport - Class in org.elasticsearch.transport
- TcpTransport(Settings, Version, ThreadPool, PageCacheRecycler, CircuitBreakerService, NamedWriteableRegistry, NetworkService) - Constructor for class org.elasticsearch.transport.TcpTransport
- TcpTransport.HttpRequestOnTransportException - Exception in org.elasticsearch.transport
-
A helper exception to mark an incoming connection as potentially being HTTP so an appropriate error code can be returned
- TcpTransport.NodeChannels - Class in org.elasticsearch.transport
- TcpTransport.ProfileSettings - Class in org.elasticsearch.transport
-
Representation of a transport profile settings for a
transport.profiles.$profilename.*
- TcpTransportChannel - Class in org.elasticsearch.transport
- TDigest() - Constructor for class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.TDigest
- TDigest(double) - Constructor for class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.TDigest
- TDIGEST - Enum constant in enum class org.elasticsearch.search.aggregations.metrics.PercentilesMethod
-
The TDigest method for calculating percentiles
- TDIGEST_PARSER - Static variable in enum class org.elasticsearch.search.aggregations.metrics.PercentilesMethod
- TDigestState - Class in org.elasticsearch.search.aggregations.metrics
-
Extension of
TDigest
with custom serialization. - TDigestState(double) - Constructor for class org.elasticsearch.search.aggregations.metrics.TDigestState
- tempBlobName(String) - Static method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- template() - Method in class org.elasticsearch.cluster.metadata.ComponentTemplate
- template() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- template(Template) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.Builder
- Template - Class in org.elasticsearch.cluster.metadata
-
A template consists of optional settings, mappings, or alias configuration for an index, however, it is entirely independent from an index.
- Template(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.Template
- Template(Settings, CompressedXContent, Map<String, AliasMetadata>) - Constructor for class org.elasticsearch.cluster.metadata.Template
- templateName(String) - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction.Request
- templates() - Method in class org.elasticsearch.cluster.metadata.Metadata
- templates(ImmutableOpenMap<String, IndexTemplateMetadata>) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- TEMPLATES - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- TemplateScript - Class in org.elasticsearch.script
-
A string template rendered as a script.
- TemplateScript(Map<String, Object>) - Constructor for class org.elasticsearch.script.TemplateScript
- TemplateScript.Factory - Interface in org.elasticsearch.script
- templatesV2() - Method in class org.elasticsearch.cluster.metadata.Metadata
- TemplateUpgradeService - Class in org.elasticsearch.cluster.metadata
-
Upgrades Templates on behalf of installed
Plugin
s when a node joins the cluster - TemplateUpgradeService(Client, ClusterService, ThreadPool, Collection<UnaryOperator<Map<String, IndexTemplateMetadata>>>) - Constructor for class org.elasticsearch.cluster.metadata.TemplateUpgradeService
- TEMPORARY_REDIRECT - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The requested resource resides temporarily under a different URI.
- tera() - Method in class org.elasticsearch.common.unit.SizeValue
- TERA - Enum constant in enum class org.elasticsearch.common.unit.SizeUnit
- teraFrac() - Method in class org.elasticsearch.common.unit.SizeValue
- term - Variable in class org.elasticsearch.cluster.coordination.ApplyCommitRequest
- term - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- term() - Method in class org.elasticsearch.cluster.ClusterState
- term() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- term() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- term(long) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.Builder
- TERM - Enum constant in enum class org.elasticsearch.common.geo.SpatialStrategy
- TERM_FREQUENCIES - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- TERM_VECTORS - Enum constant in enum class org.elasticsearch.index.search.stats.FieldUsageStats.UsageContext
- TERM_VECTORS - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- TERM_VECTORS - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- TERM_VECTORS_IN_BYTES - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- TermBasedFieldType - Class in org.elasticsearch.index.mapper
-
Base
MappedFieldType
implementation for a field that is indexed with the inverted index. - TermBasedFieldType(String, boolean, boolean, boolean, TextSearchInfo, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.TermBasedFieldType
- terminate(ExecutorService, long, TimeUnit) - Static method in class org.elasticsearch.threadpool.ThreadPool
-
Returns
true
if the given service was terminated successfully. - terminate(ScheduledThreadPoolExecutor, long, TimeUnit) - Static method in interface org.elasticsearch.threadpool.Scheduler
- terminate(ThreadPool, long, TimeUnit) - Static method in class org.elasticsearch.threadpool.ThreadPool
-
Returns
true
if the given pool was terminated successfully. - TERMINATE_AFTER_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- terminateAfter() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the number of documents to terminate after collecting.
- terminateAfter() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- terminateAfter() - Method in class org.elasticsearch.search.internal.SearchContext
- terminateAfter(int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
An optional terminate_after to terminate the search after collecting
terminateAfter
documents - terminateAfter(int) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- terminateAfter(int) - Method in class org.elasticsearch.search.internal.SearchContext
- terminateAfter(int) - Method in class org.elasticsearch.search.internal.SubSearchContext
- terminated() - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
- terminatedEarly - Variable in class org.elasticsearch.action.search.SearchResponseSections
- terminatedEarly() - Method in class org.elasticsearch.action.search.SearchResponseSections
- terminatedEarly() - Method in class org.elasticsearch.search.query.QuerySearchResult
- terminatedEarly(boolean) - Method in class org.elasticsearch.search.query.QuerySearchResult
- termIntervals(BytesRef) - Method in class org.elasticsearch.index.query.IntervalBuilder
-
Create term intervals for the provided term.
- termIntervals(BytesRef, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Create an
IntervalsSource
for the given term. - termIntervals(BytesRef, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.BinaryFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.BooleanScriptFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.ConstantFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper.TimestampFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DateScriptFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DocCountFieldMapper.DocCountFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DoubleScriptFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.GeoPointScriptFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.IpScriptFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Generates a query that will only match documents that contain the given value.
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- termQuery(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TermBasedFieldType
- termQuery(String, boolean) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, double) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, float) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, int) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, long) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, Object) - Method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- termQuery(String, Object) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- termQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query that matches documents containing a term.
- TermQueryBuilder - Class in org.elasticsearch.index.query
-
A Query that matches documents containing a term.
- TermQueryBuilder(String, boolean) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(String, double) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(String, float) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(String, long) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
- TermQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.TermQueryBuilder
-
Read from a stream.
- termQueryCaseInsensitive(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.BooleanScriptFieldType
- termQueryCaseInsensitive(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.ConstantFieldType
- termQueryCaseInsensitive(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldType
- termQueryCaseInsensitive(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- termQueryCaseInsensitive(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- termQueryCaseInsensitive(Object, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TermBasedFieldType
- terms - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- terms() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- terms(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsFields
- terms(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Terms
aggregation with the given name. - Terms - Interface in org.elasticsearch.search.aggregations.bucket.terms
-
A
terms
aggregation. - TERMS - Enum constant in enum class org.elasticsearch.index.search.stats.FieldUsageStats.UsageContext
- TERMS - Static variable in class org.elasticsearch.index.search.stats.FieldUsageStats
- Terms.Bucket - Interface in org.elasticsearch.search.aggregations.bucket.terms
-
A bucket that is associated with a single term
- TermsAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.terms
- TermsAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- TermsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
-
Read from a stream.
- TermsAggregationBuilder(TermsAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregationBuilder
- TermsAggregator - Class in org.elasticsearch.search.aggregations.bucket.terms
- TermsAggregator(String, AggregatorFactories, AggregationContext, Aggregator, TermsAggregator.BucketCountThresholds, BucketOrder, DocValueFormat, Aggregator.SubAggCollectionMode, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator
- TermsAggregator.BucketCountThresholds - Class in org.elasticsearch.search.aggregations.bucket.terms
- TermsAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.terms
- TermsAggregatorFactory.ExecutionMode - Enum Class in org.elasticsearch.search.aggregations.bucket.terms
- termsLookup() - Method in class org.elasticsearch.index.query.TermsQueryBuilder
- TermsLookup - Class in org.elasticsearch.indices
-
Encapsulates the parameters needed to fetch terms.
- TermsLookup(String, String, String) - Constructor for class org.elasticsearch.indices.TermsLookup
- TermsLookup(String, String, String, String) - Constructor for class org.elasticsearch.indices.TermsLookup
-
Deprecated.Types are in the process of being removed, use
TermsLookup(java.lang.String,java.lang.String,java.lang.String)
instead. - TermsLookup(StreamInput) - Constructor for class org.elasticsearch.indices.TermsLookup
-
Read from a stream.
- termsLookupQuery(String, TermsLookup) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A terms query that can extract the terms from another doc in an index.
- termsQuery(String, double...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter for a field based on several terms matching on any of them.
- termsQuery(String, float...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter for a field based on several terms matching on any of them.
- termsQuery(String, int...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter for a field based on several terms matching on any of them.
- termsQuery(String, long...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter for a field based on several terms matching on any of them.
- termsQuery(String, Object...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter for a field based on several terms matching on any of them.
- termsQuery(String, String...) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter for a field based on several terms matching on any of them.
- termsQuery(String, Collection<?>) - Method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
- termsQuery(String, Collection<?>) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A filter for a field based on several terms matching on any of them.
- termsQuery(Collection<?>, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.BooleanScriptFieldType
- termsQuery(Collection<?>, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.ConstantFieldType
- termsQuery(Collection<?>, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DateScriptFieldType
- termsQuery(Collection<?>, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.DoubleScriptFieldType
- termsQuery(Collection<?>, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- termsQuery(Collection<?>, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.IpScriptFieldType
- termsQuery(Collection<?>, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- termsQuery(Collection<?>, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- termsQuery(Collection<?>, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Build a constant-scoring query that matches all values.
- termsQuery(Collection<?>, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- termsQuery(Collection<?>, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TermBasedFieldType
- TermsQueryBuilder - Class in org.elasticsearch.index.query
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, double...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, float...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, int...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, long...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, Iterable<?>) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, Object...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, String...) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
A filter for a field based on several terms matching on any of them.
- TermsQueryBuilder(String, TermsLookup) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
- TermsQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.TermsQueryBuilder
-
Read from a stream.
- TermsSetQueryBuilder - Class in org.elasticsearch.index.query
- TermsSetQueryBuilder(String, List<?>) - Constructor for class org.elasticsearch.index.query.TermsSetQueryBuilder
- TermsSetQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.TermsSetQueryBuilder
- TermsSetQueryScript - Class in org.elasticsearch.script
- TermsSetQueryScript() - Constructor for class org.elasticsearch.script.TermsSetQueryScript
- TermsSetQueryScript(Map<String, Object>, SearchLookup, LeafReaderContext) - Constructor for class org.elasticsearch.script.TermsSetQueryScript
- TermsSetQueryScript.Factory - Interface in org.elasticsearch.script
-
A factory to construct stateful
TermsSetQueryScript
factories for a specific index. - TermsSetQueryScript.LeafFactory - Interface in org.elasticsearch.script
-
A factory to construct
TermsSetQueryScript
instances. - TermsSliceQuery - Class in org.elasticsearch.search.slice
-
A
SliceQuery
that uses the terms dictionary of a field to do the slicing. - TermsSliceQuery(String, int, int) - Constructor for class org.elasticsearch.search.slice.TermsSliceQuery
- termsStatistics(Term[], TermStatistics[]) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- termState() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- termStatistics() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- termStatistics() - Method in class org.elasticsearch.search.dfs.AggregatedDfs
- termStatistics() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- termStatistics(boolean) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Return the term statistics for each term in the shard or skip.
- termStatistics(Term, int, long) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
- TermStatistics - Enum constant in enum class org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
- termStats - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- termStats(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.CandidateGenerator
- termStats(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator
- termStats(BytesRef) - Method in class org.elasticsearch.search.suggest.phrase.MultiCandidateGeneratorWrapper
- TermSuggester - Class in org.elasticsearch.search.suggest.term
- termSuggestion(String) - Static method in class org.elasticsearch.search.suggest.SuggestBuilders
-
Creates a term suggestion lookup query with the provided
field
- TermSuggestion - Class in org.elasticsearch.search.suggest.term
-
The suggestion responses corresponding with the suggestions in the request.
- TermSuggestion(String, int, SortBy) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion
- TermSuggestion(StreamInput) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestion
- TermSuggestion.Entry - Class in org.elasticsearch.search.suggest.term
-
Represents a part from the suggest text with suggested options.
- TermSuggestion.Entry.Option - Class in org.elasticsearch.search.suggest.term
-
Contains the suggested text with its document frequency and score.
- TermSuggestion.Frequency - Class in org.elasticsearch.search.suggest.term
- TermSuggestion.Score - Class in org.elasticsearch.search.suggest.term
- TermSuggestionBuilder - Class in org.elasticsearch.search.suggest.term
-
Defines the actual suggest command.
- TermSuggestionBuilder(String) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
- TermSuggestionBuilder(StreamInput) - Constructor for class org.elasticsearch.search.suggest.term.TermSuggestionBuilder
-
Read from a stream.
- TermSuggestionBuilder.StringDistanceImpl - Enum Class in org.elasticsearch.search.suggest.term
-
An enum representing the valid string edit distance algorithms for determining suggestions.
- TermSuggestionBuilder.SuggestMode - Enum Class in org.elasticsearch.search.suggest.term
-
An enum representing the valid suggest modes.
- TermsValuesSourceBuilder - Class in org.elasticsearch.search.aggregations.bucket.composite
- TermsValuesSourceBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- TermsValuesSourceBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- TermsValuesSourceBuilder.TermsCompositeSupplier - Interface in org.elasticsearch.search.aggregations.bucket.composite
- termVectors() - Method in class org.elasticsearch.index.mapper.TextSearchInfo
- termVectors(Function<FieldMapper, String>) - Static method in class org.elasticsearch.index.mapper.TextParams
- termVectors(TermVectorsRequest) - Method in interface org.elasticsearch.client.Client
-
An action that returns the term vectors for a specific document.
- termVectors(TermVectorsRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- termVectors(TermVectorsRequest, ActionListener<TermVectorsResponse>) - Method in interface org.elasticsearch.client.Client
-
An action that returns the term vectors for a specific document.
- termVectors(TermVectorsRequest, ActionListener<TermVectorsResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- TermVectorsAction - Class in org.elasticsearch.action.termvectors
- TermVectorsFields - Class in org.elasticsearch.action.termvectors
-
This class represents the result of a
TermVectorsRequest
. - TermVectorsFields(BytesReference, BytesReference) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsFields
- TermVectorsFilter - Class in org.elasticsearch.action.termvectors
- TermVectorsFilter(Fields, Fields, Set<String>) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsFilter
- TermVectorsFilter.ScoreTerm - Class in org.elasticsearch.action.termvectors
- TermVectorsRequest - Class in org.elasticsearch.action.termvectors
-
Request returning the term vector (doc frequency, positions, offsets) for a document.
- TermVectorsRequest() - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequest
- TermVectorsRequest(String, String, String) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Constructs a new term vector request for a document that will be fetch from the provided index.
- TermVectorsRequest(MultiGetRequest.Item) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequest
- TermVectorsRequest(TermVectorsRequest) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Constructs a new term vector request for a document that will be fetch from the provided index.
- TermVectorsRequest.FilterSettings - Class in org.elasticsearch.action.termvectors
- TermVectorsRequest.Flag - Enum Class in org.elasticsearch.action.termvectors
- TermVectorsRequestBuilder - Class in org.elasticsearch.action.termvectors
-
The builder class for a term vector request.
- TermVectorsRequestBuilder(ElasticsearchClient, TermVectorsAction) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
- TermVectorsRequestBuilder(ElasticsearchClient, TermVectorsAction, String, String, String) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsRequestBuilder
-
Constructs a new term vector request builder for a document that will be fetch from the provided index.
- TermVectorsResponse - Class in org.elasticsearch.action.termvectors
- TermVectorsResponse(String, String, String) - Constructor for class org.elasticsearch.action.termvectors.TermVectorsResponse
- TermVectorsService - Class in org.elasticsearch.index.termvectors
- tessellate(Polygon) - Static method in class org.apache.lucene.geo.XTessellator
- tessellate(XYPolygon) - Static method in class org.apache.lucene.geo.XTessellator
- test(String) - Method in class org.elasticsearch.index.query.SearchIndexNameMatcher
-
Given an index pattern, checks whether it matches against the current shard.
- TEST_MOCK_TRANSPORT_THREAD_PREFIX - Static variable in enum class org.elasticsearch.transport.Transports
-
threads whose name is prefixed by this string will be considered network threads, even though they aren't
- text - Variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- text - Variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- text() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- text() - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
get the text for this suggestion
- text(String) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
-
Same as in
SuggestBuilder.setGlobalText(String)
, but in the suggestion scope. - text(String...) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- text(List<String>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- Text - Class in org.elasticsearch.common.text
-
Both
String
andBytesReference
representation of the text. - Text(String) - Constructor for class org.elasticsearch.common.text.Text
- Text(BytesReference) - Constructor for class org.elasticsearch.common.text.Text
- TEXT - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Fields
- TEXT - Static variable in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- TEXT_CONTENT_TYPE - Static variable in class org.elasticsearch.rest.BytesRestResponse
- TEXT_FIELD - Static variable in class org.elasticsearch.search.suggest.SuggestionBuilder
- TextFieldMapper - Class in org.elasticsearch.index.mapper
-
A
FieldMapper
for full-text fields. - TextFieldMapper(String, FieldType, TextFieldMapper.TextFieldType, Map<String, NamedAnalyzer>, TextFieldMapper.SubFieldInfo, TextFieldMapper.SubFieldInfo, FieldMapper.MultiFields, FieldMapper.CopyTo, TextFieldMapper.Builder) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper
- TextFieldMapper.Builder - Class in org.elasticsearch.index.mapper
- TextFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- TextFieldMapper.TextFieldType - Class in org.elasticsearch.index.mapper
- TextFieldType(String) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- TextFieldType(String, boolean, boolean, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- TextFieldType(String, boolean, boolean, TextSearchInfo, Map<String, String>) - Constructor for class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- TextParams - Class in org.elasticsearch.index.mapper
-
Utility functions for text mapper parameters
- TextParams.Analyzers - Class in org.elasticsearch.index.mapper
- TextSearchInfo - Class in org.elasticsearch.index.mapper
-
Encapsulates information about how to perform text searches over a field
- TextSearchInfo(FieldType, SimilarityProvider, NamedAnalyzer, NamedAnalyzer) - Constructor for class org.elasticsearch.index.mapper.TextSearchInfo
-
Create a new TextSearchInfo
- TextSearchInfo.TermVector - Enum Class in org.elasticsearch.index.mapper
-
What sort of term vectors are available
- thenCombine(StepListener<OtherResponse>, BiFunction<Response, OtherResponse, OuterResponse>) - Method in class org.elasticsearch.action.StepListener
-
Combines this listener with another one, waiting for both to successfully complete and combining their results.
- ThisIsNotTheMasterYouAreLookingForException() - Constructor for exception org.elasticsearch.discovery.zen.MasterFaultDetection.ThisIsNotTheMasterYouAreLookingForException
- ThisIsNotTheMasterYouAreLookingForException(String) - Constructor for exception org.elasticsearch.discovery.zen.MasterFaultDetection.ThisIsNotTheMasterYouAreLookingForException
- THREAD_POOL - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
- THREAD_POOL - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- THREAD_POOL_TYPES - Static variable in class org.elasticsearch.threadpool.ThreadPool
- threadContext - Variable in class org.elasticsearch.ingest.Processor.Parameters
-
Allows processors to read headers set by
ActionFilter
instances that have run prior to in ingest. - threadContext - Variable in class org.elasticsearch.transport.NetworkMessage
- ThreadContext - Class in org.elasticsearch.common.util.concurrent
-
A ThreadContext is a map of string headers and a transient map of keyed objects that are associated with a thread.
- ThreadContext(Settings) - Constructor for class org.elasticsearch.common.util.concurrent.ThreadContext
-
Creates a new ThreadContext instance
- ThreadContext.StoredContext - Interface in org.elasticsearch.common.util.concurrent
- ThreadedActionListener<Response> - Class in org.elasticsearch.action.support
-
An action listener that wraps another action listener and threading its execution.
- ThreadedActionListener(Logger, ThreadPool, String, ActionListener<Response>, boolean) - Constructor for class org.elasticsearch.action.support.ThreadedActionListener
- ThreadedActionListener.Wrapper - Class in org.elasticsearch.action.support
-
Wrapper that can be used to automatically wrap a listener in a threaded listener if needed.
- threadedListener() - Method in enum class org.elasticsearch.action.ThreadingModel
-
true
if the invocation of the action result listener will be executed on a different thread (than the calling thread or an "expensive" thread, like the IO thread). - threadedOperation() - Method in enum class org.elasticsearch.action.ThreadingModel
-
true
if the actual operation the action represents will be executed on a different thread than the calling thread (assuming it will be executed on the same node). - threadElementsSnapshotCount(int) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- threadElementsSnapshotDelay(TimeValue) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- ThreadingModel - Enum Class in org.elasticsearch.action
- threadLocalInputStream(InputStream) - Method in interface org.elasticsearch.common.compress.Compressor
-
Creates a new input stream that decompresses the contents read from the provided input stream.
- threadLocalInputStream(InputStream) - Method in class org.elasticsearch.common.compress.DeflateCompressor
- threadLocalOutputStream(OutputStream) - Method in interface org.elasticsearch.common.compress.Compressor
-
Creates a new output stream that compresses the contents and writes to the provided output stream.
- threadLocalOutputStream(OutputStream) - Method in class org.elasticsearch.common.compress.DeflateCompressor
- threadName(String, String) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- threadName(Settings, String) - Static method in class org.elasticsearch.common.util.concurrent.EsExecutors
- threadPool - Variable in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- threadPool - Variable in class org.elasticsearch.action.support.nodes.TransportNodesAction
- threadPool - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- threadPool - Variable in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- threadPool - Variable in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- threadPool - Variable in class org.elasticsearch.cluster.metadata.TemplateUpgradeService
- threadPool - Variable in class org.elasticsearch.cluster.service.MasterService
- threadPool - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- threadPool - Variable in class org.elasticsearch.http.AbstractHttpServerTransport
- threadPool - Variable in class org.elasticsearch.index.reindex.ScrollableHitSource
- threadPool - Variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- threadPool - Variable in class org.elasticsearch.transport.TcpTransport
- threadPool - Variable in class org.elasticsearch.transport.TransportService
- threadPool() - Method in interface org.elasticsearch.client.ElasticsearchClient
-
Returns the threadpool used to execute requests on this client
- threadPool() - Method in class org.elasticsearch.client.support.AbstractClient
- threadPool() - Method in class org.elasticsearch.cluster.service.ClusterApplierService
- threadPool() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- ThreadPool - Class in org.elasticsearch.threadpool
- ThreadPool(Settings, ExecutorBuilder<?>...) - Constructor for class org.elasticsearch.threadpool.ThreadPool
- ThreadPool.Info - Class in org.elasticsearch.threadpool
- ThreadPool.Names - Class in org.elasticsearch.threadpool
- ThreadPool.ThreadPoolType - Enum Class in org.elasticsearch.threadpool
- threadPoolForGet() - Method in class org.elasticsearch.indices.ExecutorNames
- threadPoolForSearch() - Method in class org.elasticsearch.indices.ExecutorNames
- threadPoolForWrite() - Method in class org.elasticsearch.indices.ExecutorNames
- ThreadPoolInfo - Class in org.elasticsearch.threadpool
- ThreadPoolInfo(List<ThreadPool.Info>) - Constructor for class org.elasticsearch.threadpool.ThreadPoolInfo
- ThreadPoolInfo(StreamInput) - Constructor for class org.elasticsearch.threadpool.ThreadPoolInfo
- ThreadPoolStats - Class in org.elasticsearch.threadpool
- ThreadPoolStats(List<ThreadPoolStats.Stats>) - Constructor for class org.elasticsearch.threadpool.ThreadPoolStats
- ThreadPoolStats(StreamInput) - Constructor for class org.elasticsearch.threadpool.ThreadPoolStats
- ThreadPoolStats.Stats - Class in org.elasticsearch.threadpool
- threads() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- threads(int) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- Threads(int, int) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.Threads
- Threads(StreamInput) - Constructor for class org.elasticsearch.monitor.jvm.JvmStats.Threads
- THRESHOLD_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.allocator.BalancedShardsAllocator
- throttle(List<NodeAllocationResult>) - Static method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Returns a THROTTLE decision, with the individual node-level decisions that comprised the final THROTTLE decision if in explain mode.
- THROTTLE - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
- THROTTLE - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.Decision
- THROTTLED - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
The allocation attempt was throttled for the shard.
- THROTTLED_HR_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- THROTTLED_RAW_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- THROTTLED_UNTIL_HR_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- THROTTLED_UNTIL_RAW_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- throttleTime() - Method in class org.elasticsearch.index.recovery.RecoveryStats
-
Total time recoveries waited due to throttling
- throttleWaitTime(long, long, int) - Method in class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- ThrottlingAllocationDecider - Class in org.elasticsearch.cluster.routing.allocation.decider
-
ThrottlingAllocationDecider
controls the recovery process per node in the cluster. - ThrottlingAllocationDecider(Settings, ClusterSettings) - Constructor for class org.elasticsearch.cluster.routing.allocation.decider.ThrottlingAllocationDecider
- throwConfigurationExceptionIfErrorsExist() - Method in class org.elasticsearch.common.inject.internal.Errors
- throwCreationExceptionIfErrorsExist() - Method in class org.elasticsearch.common.inject.internal.Errors
- throwIfEmpty() - Method in class org.elasticsearch.index.fielddata.ScriptDocValues
- throwIfNewErrors(int) - Method in class org.elasticsearch.common.inject.internal.Errors
- throwOnBrokenVInt(byte, int) - Static method in class org.elasticsearch.common.io.stream.StreamInput
- throwOnBrokenVLong(byte, long) - Static method in class org.elasticsearch.common.io.stream.StreamInput
- throwParsingExceptionOnMultipleFields(String, XContentLocation, String, String) - Static method in class org.elasticsearch.index.query.AbstractQueryBuilder
- throwParsingExceptionOnMultipleFields(String, XContentLocation, String, String) - Static method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- throwProvisionExceptionIfErrorsExist() - Method in class org.elasticsearch.common.inject.internal.Errors
- throwUnknownField(String, XContentLocation) - Static method in class org.elasticsearch.common.xcontent.XContentParserUtils
- throwUnknownToken(XContentParser.Token, XContentLocation) - Static method in class org.elasticsearch.common.xcontent.XContentParserUtils
- tieBreakActiveMasters(Collection<DiscoveryNode>) - Method in class org.elasticsearch.discovery.zen.ElectMasterService
-
selects the best active master to join, where multiple are discovered
- tieBreaker() - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
- tieBreaker() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- tieBreaker() - Method in enum class org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
- tieBreaker() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- tieBreaker(float) - Method in class org.elasticsearch.index.query.DisMaxQueryBuilder
-
The score of each non-maximum disjunct for a document is multiplied by this weight and added into the final score.
- tieBreaker(float) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Tie-Breaker for "best-match" disjunction queries (OR-Queries).
- tieBreaker(float) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
When more than one field is used with the query string, and combined queries are using dis max, control the tie breaker for it.
- tieBreaker(Float) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Tie-Breaker for "best-match" disjunction queries (OR-Queries).
- TIER_PREFERENCE - Static variable in class org.elasticsearch.cluster.routing.allocation.DataTier
- TIER_PREFERENCE_SETTING - Static variable in class org.elasticsearch.cluster.routing.allocation.DataTier
- TIM - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- time - Variable in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- time - Variable in class org.elasticsearch.script.ScriptCache.CompilationRate
- time() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns snapshot running time
- time() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
-
Returns elapsed time in millis, or 0 if timer was not started
- time() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, three digit fraction of second, and time zone offset (HH:mm:ss.SSSZZ).
- TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- TIME_FIELD - Static variable in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- TIME_SERIES_DIMENSION_PARAM - Static variable in class org.elasticsearch.index.mapper.TimeSeriesParams
- TIME_SERIES_METRIC_PARAM - Static variable in class org.elasticsearch.index.mapper.TimeSeriesParams
- timedOut - Variable in class org.elasticsearch.action.search.SearchResponseSections
- timedOut() - Method in class org.elasticsearch.action.search.SearchResponseSections
- timeElementParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO time parser.
- timeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and time zone offset (HH:mm:ssZZ).
- timeout - Variable in class org.elasticsearch.action.bulk.BulkRequest
- timeout - Variable in class org.elasticsearch.action.support.master.AcknowledgedRequest
- timeout - Variable in class org.elasticsearch.action.support.replication.ReplicationRequest
- timeout - Variable in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- timeout - Variable in class org.elasticsearch.discovery.zen.UnicastZenPing.UnicastPingRequest
- timeout() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- timeout() - Method in class org.elasticsearch.action.bulk.BulkRequest
- timeout() - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- timeout() - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
-
Returns the current timeout
- timeout() - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- timeout() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- timeout() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- timeout() - Method in class org.elasticsearch.cluster.ClusterStateTaskConfig.Basic
- timeout() - Method in interface org.elasticsearch.cluster.ClusterStateTaskConfig
-
The timeout for this cluster state update task configuration.
- timeout() - Method in class org.elasticsearch.cluster.ClusterStateUpdateTask
-
If the cluster state update task wasn't processed by the provided timeout, call
ClusterStateTaskListener.onFailure(String, Exception)
. - timeout() - Method in class org.elasticsearch.cluster.LocalClusterUpdateTask
- timeout() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Gets the timeout to control how long search is allowed to take.
- timeout() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- timeout() - Method in class org.elasticsearch.search.internal.SearchContext
- timeout() - Method in class org.elasticsearch.transport.TransportRequestOptions
- timeout(String) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- timeout(String) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout(String) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
-
Allows to set the timeout
- timeout(String) - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- timeout(String) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout(String) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- timeout(TimeValue) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout(TimeValue) - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- timeout(TimeValue) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
-
Allows to set the timeout
- timeout(TimeValue) - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- timeout(TimeValue) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout(TimeValue) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
-
A timeout to wait if the index operation can't be performed immediately.
- timeout(TimeValue) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
Timeout to wait for the shards on to be available for each bulk request.
- timeout(TimeValue) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
An optional timeout to control how long search is allowed to take.
- timeout(TimeValue) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- timeout(TimeValue) - Method in class org.elasticsearch.search.internal.SearchContext
- timeout(TimeValue) - Method in class org.elasticsearch.search.internal.SubSearchContext
- timeout(TimeValue) - Static method in class org.elasticsearch.transport.TransportRequestOptions
- TIMEOUT_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- TimeoutClusterStateListener - Interface in org.elasticsearch.cluster
-
An exception to cluster state listener that allows for timeouts and for post added notifications.
- timeParser() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a generic ISO time parser for parsing times with a possible zone.
- Timer - Class in org.elasticsearch.search.profile
-
Helps measure how much time is spent running some methods.
- Timer() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Timer
- Timer() - Constructor for class org.elasticsearch.search.profile.Timer
- Timer(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Timer
- TimeSeries() - Constructor for class org.elasticsearch.script.ScriptContextStats.TimeSeries
- TimeSeries(long, long, long) - Constructor for class org.elasticsearch.script.ScriptContextStats.TimeSeries
- TimeSeries(StreamInput) - Constructor for class org.elasticsearch.script.ScriptContextStats.TimeSeries
- TIMESERIES_LEAF_READERS_SORTER - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- TimeSeriesParams - Class in org.elasticsearch.index.mapper
-
Utility functions for time series related mapper parameters
- TimeSeriesParams.MetricType - Enum Class in org.elasticsearch.index.mapper
- timeSetting(String, Function<Settings, TimeValue>, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- timeSetting(String, Setting<TimeValue>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- timeSetting(String, Setting<TimeValue>, Setting.Validator<TimeValue>, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- timeSetting(String, Setting<TimeValue>, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- timeSetting(String, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- timeSetting(String, TimeValue, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- timeSetting(String, TimeValue, TimeValue, TimeValue, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- timestamp() - Method in exception org.elasticsearch.action.TimestampParsingException
- timestamp() - Method in class org.elasticsearch.index.seqno.RetentionLease
-
The timestamp of when this retention lease was created or renewed.
- TIMESTAMP - Static variable in class org.elasticsearch.common.Table
- TIMESTAMP_FIELD_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStream
- TimestampField(String) - Constructor for class org.elasticsearch.cluster.metadata.DataStream.TimestampField
- TimestampField(StreamInput) - Constructor for class org.elasticsearch.cluster.metadata.DataStream.TimestampField
- TimestampFieldMapperService - Class in org.elasticsearch.indices
-
Tracks the mapping of the
@timestamp
field of immutable indices that expose their timestamp range in their index metadata. - TimestampFieldMapperService(Settings, ThreadPool, IndicesService) - Constructor for class org.elasticsearch.indices.TimestampFieldMapperService
- TimestampParsingException - Exception in org.elasticsearch.action
- TimestampParsingException(String) - Constructor for exception org.elasticsearch.action.TimestampParsingException
- TimestampParsingException(String, Throwable) - Constructor for exception org.elasticsearch.action.TimestampParsingException
- TimestampParsingException(StreamInput) - Constructor for exception org.elasticsearch.action.TimestampParsingException
- timestampRange(IndexLongFieldRange) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- timezone() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- timeZone() - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- timeZone() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
In case of date field, gets the from/to fields timezone adjustment
- timeZone() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
The time zone for this value source.
- timeZone() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Gets the time zone to use for this aggregation
- timeZone() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Gets the time zone to use for this aggregation
- timeZone(String) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
-
In case of date field, we can adjust the from/to fields using a timezone
- timeZone(String) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
In case of date field, we can adjust the from/to fields using a timezone
- timeZone(ZoneId) - Method in class org.elasticsearch.common.Rounding.Builder
- timeZone(ZoneId) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- timeZone(ZoneId) - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
-
Sets the time zone to use for this aggregation
- timeZone(ZoneId) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Sets the time zone to use for this aggregation
- timeZone(DateTimeZone) - Method in class org.elasticsearch.common.rounding.Rounding.Builder
-
Deprecated.
- timing(String) - Method in class org.elasticsearch.common.StopWatch
- TIP - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- TMD - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- TMP - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- tmpFile() - Method in class org.elasticsearch.env.Environment
-
Path to the default temp directory used by the JDK
- to - Variable in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- to - Variable in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- to - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- to() - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
Gets the upper range value for this query.
- to(boolean) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(boolean) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(char) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(char) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(double) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(double) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(float) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(float) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(int) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(int) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(long) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(long) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(short) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(short) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(E) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(E) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(Class<?>) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(Class<?>) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(Class<? extends T>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - to(Class<? extends T>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- to(Object) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- to(Object, boolean) - Method in class org.elasticsearch.index.query.RangeQueryBuilder
-
The to part of the range query.
- to(String) - Method in interface org.elasticsearch.common.inject.binder.ConstantBindingBuilder
-
Binds constant to the given value.
- to(String) - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- to(Key<? extends T>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - to(Key<? extends T>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- to(TypeLiteral<? extends T>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - to(TypeLiteral<? extends T>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- TO - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- TO_AS_STRING - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- TO_FIELD - Static variable in class org.elasticsearch.index.query.RangeQueryBuilder
- TO_FIELD - Static variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- toAddrString(InetAddress) - Static method in class org.elasticsearch.common.network.InetAddresses
-
Returns the string representation of an
InetAddress
. - toArray() - Method in class org.elasticsearch.common.collect.EvictingQueue
- toArray() - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- toArray(E[]) - Method in class org.elasticsearch.common.util.concurrent.AtomicArray
-
Copies the content of the underlying atomic array to a normal one.
- toArray(Collection<Integer>) - Static method in class org.elasticsearch.common.util.CollectionUtils
- toArray(T[]) - Method in class org.elasticsearch.common.util.concurrent.SizeBlockingQueue
- toArray(T1[]) - Method in class org.elasticsearch.common.collect.EvictingQueue
- toAsStr - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- toAsString - Variable in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- toAutomaton() - Method in class org.elasticsearch.common.lucene.RegExp
- toAutomaton(int) - Method in class org.elasticsearch.common.lucene.RegExp
- toBiConsumer(ActionListener<Response>) - Static method in interface org.elasticsearch.action.ActionListener
-
Converts a listener to a
BiConsumer
for compatibility with theCompletableFuture
api. - toBlobNamePart() - Method in class org.elasticsearch.repositories.ShardGeneration
-
Convert to a
String
for use in naming theindex-$SHARD_GEN
blob containing aBlobStoreIndexShardSnapshots
. - toBooleanClauseOccur() - Method in enum class org.elasticsearch.index.query.Operator
- toBoundingBox(int, int, int) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
- toBoundingBox(long) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
- toBoundingBox(String) - Static method in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoTileUtils
-
Decode a string bucket key in "zoom/x/y" format to a bounding box of the tile corners
- toBreakdownMap() - Method in class org.elasticsearch.search.profile.AbstractProfileBreakdown
-
Build a timing count breakdown.
- toByteBuffers(BytesReference) - Static method in interface org.elasticsearch.common.bytes.BytesReference
-
Returns an array of byte buffers from the given BytesReference.
- toByteExact(Number) - Static method in class org.elasticsearch.common.Numbers
-
Return the byte that
n
stores, or throws an exception if the stored value cannot be converted to a byte that stores the exact same value. - toBytes(long) - Method in enum class org.elasticsearch.common.unit.ByteSizeUnit
- toBytes(ClusterState) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
- toBytes(BytesReference) - Static method in interface org.elasticsearch.common.bytes.BytesReference
-
Returns a compact array from the given BytesReference.
- toBytesRef() - Method in class org.elasticsearch.common.bytes.BytesArray
- toBytesRef() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Converts to Lucene BytesRef.
- toBytesRef() - Method in class org.elasticsearch.common.bytes.CompositeBytesReference
- toBytesRef() - Method in class org.elasticsearch.common.bytes.PagedBytesReference
- toBytesRef() - Method in class org.elasticsearch.common.bytes.RecyclingBytesStreamOutput
-
Return the written bytes in a
BytesRef
, avoiding allocating a newbyte[]
if the original buffer was already large enough. - toBytesRef() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- toBytesRef(Object) - Static method in class org.elasticsearch.common.lucene.BytesRefs
-
Converts an object value to BytesRef.
- toBytesRef(Object, BytesRefBuilder) - Static method in class org.elasticsearch.common.lucene.BytesRefs
- toCaseInsensitiveChar(int, int) - Static method in class org.elasticsearch.common.lucene.search.AutomatonQueries
- toCaseInsensitiveString(String, int) - Static method in class org.elasticsearch.common.lucene.search.AutomatonQueries
- toCaseInsensitiveString(BytesRef, int) - Static method in class org.elasticsearch.common.lucene.search.AutomatonQueries
- toCaseInsensitiveWildcardAutomaton(Term, int) - Static method in class org.elasticsearch.common.lucene.search.AutomatonQueries
-
Convert Lucene wildcard syntax into an automaton.
- toCidrString(InetAddress, int) - Static method in class org.elasticsearch.common.network.InetAddresses
-
Given an address and prefix length, returns the string representation of the range in CIDR notation.
- toCompressedXContent() - Method in class org.elasticsearch.index.mapper.Mapping
-
Outputs this mapping instance and returns it in
CompressedXContent
format - toConcreteKey(String) - Method in class org.elasticsearch.common.settings.Setting.AffixKey
- toContextQuery(CompletionQuery, Map<String, List<ContextMapping.InternalQueryContext>>) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
-
Wraps a
CompletionQuery
with context queries - toDataPaths(Path[]) - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
- toDateMathParser() - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- toDateMathParser() - Method in interface org.elasticsearch.common.time.DateFormatter
-
Create a DateMathParser from the existing formatter
- toDebugMap() - Method in class org.elasticsearch.search.profile.AbstractProfileBreakdown
-
Fetch extra debugging information.
- toDebugMap() - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfileBreakdown
- toDelimitedString(char) - Method in class org.elasticsearch.common.settings.Settings
-
Returns the settings as delimited string.
- toEpochSecond() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- toException() - Method in class org.elasticsearch.common.inject.internal.Errors
- toFilter(ShardSearchRequest, SearchExecutionContext) - Method in class org.elasticsearch.search.slice.SliceBuilder
-
Converts this QueryBuilder to a lucene
Query
. - toFunction(SearchExecutionContext) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
-
Called on a data node, converts this ScoreFunctionBuilder into its corresponding Lucene function object.
- toGB(long) - Method in enum class org.elasticsearch.common.unit.ByteSizeUnit
- toGiga(long) - Method in enum class org.elasticsearch.common.unit.SizeUnit
- toHash128(byte[]) - Static method in class org.elasticsearch.common.hash.Murmur3Hasher
-
Converts the 128-bit byte array returned by
Murmur3Hasher.digest()
to aMurmurHash3.Hash128
- toHexCharArray(byte[]) - Static method in class org.elasticsearch.common.hash.MessageDigests
-
Encodes the byte array into a newly created hex char array, without allocating any other temporary variables.
- toHexString(byte[]) - Static method in class org.elasticsearch.common.hash.MessageDigests
-
Format a byte array as a hex string.
- toIndexOptions(boolean, String) - Static method in class org.elasticsearch.index.mapper.TextParams
- toInnerXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.SearchHit
- toInnerXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
- toInnerXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Implementations should add specific configurations that need to be persisted
- toInnerXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- toInstance(T) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - toInstance(T) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- toInstant() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- toInstant(long) - Static method in class org.elasticsearch.common.time.DateUtils
-
convert a long value to a java time instant the long value resembles the nanoseconds since the epoch
- toInstant(long) - Method in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
-
Convert a long value in this resolution into an instant.
- toIntBytes(long) - Method in enum class org.elasticsearch.common.unit.ByteSizeUnit
-
Convert to an
int
number of bytes. - toInternalQueryContexts(List<CategoryQueryContext>) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryContextMapping
-
Parse a list of
CategoryQueryContext
usingparser
. - toInternalQueryContexts(List<GeoQueryContext>) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
-
Parse a list of
GeoQueryContext
usingparser
. - toInternalQueryContexts(List<T>) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Convert query contexts to common representation
- toIntExact(Number) - Static method in class org.elasticsearch.common.Numbers
-
Return the int that
n
stores, or throws an exception if the stored value cannot be converted to an int that stores the exact same value. - toJsonString() - Method in exception org.elasticsearch.script.ScriptException
-
Returns a JSON version of this exception for debugging.
- toKB(long) - Method in enum class org.elasticsearch.common.unit.ByteSizeUnit
- token(XContentParser, String, XContentParser.Token, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsParser
- token(XContentParser, String, XContentParser.Token, Map<String, Object>) - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketParser
- TOKEN_FILTERS - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Fields
- TOKEN_LIMIT_FIELD - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- TokenConsumer() - Constructor for class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.TokenConsumer
- TokenFilterFactory - Interface in org.elasticsearch.index.analysis
- tokenfilters() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.DetailAnalyzeResponse
- tokenFilters() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- tokenFilters() - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- tokenizeByCommaToSet(String) - Static method in class org.elasticsearch.common.Strings
-
Tokenize the specified string by commas to a set, trimming whitespace and ignoring empty tokens.
- tokenizer() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.DetailAnalyzeResponse
- tokenizer() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- tokenizer(String) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- tokenizer(Map<String, ?>) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- tokenizer(NameOrDefinition) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- TOKENIZER - Static variable in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Fields
- tokenizerFactory() - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
- TokenizerFactory - Interface in org.elasticsearch.index.analysis
- tokenizeToStringArray(String, String) - Static method in class org.elasticsearch.common.Strings
-
Tokenize the given String into a String array via a StringTokenizer.
- tokenLimit() - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
-
get the
PhraseSuggestionBuilder.tokenLimit(int)
parameter - tokenLimit(int) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestionBuilder
- tokenStream(Analyzer, TokenStream) - Method in class org.elasticsearch.index.mapper.CustomDocValuesField
- tokenStream(Analyzer, TokenStream) - Method in class org.elasticsearch.index.mapper.CustomTermFreqField
- toKilo(long) - Method in enum class org.elasticsearch.common.unit.SizeUnit
- TOLERANCE - Static variable in class org.elasticsearch.common.geo.GeoUtils
-
rounding error for quantized latitude and longitude values
- toList() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingCollection
-
serialize current pings to a list.
- toLocalDate() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- toLocalDateTime() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- toLocalTime() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- toLong(String, boolean) - Static method in class org.elasticsearch.common.Numbers
-
Return the long that
stringValue
stores or throws an exception if the stored value cannot be converted to a long that stores the exact same value andcoerce
is false. - toLong(Instant) - Static method in class org.elasticsearch.common.time.DateUtils
-
convert a java time instant to a long value which is stored in lucene the long value resembles the nanoseconds since the epoch
- toLongExact(Number) - Static method in class org.elasticsearch.common.Numbers
-
Return the long that
n
stores, or throws an exception if the stored value cannot be converted to a long that stores the exact same value. - toLowercaseAscii(String) - Static method in class org.elasticsearch.common.Strings
- toLucene() - Method in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
- toLucene() - Method in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
- toLuceneCircle(Circle) - Static method in class org.elasticsearch.common.geo.GeoShapeUtils
- toLuceneGeometry(String, SearchExecutionContext, Geometry, ShapeRelation) - Static method in class org.elasticsearch.common.geo.GeoShapeUtils
- toLuceneLine(Line) - Static method in class org.elasticsearch.common.geo.GeoShapeUtils
- toLucenePoint(Point) - Static method in class org.elasticsearch.common.geo.GeoShapeUtils
- toLucenePolygon(Polygon) - Static method in class org.elasticsearch.common.geo.GeoShapeUtils
- toLucenePolygon(Rectangle) - Static method in class org.elasticsearch.common.geo.GeoShapeUtils
- toLuceneRectangle(Rectangle) - Static method in class org.elasticsearch.common.geo.GeoShapeUtils
- toMap() - Method in class org.elasticsearch.tasks.RawTaskStatus
-
Convert the from XContent to a Map for easy reading.
- toMap(Geometry) - Static method in class org.elasticsearch.common.geo.GeoJson
-
Produces that same GeoJSON as toXContent only in parsed map form
- toMB(long) - Method in enum class org.elasticsearch.common.unit.ByteSizeUnit
- tombstone() - Static method in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SequenceIDFields
- TOMBSTONE_NAME - Static variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper
- tombstoneField - Variable in class org.elasticsearch.index.mapper.SeqNoFieldMapper.SequenceIDFields
- tombstones() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Builder
-
A copy of the current tombstones in the builder.
- toMega(long) - Method in enum class org.elasticsearch.common.unit.SizeUnit
- toMeters(double) - Method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Convert a value into meters
- toMilliSeconds(long) - Static method in class org.elasticsearch.common.time.DateUtils
-
Convert a nanosecond timestamp in milliseconds
- toNanoSeconds(long) - Static method in class org.elasticsearch.common.time.DateUtils
-
Convert a nanosecond timestamp in milliseconds
- toNode() - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- toNodeTime() - Method in class org.elasticsearch.search.profile.AbstractProfileBreakdown
- TOO_MANY_REQUESTS - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
429 Too Many Requests (RFC6585)
- toOffsetDateTime() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- TOOL - Enum constant in enum class org.elasticsearch.common.inject.Stage
-
We're running in a tool (an IDE plugin for example).
- TooManyBucketsException(String, int) - Constructor for exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
- TooManyBucketsException(StreamInput) - Constructor for exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
- tooManyConstructors(Class<?>) - Method in class org.elasticsearch.common.inject.internal.Errors
- top - Variable in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- top() - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- TOP_LEFT - Enum constant in enum class org.elasticsearch.common.geo.GeoUtils.EffectivePoint
- TOP_LEFT_FIELD - Static variable in class org.elasticsearch.common.geo.GeoBoundingBox
- TOP_RIGHT - Enum constant in enum class org.elasticsearch.common.geo.GeoUtils.EffectivePoint
- TOP_TERMS - Static variable in class org.elasticsearch.index.query.support.QueryParsers
- TOP_TERMS_BLENDED_FREQS - Static variable in class org.elasticsearch.index.query.support.QueryParsers
- TOP_TERMS_BOOST - Static variable in class org.elasticsearch.index.query.support.QueryParsers
- toPB(long) - Method in enum class org.elasticsearch.common.unit.ByteSizeUnit
- TopBucketBuilder<B extends InternalMultiBucketAggregation.InternalBucket> - Class in org.elasticsearch.search.aggregations
-
Merges many buckets into the "top" buckets as sorted by
BucketOrder
. - topDocs - Variable in class org.elasticsearch.common.lucene.search.TopDocsAndMaxScore
- topDocs() - Method in class org.elasticsearch.search.query.QuerySearchResult
- topDocs(TopDocsAndMaxScore, DocValueFormat[]) - Method in class org.elasticsearch.search.query.QuerySearchResult
- topDocs(SearchHit) - Method in class org.elasticsearch.search.fetch.subphase.InnerHitsContext.InnerHitSubContext
- TopDocsAndMaxScore - Class in org.elasticsearch.common.lucene.search
-
Wrapper around a
TopDocs
instance and the maximum score. - TopDocsAndMaxScore(TopDocs, float) - Constructor for class org.elasticsearch.common.lucene.search.TopDocsAndMaxScore
- toPeta(long) - Method in enum class org.elasticsearch.common.unit.SizeUnit
- topHits(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
TopHits
aggregation with the given name. - TopHits - Interface in org.elasticsearch.search.aggregations.metrics
-
Accumulation of the most relevant hits for a bucket this aggregation falls into.
- TopHitsAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- TopHitsAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- TopHitsAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Read from a stream.
- TopHitsAggregationBuilder(TopHitsAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
- topLeft() - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- topLeft() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Returns the top left corner of the bounding box.
- topLeft() - Method in interface org.elasticsearch.search.aggregations.metrics.GeoBounds
-
Get the top-left location of the bounding box.
- topLeft() - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- topLeft() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedGeoBounds
- topLevelQuery() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
-
The "top level" query that will filter the results sent to this Aggregator.
- topLevelQuery(Term[], TermStates[], int[], int) - Method in class org.apache.lucene.queries.BlendedTermQuery
- topLevelReader() - Method in class org.elasticsearch.search.fetch.FetchSubPhase.HitContext
- topLevelReduce(List<InternalAggregations>, InternalAggregation.ReduceContext) - Static method in class org.elasticsearch.search.aggregations.InternalAggregations
-
Begin the reduction process.
- toProvider(Class<? extends Provider<? extends T>>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - toProvider(Class<? extends Provider<? extends T>>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- toProvider(Key<? extends Provider<? extends T>>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - toProvider(Key<? extends Provider<? extends T>>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- toProvider(Provider<? extends T>) - Method in interface org.elasticsearch.common.inject.binder.LinkedBindingBuilder
-
See the EDSL examples at
Binder
. - toProvider(Provider<? extends T>) - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- toQuery(QueryBuilder) - Method in class org.elasticsearch.index.query.SearchExecutionContext
- toQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- toQuery(SearchExecutionContext) - Method in interface org.elasticsearch.index.query.QueryBuilder
-
Converts this QueryBuilder to a lucene
Query
. - toQuery(SearchExecutionContext) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- toQueryParserOperator() - Method in enum class org.elasticsearch.index.query.Operator
- toScriptCacheStats() - Method in class org.elasticsearch.script.ScriptStats
- toSerializable(LogEvent) - Method in class org.elasticsearch.common.logging.ESJsonLayout
- toShortExact(Number) - Static method in class org.elasticsearch.common.Numbers
-
Return the short that
n
stores, or throws an exception if the stored value cannot be converted to a short that stores the exact same value. - toSingleItemBulkRequest(ReplicatedWriteRequest<?>) - Static method in class org.elasticsearch.action.bulk.TransportSingleItemBulkWriteAction
-
Deprecated.
- toSingles(long) - Method in enum class org.elasticsearch.common.unit.SizeUnit
- toSortableLongBits(SortedNumericDoubleValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Given a
SortedNumericDoubleValues
, return aSortedNumericDocValues
instance that will translate double values to sortable long bits usingNumericUtils.doubleToSortableLong(double)
. - toSortedSet() - Static method in class org.elasticsearch.common.util.set.Sets
-
Returns a
Collector
that accumulates the input elements into a sorted set. - toString() - Method in class org.apache.lucene.geo.XTessellator.Node
- toString() - Method in class org.apache.lucene.geo.XTessellator.Triangle
-
pretty print the triangle vertices
- toString() - Method in class org.elasticsearch.action.ActionListener.Delegating
- toString() - Method in class org.elasticsearch.action.ActionListener.DelegatingActionListener
- toString() - Method in class org.elasticsearch.action.ActionListener.DelegatingFailureActionListener
- toString() - Method in class org.elasticsearch.action.ActionListener.MappedActionListener
- toString() - Method in class org.elasticsearch.action.ActionListener.RunAfterActionListener
- toString() - Method in class org.elasticsearch.action.ActionListener.RunBeforeActionListener
- toString() - Method in class org.elasticsearch.action.ActionListenerResponseHandler
- toString() - Method in class org.elasticsearch.action.ActionResponse.Empty
- toString() - Method in class org.elasticsearch.action.ActionRunnable
- toString() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.FeatureUpgradeStatus
- toString() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.IndexInfo
- toString() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse.Feature
- toString() - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse
- toString() - Method in enum class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.SortBy
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
- toString() - Method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
- toString() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
- toString() - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- toString() - Method in class org.elasticsearch.action.admin.cluster.stats.MappingStats
- toString() - Method in class org.elasticsearch.action.admin.cluster.stats.VersionStats
- toString() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptContextRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptLanguageRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- toString() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
- toString() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- toString() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Response
- toString() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.IndexResult
- toString() - Method in exception org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult.Failure
- toString() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult
- toString() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction.ShardRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.dangling.delete.DeleteDanglingIndexRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.dangling.find.FindDanglingIndexRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.dangling.import_index.ImportDanglingIndexRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats.PerFieldDiskUsage
- toString() - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- toString() - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.flush.ShardFlushRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetadata
- toString() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockResult
- toString() - Method in exception org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult.Failure
- toString() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult
- toString() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction.ShardRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.rollover.Condition
- toString() - Method in class org.elasticsearch.action.admin.indices.rollover.MetadataRolloverService.RolloverResult
- toString() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- toString() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateResponse
- toString() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction.Request
- toString() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
- toString() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest
- toString() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- toString() - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- toString() - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- toString() - Method in class org.elasticsearch.action.delete.DeleteRequest
- toString() - Method in class org.elasticsearch.action.delete.DeleteResponse
- toString() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
- toString() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
- toString() - Method in class org.elasticsearch.action.get.GetRequest
- toString() - Method in class org.elasticsearch.action.get.GetResponse
- toString() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- toString() - Method in class org.elasticsearch.action.index.IndexRequest
- toString() - Method in class org.elasticsearch.action.index.IndexResponse
- toString() - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- toString() - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- toString() - Method in class org.elasticsearch.action.main.MainResponse
- toString() - Method in class org.elasticsearch.action.OriginalIndices
- toString() - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- toString() - Method in class org.elasticsearch.action.search.MultiSearchResponse
- toString() - Method in class org.elasticsearch.action.search.SearchContextIdForNode
- toString() - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- toString() - Method in class org.elasticsearch.action.search.SearchRequest
- toString() - Method in class org.elasticsearch.action.search.SearchRequestBuilder
- toString() - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
- toString() - Method in class org.elasticsearch.action.search.SearchResponse
- toString() - Method in class org.elasticsearch.action.search.SearchScrollRequest
- toString() - Method in class org.elasticsearch.action.search.SearchShard
- toString() - Method in exception org.elasticsearch.action.search.ShardSearchFailure
- toString() - Method in class org.elasticsearch.action.support.ActiveShardCount
- toString() - Method in class org.elasticsearch.action.support.ChannelActionListener
- toString() - Method in exception org.elasticsearch.action.support.DefaultShardOperationFailedException
- toString() - Method in class org.elasticsearch.action.support.IndicesOptions
- toString() - Method in class org.elasticsearch.action.support.replication.BasicReplicationRequest
- toString() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- toString() - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- toString() - Method in class org.elasticsearch.action.support.replication.ReplicationTask.Status
- toString() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteReplicaRequest
- toString() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- toString() - Method in class org.elasticsearch.action.support.ThreadedActionListener
- toString() - Method in class org.elasticsearch.action.TaskOperationFailure
- toString() - Method in class org.elasticsearch.action.update.UpdateRequest
- toString() - Method in class org.elasticsearch.action.update.UpdateResponse
- toString() - Method in class org.elasticsearch.Build
- toString() - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.FailedShardEntry
- toString() - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.StartedShardEntry
- toString() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- toString() - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- toString() - Method in class org.elasticsearch.cluster.ClusterName
- toString() - Method in enum class org.elasticsearch.cluster.ClusterState.Metric
- toString() - Method in class org.elasticsearch.cluster.ClusterState
- toString() - Method in class org.elasticsearch.cluster.coordination.ApplyCommitRequest
- toString() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- toString() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfigExclusion
- toString() - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfiguration
- toString() - Method in class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- toString() - Method in class org.elasticsearch.cluster.coordination.ElectionSchedulerFactory
- toString() - Method in class org.elasticsearch.cluster.coordination.FollowersChecker.FollowerCheckRequest
- toString() - Method in class org.elasticsearch.cluster.coordination.FollowersChecker
- toString() - Method in class org.elasticsearch.cluster.coordination.Join
- toString() - Method in class org.elasticsearch.cluster.coordination.JoinRequest
- toString() - Method in class org.elasticsearch.cluster.coordination.JoinTaskExecutor.Task
- toString() - Method in class org.elasticsearch.cluster.coordination.LagDetector
- toString() - Method in class org.elasticsearch.cluster.coordination.NodeRemovalClusterStateTaskExecutor.Task
- toString() - Method in class org.elasticsearch.cluster.coordination.PeersResponse
- toString() - Method in class org.elasticsearch.cluster.coordination.PreVoteCollector
- toString() - Method in class org.elasticsearch.cluster.coordination.PreVoteRequest
- toString() - Method in class org.elasticsearch.cluster.coordination.PreVoteResponse
- toString() - Method in class org.elasticsearch.cluster.coordination.Publication
- toString() - Method in class org.elasticsearch.cluster.coordination.PublishRequest
- toString() - Method in class org.elasticsearch.cluster.coordination.PublishResponse
- toString() - Method in class org.elasticsearch.cluster.coordination.PublishWithJoinResponse
- toString() - Method in class org.elasticsearch.cluster.coordination.Reconfigurator
- toString() - Method in class org.elasticsearch.cluster.coordination.StartJoinRequest
- toString() - Method in class org.elasticsearch.cluster.DiskUsage
- toString() - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- toString() - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- toString() - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- toString() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- toString() - Method in class org.elasticsearch.cluster.metadata.AutoExpandReplicas
- toString() - Method in class org.elasticsearch.cluster.metadata.ComponentTemplate
- toString() - Method in class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- toString() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- toString() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- toString() - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
- toString() - Method in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- toString() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Tombstone
- toString() - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- toString() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- toString() - Method in class org.elasticsearch.cluster.metadata.ItemUsage
- toString() - Method in class org.elasticsearch.cluster.metadata.Manifest
- toString() - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
- toString() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
- toString() - Method in class org.elasticsearch.cluster.metadata.ShutdownPersistentTasksStatus
- toString() - Method in class org.elasticsearch.cluster.metadata.ShutdownPluginsStatus
- toString() - Method in class org.elasticsearch.cluster.metadata.ShutdownShardMigrationStatus
- toString() - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- toString() - Method in class org.elasticsearch.cluster.metadata.Template
- toString() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- toString() - Method in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
-
Generates a human-readable string for the DiscoverNodeFilters.
- toString() - Method in class org.elasticsearch.cluster.node.DiscoveryNodeRole
- toString() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
- toString() - Method in class org.elasticsearch.cluster.RepositoryCleanupInProgress.Entry
- toString() - Method in class org.elasticsearch.cluster.RepositoryCleanupInProgress
- toString() - Method in class org.elasticsearch.cluster.RestoreInProgress
- toString() - Method in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
- toString() - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
- toString() - Method in enum class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
- toString() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- toString() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- toString() - Method in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
- toString() - Method in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
- toString() - Method in class org.elasticsearch.cluster.routing.allocation.FailedShard
- toString() - Method in class org.elasticsearch.cluster.routing.allocation.StaleShard
- toString() - Method in class org.elasticsearch.cluster.routing.AllocationId
- toString() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
- toString() - Method in class org.elasticsearch.cluster.routing.RecoverySource.EmptyStoreRecoverySource
- toString() - Method in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- toString() - Method in class org.elasticsearch.cluster.routing.RecoverySource.LocalShardsRecoverySource
- toString() - Method in class org.elasticsearch.cluster.routing.RecoverySource.PeerRecoverySource
- toString() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- toString() - Method in class org.elasticsearch.cluster.routing.RoutingNode
- toString() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- toString() - Method in class org.elasticsearch.cluster.routing.RoutingTable
- toString() - Method in class org.elasticsearch.cluster.routing.ShardRouting
- toString() - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
- toString() - Method in class org.elasticsearch.cluster.service.ClusterApplierRecordingService.Stats.Recording
- toString() - Method in class org.elasticsearch.cluster.service.SourcePrioritizedRunnable
- toString() - Method in class org.elasticsearch.cluster.service.TaskBatcher.BatchedTask
- toString() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- toString() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- toString() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- toString() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- toString() - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- toString() - Method in class org.elasticsearch.common.blobstore.BlobPath
- toString() - Method in class org.elasticsearch.common.blobstore.fs.FsBlobStore
- toString() - Method in class org.elasticsearch.common.blobstore.support.PlainBlobMetadata
- toString() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- toString() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
- toString() - Method in class org.elasticsearch.common.component.Lifecycle
- toString() - Method in class org.elasticsearch.common.compress.CompressedXContent
- toString() - Method in class org.elasticsearch.common.document.DocumentField
- toString() - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- toString() - Method in class org.elasticsearch.common.geo.GeoPoint
- toString() - Method in class org.elasticsearch.common.hash.MurmurHash3.Hash128
- toString() - Method in class org.elasticsearch.common.inject.internal.BindingBuilder
- toString() - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.ConstantBindingBuilderImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.ExposureBuilder
- toString() - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.InternalFactory.Instance
- toString() - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.MatcherAndConverter
- toString() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.GenericArrayTypeImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.MemberImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.ParameterizedTypeImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.PrivateElementsImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- toString() - Method in class org.elasticsearch.common.inject.internal.ToStringBuilder
- toString() - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- toString() - Method in class org.elasticsearch.common.inject.Key
- toString() - Method in class org.elasticsearch.common.inject.multibindings.Multibinder.RealMultibinder
- toString() - Method in interface org.elasticsearch.common.inject.Scope
-
A short but useful description of this scope.
- toString() - Method in class org.elasticsearch.common.inject.spi.Dependency
- toString() - Method in class org.elasticsearch.common.inject.spi.InjectionPoint
- toString() - Method in class org.elasticsearch.common.inject.spi.Message
- toString() - Method in class org.elasticsearch.common.inject.spi.ProviderLookup.ProviderImpl
- toString() - Method in class org.elasticsearch.common.inject.TypeLiteral
- toString() - Method in class org.elasticsearch.common.LocalTimeOffset
- toString() - Method in class org.elasticsearch.common.logging.ESJsonLayout
- toString() - Method in class org.elasticsearch.common.lucene.FilterIndexCommit
- toString() - Method in class org.elasticsearch.common.lucene.RegExp
- toString() - Method in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- toString() - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreFunction
- toString() - Method in class org.elasticsearch.common.path.PathTrie.TrieNode
- toString() - Method in class org.elasticsearch.common.settings.SecureString
-
Convert to a
String
. - toString() - Method in class org.elasticsearch.common.settings.Setting.AffixKey
- toString() - Method in class org.elasticsearch.common.settings.Setting.SimpleKey
- toString() - Method in class org.elasticsearch.common.settings.Setting
- toString() - Method in class org.elasticsearch.common.settings.Settings
- toString() - Method in class org.elasticsearch.common.StopWatch
-
Return an informative string describing all tasks performed For custom reporting, call
getTaskInfo()
and use the task info directly. - toString() - Method in class org.elasticsearch.common.text.Text
- toString() - Method in class org.elasticsearch.common.time.WriteableZoneId
- toString() - Method in class org.elasticsearch.common.transport.BoundTransportAddress
- toString() - Method in class org.elasticsearch.common.transport.PortsRange
- toString() - Method in class org.elasticsearch.common.transport.TransportAddress
- toString() - Method in class org.elasticsearch.common.unit.ByteSizeValue
- toString() - Method in class org.elasticsearch.common.unit.DistanceUnit.Distance
- toString() - Method in enum class org.elasticsearch.common.unit.DistanceUnit
- toString() - Method in class org.elasticsearch.common.unit.RatioValue
- toString() - Method in class org.elasticsearch.common.unit.SizeValue
- toString() - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
- toString() - Method in class org.elasticsearch.common.util.LazyMap
- toString() - Method in class org.elasticsearch.common.util.URIPattern
- toString() - Method in class org.elasticsearch.discovery.PeersRequest
- toString() - Method in class org.elasticsearch.discovery.ProbeConnectionResult
- toString() - Method in class org.elasticsearch.discovery.zen.ElectMasterService.MasterCandidate
- toString() - Method in class org.elasticsearch.discovery.zen.PendingClusterStateStats
- toString() - Method in class org.elasticsearch.discovery.zen.PublishClusterStateStats
- toString() - Method in class org.elasticsearch.discovery.zen.ZenPing.PingResponse
- toString() - Method in exception org.elasticsearch.ElasticsearchException
- toString() - Method in class org.elasticsearch.env.NodeEnvironment.DataPath
- toString() - Method in class org.elasticsearch.env.NodeMetadata
- toString() - Method in class org.elasticsearch.env.ShardLock
- toString() - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- toString() - Method in class org.elasticsearch.http.CorsHandler.Config
- toString() - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
- toString() - Method in class org.elasticsearch.index.engine.Engine.CommitId
- toString() - Method in class org.elasticsearch.index.engine.Segment
- toString() - Method in class org.elasticsearch.index.engine.SegmentsStats.FileStats
- toString() - Method in class org.elasticsearch.index.get.GetResult
- toString() - Method in class org.elasticsearch.index.Index
- toString() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- toString() - Method in enum class org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
- toString() - Method in class org.elasticsearch.index.mapper.Mapping
- toString() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- toString() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.Range
- toString() - Method in class org.elasticsearch.index.mapper.Uid
- toString() - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- toString() - Method in class org.elasticsearch.index.query.DistanceFeatureQueryBuilder.Origin
- toString() - Method in class org.elasticsearch.index.query.InnerHitBuilder
- toString() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- toString() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- toString() - Method in class org.elasticsearch.index.recovery.RecoveryStats
- toString() - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- toString() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- toString() - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- toString() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- toString() - Method in class org.elasticsearch.index.reindex.ReindexRequest
- toString() - Method in class org.elasticsearch.index.reindex.RemoteInfo
- toString() - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- toString() - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- toString() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- toString() - Method in class org.elasticsearch.index.search.stats.FieldUsageStats
- toString() - Method in class org.elasticsearch.index.search.stats.SearchStats
- toString() - Method in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction.Request
- toString() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
- toString() - Method in class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- toString() - Method in class org.elasticsearch.index.seqno.RetentionLease
- toString() - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction.Request
- toString() - Method in class org.elasticsearch.index.seqno.RetentionLeases
- toString() - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Request
- toString() - Method in class org.elasticsearch.index.seqno.SeqNoStats
- toString() - Method in class org.elasticsearch.index.seqno.SequenceNumbers.CommitInfo
- toString() - Method in class org.elasticsearch.index.shard.IndexLongFieldRange
- toString() - Method in class org.elasticsearch.index.shard.IndexShard
- toString() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncRequest
- toString() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- toString() - Method in class org.elasticsearch.index.shard.ReplicationGroup
- toString() - Method in class org.elasticsearch.index.shard.ShardCountStats
- toString() - Method in class org.elasticsearch.index.shard.ShardId
- toString() - Method in class org.elasticsearch.index.shard.ShardLongFieldRange
- toString() - Method in class org.elasticsearch.index.shard.ShardPath
- toString() - Method in class org.elasticsearch.index.shard.ShardStateMetadata
- toString() - Method in class org.elasticsearch.index.similarity.ScriptedSimilarity
- toString() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
- toString() - Method in class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
- toString() - Method in class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Copy
- toString() - Method in class org.elasticsearch.index.store.Store.RecoveryDiff
- toString() - Method in class org.elasticsearch.index.store.StoreFileMetadata
- toString() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- toString() - Method in class org.elasticsearch.index.translog.Translog.Delete
- toString() - Method in class org.elasticsearch.index.translog.Translog.Index
- toString() - Method in class org.elasticsearch.index.translog.Translog.Location
- toString() - Method in class org.elasticsearch.index.translog.Translog.NoOp
- toString() - Method in class org.elasticsearch.index.translog.TranslogStats
- toString() - Method in class org.elasticsearch.indices.AssociatedIndexDescriptor
- toString() - Method in class org.elasticsearch.indices.breaker.BreakerSettings
- toString() - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- toString() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.InFlightOpsRequest
- toString() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.PreShardSyncedFlushRequest
- toString() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- toString() - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- toString() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- toString() - Method in class org.elasticsearch.indices.recovery.RecoverySourceHandler
- toString() - Method in class org.elasticsearch.indices.recovery.RecoveryState.FileDetail
- toString() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- toString() - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- toString() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodeStoreFilesMetadata
- toString() - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
- toString() - Method in class org.elasticsearch.indices.SystemIndexDescriptor
- toString() - Method in class org.elasticsearch.indices.TermsLookup
- toString() - Method in class org.elasticsearch.ingest.IngestDocument
- toString() - Method in class org.elasticsearch.ingest.PipelineConfiguration
- toString() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
- toString() - Method in class org.elasticsearch.monitor.StatusInfo
- toString() - Method in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- toString() - Method in class org.elasticsearch.persistent.decider.AssignmentDecision
- toString() - Method in enum class org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
- toString() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Assignment
- toString() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- toString() - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- toString() - Method in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- toString() - Method in class org.elasticsearch.plugins.ActionPlugin.ActionHandler
- toString() - Method in class org.elasticsearch.plugins.PluginDescriptor
- toString() - Method in enum class org.elasticsearch.plugins.PluginType
- toString() - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- toString() - Method in class org.elasticsearch.repositories.IndexId
- toString() - Method in class org.elasticsearch.repositories.IndexMetaDataGenerations
- toString() - Method in class org.elasticsearch.repositories.RepositoryCleanupResult
- toString() - Method in class org.elasticsearch.repositories.RepositoryInfo
- toString() - Method in class org.elasticsearch.repositories.RepositoryShardId
- toString() - Method in class org.elasticsearch.repositories.RepositoryStats
- toString() - Method in class org.elasticsearch.repositories.RepositoryStatsSnapshot
- toString() - Method in class org.elasticsearch.repositories.ShardGeneration
- toString() - Method in class org.elasticsearch.repositories.ShardGenerations
- toString() - Method in class org.elasticsearch.repositories.ShardSnapshotInfo
- toString() - Method in class org.elasticsearch.repositories.ShardSnapshotResult
- toString() - Method in class org.elasticsearch.repositories.VerificationFailure
- toString() - Method in class org.elasticsearch.script.DynamicMap
- toString() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- toString() - Method in class org.elasticsearch.script.Script
- toString() - Method in class org.elasticsearch.script.ScriptCache.CompilationRate
- toString() - Method in class org.elasticsearch.script.ScriptMetadata
- toString() - Method in enum class org.elasticsearch.script.ScriptType
- toString() - Method in class org.elasticsearch.script.StoredScriptSource
- toString() - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
- toString() - Method in class org.elasticsearch.search.aggregations.AggregatorBase
- toString() - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- toString() - Method in class org.elasticsearch.search.aggregations.bucket.DocCountProvider
- toString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- toString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- toString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DoubleBounds
- toString() - Method in class org.elasticsearch.search.aggregations.bucket.histogram.LongBounds
- toString() - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- toString() - Method in enum class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
- toString() - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic.LongAccessor
- toString() - Method in enum class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregatorFactory.ExecutionMode
- toString() - Method in enum class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregatorFactory.ExecutionMode
- toString() - Method in enum class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
- toString() - Method in class org.elasticsearch.search.aggregations.BucketOrder
- toString() - Method in class org.elasticsearch.search.aggregations.DelayedBucket
- toString() - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- toString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalGeoCentroid
- toString() - Method in class org.elasticsearch.search.aggregations.metrics.InternalValueCount
- toString() - Method in enum class org.elasticsearch.search.aggregations.metrics.PercentilesMethod
- toString() - Method in class org.elasticsearch.search.aggregations.MultiBucketCollector
- toString() - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator.PipelineTree
- toString() - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
- toString() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath.PathElement
- toString() - Method in class org.elasticsearch.search.aggregations.support.AggregationPath
- toString() - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- toString() - Method in enum class org.elasticsearch.search.aggregations.support.ValueType
- toString() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- toString() - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- toString() - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- toString() - Method in class org.elasticsearch.search.DocValueFormat.IpDocValueFormat
- toString() - Method in class org.elasticsearch.search.DocValueFormat.RawDocValueFormat
- toString() - Method in class org.elasticsearch.search.DocValueFormat.UnsignedLongShiftedDocValueFormat
- toString() - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- toString() - Method in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
- toString() - Method in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
- toString() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- toString() - Method in class org.elasticsearch.search.fetch.subphase.highlight.LimitTokenOffsetAnalyzer
- toString() - Method in class org.elasticsearch.search.internal.AliasFilter
- toString() - Method in class org.elasticsearch.search.internal.SearchContext
- toString() - Method in class org.elasticsearch.search.internal.ShardSearchContextId
- toString() - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- toString() - Method in enum class org.elasticsearch.search.profile.aggregation.AggregationTimingType
- toString() - Method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- toString() - Method in class org.elasticsearch.search.profile.ProfileResult
- toString() - Method in class org.elasticsearch.search.profile.query.CollectorResult
- toString() - Method in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- toString() - Method in enum class org.elasticsearch.search.profile.query.QueryTimingType
- toString() - Method in class org.elasticsearch.search.profile.SearchProfileResults
- toString() - Method in class org.elasticsearch.search.profile.SearchProfileShardResult
- toString() - Method in enum class org.elasticsearch.search.rescore.QueryRescoreMode
- toString() - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- toString() - Method in class org.elasticsearch.search.Scroll
- toString() - Method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- toString() - Method in class org.elasticsearch.search.SearchContextSourcePrinter
- toString() - Method in class org.elasticsearch.search.SearchHit.NestedIdentity
- toString() - Method in class org.elasticsearch.search.SearchHit
- toString() - Method in class org.elasticsearch.search.SearchShardTarget
- toString() - Method in class org.elasticsearch.search.slice.SliceBuilder
- toString() - Method in enum class org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
- toString() - Method in class org.elasticsearch.search.sort.SortBuilder
- toString() - Method in enum class org.elasticsearch.search.sort.SortMode
- toString() - Method in class org.elasticsearch.search.sort.SortValue
- toString() - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- toString() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping.InternalQueryContext
- toString() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- toString() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
- toString() - Method in class org.elasticsearch.search.suggest.DirectSpellcheckerSettings
- toString() - Method in class org.elasticsearch.search.suggest.phrase.Correction
- toString() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- toString() - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- toString() - Method in class org.elasticsearch.search.suggest.Suggest
- toString() - Method in class org.elasticsearch.search.suggest.SuggestBuilder
- toString() - Method in class org.elasticsearch.search.suggest.SuggestionSearchContext.SuggestionContext
- toString() - Method in class org.elasticsearch.snapshots.InternalSnapshotsInfoService.SnapshotShard
- toString() - Method in class org.elasticsearch.snapshots.RestoreInfo
- toString() - Method in class org.elasticsearch.snapshots.Snapshot
- toString() - Method in class org.elasticsearch.snapshots.SnapshotFeatureInfo
- toString() - Method in class org.elasticsearch.snapshots.SnapshotId
- toString() - Method in class org.elasticsearch.snapshots.SnapshotInfo.IndexSnapshotDetails
- toString() - Method in class org.elasticsearch.snapshots.SnapshotInfo
- toString() - Method in exception org.elasticsearch.snapshots.SnapshotShardFailure
- toString() - Method in class org.elasticsearch.snapshots.UpdateIndexShardSnapshotStatusRequest
- toString() - Method in class org.elasticsearch.tasks.RawTaskStatus
- toString() - Method in class org.elasticsearch.tasks.TaskId
- toString() - Method in class org.elasticsearch.tasks.TaskInfo
- toString() - Method in class org.elasticsearch.tasks.TaskResult
- toString() - Method in class org.elasticsearch.threadpool.Scheduler.ReschedulingRunnable
- toString() - Method in class org.elasticsearch.transport.Header
- toString() - Method in class org.elasticsearch.transport.InboundMessage
- toString() - Method in class org.elasticsearch.transport.PlainTransportFuture
- toString() - Method in class org.elasticsearch.transport.RequestHandlerRegistry
- toString() - Method in class org.elasticsearch.transport.ReuseBuffersLZ4BlockOutputStream
- toString() - Method in class org.elasticsearch.transport.TcpTransport.NodeChannels
- toString() - Method in class org.elasticsearch.transport.TransportRequest
- toString() - Method in class org.elasticsearch.transport.TransportResponse.Empty
- toString() - Method in class org.elasticsearch.transport.TransportService.ContextRestoreResponseHandler
- toString() - Method in class org.elasticsearch.upgrades.FeatureMigrationResults
- toString() - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskState
- toString() - Method in class org.elasticsearch.Version
- toString(double) - Method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Convert a value to a distance string
- toString(long) - Method in class org.elasticsearch.common.LocalTimeOffset.Gap
- toString(long) - Method in class org.elasticsearch.common.LocalTimeOffset.Overlap
- toString(long) - Method in class org.elasticsearch.common.LocalTimeOffset
- toString(Object) - Static method in class org.elasticsearch.common.lucene.BytesRefs
-
Converts a value to a string, taking special care if its a
BytesRef
to callBytesRef.utf8ToString()
. - toString(Member) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
-
Formats a member as concise string, such as
java.util.ArrayList.size
,java.util.ArrayList<init>()
orjava.util.List.remove()
. - toString(Type) - Static method in class org.elasticsearch.common.inject.internal.MoreTypes
- toString(String) - Method in class org.apache.lucene.queries.BinaryDocValuesRangeQuery
- toString(String) - Method in class org.apache.lucene.queries.BlendedTermQuery
- toString(String) - Method in class org.apache.lucene.queries.MinDocQuery
- toString(String) - Method in class org.apache.lucene.queries.SearchAfterSortedDocQuery
- toString(String) - Method in class org.apache.lucene.queries.SpanMatchNoDocsQuery
- toString(String) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- toString(String) - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreQuery
- toString(String) - Method in class org.elasticsearch.common.lucene.search.MoreLikeThisQuery
- toString(String) - Method in class org.elasticsearch.common.lucene.search.MultiPhrasePrefixQuery
- toString(String) - Method in class org.elasticsearch.index.query.DateRangeIncludingNowQuery
- toString(String) - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
- toString(String) - Method in class org.elasticsearch.plugins.PluginDescriptor
- toString(String) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- toString(String) - Method in class org.elasticsearch.search.aggregations.bucket.filter.MergedPointRangeQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.BooleanScriptFieldExistsQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.BooleanScriptFieldTermQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldExistsQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldRangeQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldTermQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldTermsQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.GeoPointScriptFieldDistanceFeatureQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.GeoPointScriptFieldExistsQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.GeoPointScriptFieldGeoShapeQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.IpScriptFieldExistsQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.IpScriptFieldRangeQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.IpScriptFieldTermQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.IpScriptFieldTermsQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.LongScriptFieldDistanceFeatureQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.LongScriptFieldExistsQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.LongScriptFieldRangeQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.LongScriptFieldTermQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.LongScriptFieldTermsQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.StringScriptFieldExistsQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.StringScriptFieldFuzzyQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.StringScriptFieldPrefixQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.StringScriptFieldRangeQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.StringScriptFieldRegexpQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.StringScriptFieldTermQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.StringScriptFieldTermsQuery
- toString(String) - Method in class org.elasticsearch.search.runtime.StringScriptFieldWildcardQuery
- toString(String) - Method in class org.elasticsearch.search.slice.SliceQuery
- toString(String, Locale) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
-
Deprecated.
- toString(String, SearchExecutionContext, String) - Static method in class org.elasticsearch.index.mapper.SourceValueFetcher
-
Creates a
SourceValueFetcher
that converts source values to strings. - toString(Set<String>) - Static method in class org.elasticsearch.index.mapper.SourceValueFetcher
-
Creates a
SourceValueFetcher
that converts source values to Strings - toString(SortedNumericDocValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Return a
String
representation of the provided values. - toString(SortedSetDocValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Return a
String
representation of the provided values. - toString(MultiGeoPointValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Return a
String
representation of the provided values. - toString(SortedNumericDoubleValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Return a
String
representation of the provided values. - toString(VersionType) - Static method in enum class org.elasticsearch.index.VersionType
- toString(ToXContent) - Static method in class org.elasticsearch.common.Strings
-
Return a
String
that is the json representation of the providedToXContent
. - toString(ToXContent.Params) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- toString(ToXContent, boolean, boolean) - Static method in class org.elasticsearch.common.Strings
-
Return a
String
that is the json representation of the providedToXContent
. - toString(ToXContent, ToXContent.Params) - Static method in class org.elasticsearch.common.Strings
-
Return a
String
that is the json representation of the providedToXContent
. - toString(XContentBuilder) - Static method in class org.elasticsearch.common.Strings
-
Returns a string representation of the builder (only applicable for text based xcontent).
- toStringArray(Collection<String>) - Static method in class org.elasticsearch.common.Strings
-
Copy the given Collection into a String array.
- ToStringBuilder - Class in org.elasticsearch.common.inject.internal
-
Helps with
toString()
methods. - ToStringBuilder(Class<?>) - Constructor for class org.elasticsearch.common.inject.internal.ToStringBuilder
- ToStringBuilder(String) - Constructor for class org.elasticsearch.common.inject.internal.ToStringBuilder
- total() - Method in class org.elasticsearch.index.warmer.WarmerStats
-
The total number of warmer executed.
- Total - Enum constant in enum class org.elasticsearch.search.rescore.QueryRescoreMode
- TOTAL - Enum constant in enum class org.elasticsearch.monitor.jvm.HotThreads.SortOrder
- TOTAL - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- TOTAL - Static variable in class org.elasticsearch.search.SearchHits.Fields
- TOTAL_CIRCUIT_BREAKER_LIMIT_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- TOTAL_DATA_SET_SIZE_SIZE_VERSION - Static variable in class org.elasticsearch.index.store.StoreStats
- TOTAL_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- TOTAL_FIELD - Static variable in class org.elasticsearch.rest.action.RestActions
- TOTAL_HITS_AS_INT_PARAM - Static variable in class org.elasticsearch.rest.action.search.RestSearchAction
-
Indicates whether hits.total should be rendered as an integer or an object in the rest search response.
- TOTAL_IN_BYTES - Static variable in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- totalBytes() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
total number of bytes in th shard
- totalCount() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- totalDataSetSize() - Method in class org.elasticsearch.index.store.StoreStats
- totalDataSetSizeInBytes() - Method in class org.elasticsearch.index.store.StoreStats
- totalFileCount() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns total number of files that are referenced by this snapshot
- totalFileCount() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
total number of files that are part of this recovery, both re-used and recovered
- totalFilesSize() - Method in exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
- totalHits - Variable in class org.elasticsearch.search.internal.ScrollContext
- totalLocal() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- totalLocal(int) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
-
Sets the total number of translog operations to be recovered locally before performing peer recovery
- totalOperations() - Method in class org.elasticsearch.index.translog.BaseTranslogReader
- totalOperations() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
-
The total estimated number of operations in the snapshot.
- totalOperations() - Method in class org.elasticsearch.index.translog.Translog
-
Returns the number of operations in the translog files
- totalOperations() - Method in class org.elasticsearch.index.translog.TranslogReader
- totalOperations() - Method in class org.elasticsearch.index.translog.TranslogWriter
- totalOperations() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
-
returns the total number of translog operations needed to be recovered at this moment.
- totalOperations(int) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- totalOperationsByMinGen(long) - Method in class org.elasticsearch.index.translog.Translog
-
Returns the number of operations in the translog files at least the given generation
- totalOperationsOnStart() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
-
returns the total number of translog operations to recovered, on the start of the recovery.
- totalOperationsOnStart(int) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- totalRecoverBytes() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
total bytes of files to be recovered (potentially not yet done)
- totalRecoverFiles() - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
-
total number of files to be recovered (potentially not yet done)
- totalShards() - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
-
total number shards, including replicas, both assigned and unassigned
- totalShards() - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- totalShards() - Method in class org.elasticsearch.repositories.ShardGenerations
-
Returns the total number of shards tracked by this instance.
- totalShards() - Method in class org.elasticsearch.snapshots.RestoreInfo
-
Number of shards being restored
- totalShards() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns total number of shards that were snapshotted; a value of
0
will be returned ifSnapshotInfo.state()
returnsnull
. - totalSize() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
-
Returns the total number of shards within all groups
- totalSize() - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Returns total size of all files that where snapshotted
- totalSize() - Method in class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
- totalSize(List<BlobStoreIndexShardSnapshot.FileInfo>) - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
- totalSizeWith1ForEmpty() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
-
Returns the total number of shards plus the number of empty groups
- totalTermFreq() - Method in class org.elasticsearch.common.lucene.index.FilterableTermsEnum
- totalTime() - Method in class org.elasticsearch.common.StopWatch
-
Return the total time for all tasks.
- totalTime() - Method in class org.elasticsearch.index.warmer.WarmerStats
-
The total time warmer have been executed.
- totalTimeInMillis() - Method in class org.elasticsearch.index.warmer.WarmerStats
-
The total time warmer have been executed (in milliseconds).
- totalTranslogOps() - Method in class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- totalTranslogOps() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- totalTranslogOps() - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- toTB(long) - Method in enum class org.elasticsearch.common.unit.ByteSizeUnit
- toTera(long) - Method in enum class org.elasticsearch.common.unit.SizeUnit
- toUnmodifiableOrderedMap(Function<T, ? extends K>, Function<T, ? extends V>) - Static method in class org.elasticsearch.common.util.Maps
-
Returns a
Collector
that accumulates the input elements into a linked hash map and finishes the resulting set into an unmodifiable map. - toUnmodifiableSortedMap(Function<T, ? extends K>, Function<T, ? extends V>) - Static method in class org.elasticsearch.common.util.Maps
-
Returns a
Collector
that accumulates the input elements into a sorted map and finishes the resulting set into an unmodifiable sorted map. - toUnmodifiableSortedSet() - Static method in class org.elasticsearch.common.util.set.Sets
-
Returns a
Collector
that accumulates the input elements into a sorted set and finishes the resulting set into an unmodifiable set. - toUriString(InetAddress) - Static method in class org.elasticsearch.common.network.InetAddresses
-
Returns the string representation of an
InetAddress
suitable for inclusion in a URI. - toUTF8Bytes(CharSequence) - Static method in class org.elasticsearch.common.Strings
- toUTF8Bytes(CharSequence, BytesRefBuilder) - Static method in class org.elasticsearch.common.Strings
- toXContent(String, XContentBuilder) - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
- toXContent(EnumSet<IndicesOptions.WildcardStates>, XContentBuilder) - Static method in enum class org.elasticsearch.action.support.IndicesOptions.WildcardStates
- toXContent(AliasMetadata, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.AliasMetadata.Builder
- toXContent(IndexMetadata, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- toXContent(IndexTemplateMetadata, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
-
Serializes the template to xContent, making sure not to nest mappings under the type name.
- toXContent(Metadata, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- toXContent(RepositoryMetadata, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
-
Serializes information about a single repository
- toXContent(RestoreInProgress.Entry, XContentBuilder) - Method in class org.elasticsearch.cluster.RestoreInProgress
-
Serializes single restore operation
- toXContent(Geometry, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.common.geo.GeoJson
- toXContent(Geometry, XContentBuilder, ToXContent.Params) - Method in enum class org.elasticsearch.common.geo.GeometryParserFormat
-
Serializes the geometry into its JSON representation
- toXContent(BlobStoreIndexShardSnapshot.FileInfo, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
-
Serializes file info into JSON
- toXContent(CompositeValuesSourceBuilder<?>, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceParserHelper
- toXContent(ToXContent, XContentType, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Returns the bytes that represent the XContent output of the provided
ToXContent
object, using the providedXContentType
. - toXContent(ToXContent, XContentType, ToXContent.Params, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Returns the bytes that represent the XContent output of the provided
ToXContent
object, using the providedXContentType
. - toXContent(XContentBuilder, boolean) - Method in class org.elasticsearch.index.mapper.FieldMapper.Parameter
- toXContent(XContentBuilder, String, String, String) - Method in class org.elasticsearch.common.FieldMemoryStats
-
Generates x-content into the given builder for each of the fields in this stats instance
- toXContent(XContentBuilder, DocValueFormat) - Method in class org.elasticsearch.search.sort.SortValue
-
Write the key as xcontent.
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ActionResponse.Empty
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.FeatureUpgradeStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.IndexInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse.Feature
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TaskGroup
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse.SnapshottableFeature
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotShardsStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices.ShardStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsIndices
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.Counts
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.JvmStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.OsStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes.ProcessStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodes
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.FieldScriptStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.IndexFeatureStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.MappingStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.RuntimeFieldStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.stats.VersionStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptContextResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptLanguageResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeToken
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeTokenList
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.CharFilteredText
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.DetailAnalyzeResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Response
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.IndexResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats.PerFieldDiskUsage
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse.FieldMappingMetadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedAlias
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedDataStream
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedIndex
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Response
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxPrimaryShardSizeCondition
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageShardResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Response
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Response
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.bulk.BulkItemResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.bulk.BulkResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.datastreams.ModifyDataStreamsAction.Request
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.DocWriteResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.explain.ExplainRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.explain.ExplainResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesFailure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.get.GetResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.get.MultiGetRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.get.MultiGetResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.main.MainResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.ClearScrollResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.ClosePointInTimeRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.MultiSearchResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.OpenPointInTimeResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.SearchResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.SearchResponseSections
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.SearchScrollRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.search.ShardSearchFailure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.support.DefaultShardOperationFailedException
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.IndicesOptions
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.replication.ReplicationTask.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.TaskOperationFailure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.update.UpdateRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.block.ClusterBlock
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.ClusterInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in interface org.elasticsearch.cluster.ClusterState.Custom
-
Serialize this
ClusterState.Custom
for diagnostic purposes, exposed by the - toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.ClusterState
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.coordination.ClusterStateSerializationStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfigExclusion
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfiguration
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownCondition
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownMetadataCustom
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.DiskUsage
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.ComponentTemplate
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.DataStream.TimestampField
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.DataStream
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.DataStreamAction
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Tombstone
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.ItemUsage
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.Manifest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.Metadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.ShutdownPersistentTasksStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.ShutdownPluginsStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.ShutdownShardMigrationStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.metadata.Template
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.RepositoryCleanupInProgress
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.RestoreInProgress
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.RerouteExplanation
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.AllocationId
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.RecoverySource
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.ShardRouting
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.service.ClusterApplierRecordingService.Stats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.bytes.AbstractBytesReference
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.geo.GeoPoint
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.settings.Setting
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.settings.Settings
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.text.Text
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.time.WriteableZoneId
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.transport.TransportAddress
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.unit.ByteSizeValue
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.common.unit.Fuzziness
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.discovery.DiscoveryStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.discovery.zen.PendingClusterStateStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.discovery.zen.PublishClusterStateStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.ElasticsearchException
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.http.HttpInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.http.HttpStats.ClientStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.http.HttpStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.analysis.NameOrDefinition
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.engine.CommitStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.engine.SegmentsStats.FileStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.engine.SegmentsStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.flush.FlushStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.get.GetResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.get.GetStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.Index
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.CompositeRuntimeField
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.DynamicTemplate
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.FieldMapper.Builder
-
Writes the current builder parameter values as XContent
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.FieldMapper.CopyTo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.FieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.LeafRuntimeField
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.Mapping
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.MetadataFieldMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.NestedObjectMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.merge.MergeStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Combine
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Disjunction
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Fuzzy
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.IntervalFilter
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Match
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Prefix
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Wildcard
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.refresh.RefreshStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.ReindexRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.RemoteInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.search.stats.FieldUsageStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.search.stats.SearchStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.seqno.RetentionLease
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.seqno.RetentionLeases
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.seqno.RetentionLeaseStats
-
Converts the retention lease stats to
XContent
using the specified builder and pararms. - toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.seqno.SeqNoStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.shard.DocsStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.shard.IndexingStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.shard.IndexLongFieldRange
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.shard.ShardCountStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.shard.ShardId
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot
-
Serializes shard snapshot metadata info into JSON
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
-
Writes index file for the shard in the following format.
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.stats.IndexingPressureStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.store.StoreStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.translog.TranslogStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.warmer.WarmerStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.NodeIndicesStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.recovery.RecoveryState.FileDetail
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.recovery.RecoveryState
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.indices.TermsLookup
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.ingest.IngestInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.ingest.IngestMetadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.ingest.IngestStats.Stats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.ingest.IngestStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.ingest.PipelineConfiguration
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.ingest.ProcessorInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.fs.FsInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.jvm.JvmStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup.CpuStat
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsStats.Swap
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.os.OsStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.process.ProcessInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.monitor.process.ProcessStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.node.AdaptiveSelectionStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.plugins.PluginDescriptor
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.repositories.IndexId
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.repositories.RepositoryCleanupResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.repositories.RepositoryInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.repositories.RepositoryStatsSnapshot
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.repositories.ShardGeneration
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.Script
-
This will build scripts into the following XContent structure:
{ "<(id, source)>" : "<idOrCode>", "lang" : "<lang>", "options" : { "option0" : "<option0>", "option1" : "<option1>", ... }, "params" : { "param0" : "<param0>", "param1" : "<param1>", ... } }
Example:{ "source" : "return Math.log(doc.popularity) * params.multiplier;", "lang" : "painless", "params" : { "multiplier" : 100.0 } }
Note that lang, options, and params will only be included if there have been any specified. - toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.ScriptCacheStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo.ParameterInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.ScriptContextInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.ScriptContextStats.TimeSeries
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.ScriptContextStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.ScriptLanguagesInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.ScriptMetadata
-
This will write XContent from
ScriptMetadata
. - toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.ScriptStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.script.StoredScriptSource
-
This will write XContent from a
StoredScriptSource
. - toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.Aggregations
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite.InternalBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.composite.ParsedComposite.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.filter.ParsedFilters.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DoubleBounds
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.LongBounds
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.ParsedVariableWidthHistogram.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.IpRangeAggregationBuilder.Range
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedBinaryRange.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.ParsedRange.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ChiSquare.ChiSquareBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ChiSquare
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.GND.GNDBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.GND
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.JLHScore.JLHScoreBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.JLHScore
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.MutualInformation.MutualInformationBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.MutualInformation
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.PercentageScore.PercentageScoreBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.PercentageScore
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedRareTerms.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedSignificantTerms.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.ParsedTerms.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.InternalOrder.Aggregation
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.InternalOrder.CompoundOrder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.Hdr
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.TDigest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.ParsedAggregation
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.ParsedMultiBucketAggregation.ParsedBucket
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel.EWMAModelBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel.HoltLinearModelBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.HoltWintersModelBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel.LinearModelBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel.SimpleModelBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.support.AggregationInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.builder.PointInTimeBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.IndexBoost
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.fetch.subphase.FieldAndFormat
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.ProfileResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.query.CollectorResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.SearchProfileResults
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.profile.SearchProfileShardResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.SearchHit.NestedIdentity
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.SearchHit
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.SearchHits
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.SearchSortValues
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.slice.SliceBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.sort.NestedSortBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.CategoryQueryContext
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMappings
-
Writes a list of objects specified by the defined
ContextMapping
s seeContextMapping.toXContent(XContentBuilder, Params)
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.context.GeoQueryContext
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.completion.RegexOptions
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.phrase.SmoothingModel
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.Suggest
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.RestoreInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.SnapshotFeatureInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.SnapshotId
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.SnapshotInfo.IndexSnapshotDetails
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.SnapshotInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in exception org.elasticsearch.snapshots.SnapshotShardFailure
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.tasks.RawTaskStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.tasks.TaskInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.tasks.TaskResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.threadpool.ThreadPoolStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.transport.ProxyConnectionStrategy.ProxyModeInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.transport.SniffConnectionStrategy.SniffModeInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.transport.TransportInfo
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.transport.TransportStats
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.upgrades.FeatureMigrationResults
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.upgrades.SingleFeatureMigrationResult
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskParams
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskState
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.Version
- toXContent(XContentBuilder, T) - Method in class org.elasticsearch.gateway.MetadataStateFormat
-
Writes the given state to the given XContentBuilder Subclasses need to implement this class for theirs specific state.
- toXContentCommon(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
- toXContentEmbedded(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.get.GetResult
- toXContentExternal(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Serialize this
SnapshotInfo
for external consumption, i.e. - toXContentFragment(CompositeAggregation, XContentBuilder, ToXContent.Params) - Static method in interface org.elasticsearch.search.aggregations.bucket.composite.CompositeAggregation
- toXContentFragment(XContentBuilder, boolean) - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- toXContentGroupedByNode(XContentBuilder, ToXContent.Params, DiscoveryNodes) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
Convert this task response to XContent grouping by executing nodes.
- toXContentGroupedByNone(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
Presents a flat list of tasks
- toXContentGroupedByParents(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
-
Convert this response to XContent grouping by parent tasks.
- toXContentInternal(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.aggregations.Aggregations
-
Directly write all the aggregations without their bounding object.
- toXContentWithTypes(IndexTemplateMetadata, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
-
Serializes the template to xContent, using the legacy format where the mappings are nested under the type name.
- TRACE - Enum constant in enum class org.elasticsearch.index.SlowLogLevel
- TRACE - Enum constant in enum class org.elasticsearch.rest.RestRequest.Method
- TRACE_ENABLED - Static variable in class org.elasticsearch.transport.NetworkTraceFlag
- TRACE_ID - Static variable in class org.elasticsearch.tasks.Task
-
Parsed part of traceparent.
- TRACE_LOG_EXCLUDE_SETTING - Static variable in class org.elasticsearch.transport.TransportSettings
- TRACE_LOG_INCLUDE_SETTING - Static variable in class org.elasticsearch.transport.TransportSettings
- TRACE_PARENT_HTTP_HEADER - Static variable in class org.elasticsearch.tasks.Task
-
The request header which is contained in HTTP request.
- TraceIdConverter - Class in org.elasticsearch.common.logging
-
Pattern converter to format the trace id provided in the traceparent header into JSON fields
trace.id
. - TraceIdConverter() - Constructor for class org.elasticsearch.common.logging.TraceIdConverter
- TRACK_SCORES_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- TRACK_TOTAL_HITS_ACCURATE - Static variable in class org.elasticsearch.search.internal.SearchContext
- TRACK_TOTAL_HITS_DISABLED - Static variable in class org.elasticsearch.search.internal.SearchContext
- TRACK_TOTAL_HITS_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- TrackingResultProcessor - Class in org.elasticsearch.ingest
-
Processor to be used within Simulate API to keep track of processors executed in pipeline.
- trackResponseAndCheckIfLast(int, Object) - Method in class org.elasticsearch.action.support.NodeResponseTracker
-
This method stores a new node response if the intermediate responses haven't been discarded yet.
- trackScores() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Indicates whether scores will be tracked for this request.
- trackScores() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicates whether scores will be tracked for this request.
- trackScores() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- trackScores() - Method in class org.elasticsearch.search.internal.SearchContext
- trackScores() - Method in class org.elasticsearch.search.internal.SubSearchContext
- trackScores(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Applies when sorting, and controls if scores will be tracked as well.
- trackScores(boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Applies when sorting, and controls if scores will be tracked as well.
- trackScores(boolean) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- trackScores(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
- trackScores(boolean) - Method in class org.elasticsearch.search.internal.SubSearchContext
- trackTotalHits(boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicates if the total hit count for the query should be tracked.
- trackTotalHitsUpTo() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Returns the total hit count that should be tracked or null if the value is unset.
- trackTotalHitsUpTo() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- trackTotalHitsUpTo() - Method in class org.elasticsearch.search.internal.SearchContext
-
Indicates the total number of hits to count accurately.
- trackTotalHitsUpTo(int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- trackTotalHitsUpTo(int) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- trackTotalHitsUpTo(int) - Method in class org.elasticsearch.search.internal.SearchContext
- tragedy - Variable in class org.elasticsearch.index.translog.Translog
- TragicExceptionHolder - Class in org.elasticsearch.index.translog
- TragicExceptionHolder() - Constructor for class org.elasticsearch.index.translog.TragicExceptionHolder
- TRANSIENT - Enum constant in enum class org.elasticsearch.common.breaker.CircuitBreaker.Durability
- transientSettings() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Deprecated.Transient settings are in the process of being removed. Use persistent settings to update your cluster settings instead.
- transientSettings() - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- transientSettings() - Method in class org.elasticsearch.cluster.metadata.Metadata
- transientSettings(String, XContentType) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Deprecated.Transient settings are in the process of being removed. Use persistent settings to update your cluster settings instead.
- transientSettings(Map<String, ?>) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Deprecated.Transient settings are in the process of being removed. Use persistent settings to update your cluster settings instead.
- transientSettings(Settings) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Deprecated.Transient settings are in the process of being removed. Use persistent settings to update your cluster settings instead.
- transientSettings(Settings) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- transientSettings(Settings.Builder) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
-
Deprecated.Transient settings are in the process of being removed. Use persistent settings to update your cluster settings instead.
- translog - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- translog() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- translog(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- Translog - Class in org.elasticsearch.index.translog
-
A Translog is a per index shard component that records all non-committed index operations in a durable manner.
- Translog - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- Translog() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Translog
- Translog(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.Translog
- Translog(TranslogConfig, String, TranslogDeletionPolicy, LongSupplier, LongSupplier, LongConsumer) - Constructor for class org.elasticsearch.index.translog.Translog
-
Creates a new Translog instance.
- TRANSLOG - Enum constant in enum class org.elasticsearch.index.engine.Engine.HistorySource
- TRANSLOG - Enum constant in enum class org.elasticsearch.indices.recovery.RecoveryState.Stage
-
starting up the engine, replaying the translog
- TRANSLOG_FILE_PREFIX - Static variable in class org.elasticsearch.index.translog.Translog
- TRANSLOG_FILE_SUFFIX - Static variable in class org.elasticsearch.index.translog.Translog
- TRANSLOG_FOLDER_NAME - Static variable in class org.elasticsearch.index.shard.ShardPath
- TRANSLOG_OPS - Static variable in class org.elasticsearch.indices.recovery.PeerRecoveryTargetService.Actions
- TRANSLOG_UUID_KEY - Static variable in class org.elasticsearch.index.translog.Translog
- Translog.Delete - Class in org.elasticsearch.index.translog
- Translog.Durability - Enum Class in org.elasticsearch.index.translog
- Translog.Index - Class in org.elasticsearch.index.translog
- Translog.Location - Class in org.elasticsearch.index.translog
- Translog.NoOp - Class in org.elasticsearch.index.translog
- Translog.Operation - Interface in org.elasticsearch.index.translog
-
A generic interface representing an operation performed on the transaction log.
- Translog.Operation.Type - Enum Class in org.elasticsearch.index.translog
- Translog.Snapshot - Interface in org.elasticsearch.index.translog
-
A snapshot of the transaction log, allows to iterate over all the transaction log operations.
- Translog.Source - Class in org.elasticsearch.index.translog
- Translog.TranslogGeneration - Class in org.elasticsearch.index.translog
-
References a transaction log generation
- TranslogConfig - Class in org.elasticsearch.index.translog
- TranslogConfig(ShardId, Path, IndexSettings, BigArrays) - Constructor for class org.elasticsearch.index.translog.TranslogConfig
-
Creates a new TranslogConfig instance
- TranslogCorruptedException - Exception in org.elasticsearch.index.translog
- TranslogCorruptedException(String, String) - Constructor for exception org.elasticsearch.index.translog.TranslogCorruptedException
- TranslogCorruptedException(String, String, Throwable) - Constructor for exception org.elasticsearch.index.translog.TranslogCorruptedException
- TranslogCorruptedException(String, Throwable) - Constructor for exception org.elasticsearch.index.translog.TranslogCorruptedException
- TranslogCorruptedException(StreamInput) - Constructor for exception org.elasticsearch.index.translog.TranslogCorruptedException
- TranslogDeletionPolicy - Class in org.elasticsearch.index.translog
- TranslogDeletionPolicy(long, long, int) - Constructor for class org.elasticsearch.index.translog.TranslogDeletionPolicy
- TranslogException - Exception in org.elasticsearch.index.translog
- TranslogException(StreamInput) - Constructor for exception org.elasticsearch.index.translog.TranslogException
- TranslogException(ShardId, String) - Constructor for exception org.elasticsearch.index.translog.TranslogException
- TranslogException(ShardId, String, Throwable) - Constructor for exception org.elasticsearch.index.translog.TranslogException
- translogFileGeneration - Variable in class org.elasticsearch.index.translog.Translog.TranslogGeneration
- TranslogGeneration(String, long) - Constructor for class org.elasticsearch.index.translog.Translog.TranslogGeneration
- translogGetCount - Variable in class org.elasticsearch.index.engine.InternalEngine
- translogInMemorySegmentsCount - Variable in class org.elasticsearch.index.engine.InternalEngine
- translogLocation - Variable in class org.elasticsearch.index.translog.Translog.Location
- TranslogReader - Class in org.elasticsearch.index.translog
-
an immutable translog filereader
- translogStats - Variable in class org.elasticsearch.index.engine.ReadOnlyEngine
- translogStats() - Method in class org.elasticsearch.index.shard.IndexShard
- TranslogStats - Class in org.elasticsearch.index.translog
- TranslogStats() - Constructor for class org.elasticsearch.index.translog.TranslogStats
- TranslogStats(int, long, int, long, long) - Constructor for class org.elasticsearch.index.translog.TranslogStats
- TranslogStats(StreamInput) - Constructor for class org.elasticsearch.index.translog.TranslogStats
- translogUUID - Variable in class org.elasticsearch.index.translog.Translog.TranslogGeneration
- TranslogWriter - Class in org.elasticsearch.index.translog
- transport - Variable in class org.elasticsearch.transport.TransportService
- Transport - Interface in org.elasticsearch.transport
- TRANSPORT - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
- TRANSPORT - Enum constant in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
- TRANSPORT_CLIENT_FEATURE - Static variable in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.
- TRANSPORT_COMPRESS - Static variable in class org.elasticsearch.transport.TransportSettings
- TRANSPORT_COMPRESSION_SCHEME - Static variable in class org.elasticsearch.transport.TransportSettings
- TRANSPORT_DEFAULT_TYPE_SETTING - Static variable in class org.elasticsearch.common.network.NetworkModule
- TRANSPORT_TYPE_DEFAULT_KEY - Static variable in class org.elasticsearch.common.network.NetworkModule
- TRANSPORT_TYPE_KEY - Static variable in class org.elasticsearch.common.network.NetworkModule
- TRANSPORT_TYPE_SETTING - Static variable in class org.elasticsearch.common.network.NetworkModule
- TRANSPORT_WORKER_THREAD_NAME_PREFIX - Static variable in class org.elasticsearch.transport.TcpTransport
- Transport.Connection - Interface in org.elasticsearch.transport
-
A unidirectional connection to a
DiscoveryNode
- Transport.RequestHandlers - Class in org.elasticsearch.transport
- Transport.ResponseContext<T extends TransportResponse> - Class in org.elasticsearch.transport
-
This class represents a response context that encapsulates the actual response handler, the action and the connection it was executed on.
- Transport.ResponseHandlers - Class in org.elasticsearch.transport
-
This class is a registry that allows
- TransportAction<Request extends ActionRequest,
Response extends ActionResponse> - Class in org.elasticsearch.action.support - TransportAction(String, ActionFilters, Transport.Connection, TaskManager) - Constructor for class org.elasticsearch.action.support.TransportAction
- TransportAction(ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, IndicesService) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.Add.TransportAction
- TransportAction(ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, IndicesService) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.Remove.TransportAction
- TransportAction(ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, IndicesService) - Constructor for class org.elasticsearch.index.seqno.RetentionLeaseActions.Renew.TransportAction
- TransportAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.TransportAction
- TransportAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, MetadataCreateIndexService, MetadataCreateDataStreamService, AutoCreateIndex, SystemIndices) - Constructor for class org.elasticsearch.action.admin.indices.create.AutoCreateAction.TransportAction
- TransportAction(TransportService, ClusterService, ThreadPool, ActionFilters, PersistentTasksClusterService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.persistent.CompletionPersistentTaskAction.TransportAction
- TransportAction(TransportService, ClusterService, ThreadPool, ActionFilters, PersistentTasksClusterService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.persistent.RemovePersistentTaskAction.TransportAction
- TransportAction(TransportService, ClusterService, ThreadPool, ActionFilters, PersistentTasksClusterService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.TransportAction
- TransportAction(TransportService, ClusterService, ThreadPool, ActionFilters, PersistentTasksClusterService, PersistentTasksExecutorRegistry, PersistentTasksService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.persistent.StartPersistentTaskAction.TransportAction
- TransportActionNodeProxy<Request extends ActionRequest,
Response extends ActionResponse> - Class in org.elasticsearch.action -
A generic proxy that will execute the given action against a specific node.
- TransportActionNodeProxy(ActionType<Response>, TransportService) - Constructor for class org.elasticsearch.action.TransportActionNodeProxy
- TransportActionProxy - Class in org.elasticsearch.transport
-
TransportActionProxy allows an arbitrary action to be executed on a defined target node while the initial request is sent to a second node that acts as a request proxy to the target node.
- TransportActions - Class in org.elasticsearch.action.support
- TransportActions() - Constructor for class org.elasticsearch.action.support.TransportActions
- TransportAddIndexBlockAction - Class in org.elasticsearch.action.admin.indices.readonly
-
Adds a single index level block to a given set of indices.
- TransportAddIndexBlockAction(TransportService, ClusterService, ThreadPool, MetadataIndexStateService, ActionFilters, IndexNameExpressionResolver, DestructiveOperations) - Constructor for class org.elasticsearch.action.admin.indices.readonly.TransportAddIndexBlockAction
- TransportAddress - Class in org.elasticsearch.common.transport
-
A transport address used for IP socket address (wraps
InetSocketAddress
). - TransportAddress(InetAddress, int) - Constructor for class org.elasticsearch.common.transport.TransportAddress
- TransportAddress(InetSocketAddress) - Constructor for class org.elasticsearch.common.transport.TransportAddress
- TransportAddress(StreamInput) - Constructor for class org.elasticsearch.common.transport.TransportAddress
-
Read from a stream.
- TransportAddressConnector - Interface in org.elasticsearch.discovery
- transportAddresses() - Method in class org.elasticsearch.client.transport.TransportClient
-
Deprecated.Returns the current registered transport addresses to use (added using
TransportClient.addTransportAddress(org.elasticsearch.common.transport.TransportAddress)
. - TransportAddVotingConfigExclusionsAction - Class in org.elasticsearch.action.admin.cluster.configuration
- TransportAddVotingConfigExclusionsAction(Settings, ClusterSettings, TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.TransportAddVotingConfigExclusionsAction
- TransportAliasesExistAction - Class in org.elasticsearch.action.admin.indices.alias.exists
- TransportAliasesExistAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.alias.exists.TransportAliasesExistAction
- TransportAnalyzeAction - Class in org.elasticsearch.action.admin.indices.analyze
-
Transport action used to execute analyze requests
- TransportAnalyzeAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.analyze.TransportAnalyzeAction
- TransportAnalyzeIndexDiskUsageAction - Class in org.elasticsearch.action.admin.indices.diskusage
- TransportAnalyzeIndexDiskUsageAction(ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.diskusage.TransportAnalyzeIndexDiskUsageAction
- TransportAutoPutMappingAction - Class in org.elasticsearch.action.admin.indices.mapping.put
- TransportAutoPutMappingAction(TransportService, ClusterService, ThreadPool, MetadataMappingService, ActionFilters, IndexNameExpressionResolver, SystemIndices) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.TransportAutoPutMappingAction
- TransportBroadcastAction<Request extends BroadcastRequest<Request>,
Response extends BroadcastResponse, ShardRequest extends BroadcastShardRequest, ShardResponse extends BroadcastShardResponse> - Class in org.elasticsearch.action.support.broadcast - TransportBroadcastAction(String, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Writeable.Reader<Request>, Writeable.Reader<ShardRequest>, String) - Constructor for class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- TransportBroadcastAction.AsyncBroadcastAction - Class in org.elasticsearch.action.support.broadcast
- TransportBroadcastByNodeAction<Request extends BroadcastRequest<Request>,
Response extends BroadcastResponse, ShardOperationResult extends Writeable> - Class in org.elasticsearch.action.support.broadcast.node -
Abstraction for transporting aggregated shard-level operations in a single request (NodeRequest) per-node and executing the shard-level operations serially on the receiving node.
- TransportBroadcastByNodeAction(String, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Writeable.Reader<Request>, String) - Constructor for class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
- TransportBroadcastByNodeAction(String, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Writeable.Reader<Request>, String, boolean) - Constructor for class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction
- TransportBroadcastByNodeAction.AsyncAction - Class in org.elasticsearch.action.support.broadcast.node
- TransportBroadcastByNodeAction.EmptyResult - Class in org.elasticsearch.action.support.broadcast.node
-
Can be used for implementations of
shardOperation
for which there is no shard-level return value. - TransportBroadcastByNodeAction.NodeRequest - Class in org.elasticsearch.action.support.broadcast.node
- TransportBroadcastReplicationAction<Request extends BroadcastRequest<Request>,
Response extends BroadcastResponse, ShardRequest extends ReplicationRequest<ShardRequest>, ShardResponse extends ReplicationResponse> - Class in org.elasticsearch.action.support.replication -
Base class for requests that should be executed on all shards of an index or several indices.
- TransportBroadcastReplicationAction(String, Writeable.Reader<Request>, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, TransportReplicationAction) - Constructor for class org.elasticsearch.action.support.replication.TransportBroadcastReplicationAction
- TransportBulkAction - Class in org.elasticsearch.action.bulk
-
Groups bulk request items by shard, optionally creating non-existent indices and delegates to
TransportShardBulkAction
for shard-level bulk execution - TransportBulkAction(ThreadPool, TransportService, ClusterService, IngestService, TransportShardBulkAction, NodeClient, ActionFilters, IndexNameExpressionResolver, IndexingPressure, SystemIndices) - Constructor for class org.elasticsearch.action.bulk.TransportBulkAction
- TransportBulkAction(ThreadPool, TransportService, ClusterService, IngestService, TransportShardBulkAction, NodeClient, ActionFilters, IndexNameExpressionResolver, IndexingPressure, SystemIndices, LongSupplier) - Constructor for class org.elasticsearch.action.bulk.TransportBulkAction
- TransportCancelTasksAction - Class in org.elasticsearch.action.admin.cluster.node.tasks.cancel
-
Transport action that can be used to cancel currently running cancellable tasks.
- TransportCancelTasksAction(ClusterService, TransportService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.cancel.TransportCancelTasksAction
- TransportChannel - Interface in org.elasticsearch.transport
-
A transport channel allows to send a response to a request on the channel.
- TransportCleanupRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.cleanup
-
Repository cleanup action for repository implementations based on
BlobStoreRepository
. - TransportCleanupRepositoryAction(TransportService, ClusterService, RepositoriesService, SnapshotsService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.cleanup.TransportCleanupRepositoryAction
- TransportClearIndicesCacheAction - Class in org.elasticsearch.action.admin.indices.cache.clear
-
Indices clear cache action.
- TransportClearIndicesCacheAction(ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
- TransportClearScrollAction - Class in org.elasticsearch.action.search
- TransportClearScrollAction(TransportService, ClusterService, ActionFilters, SearchTransportService) - Constructor for class org.elasticsearch.action.search.TransportClearScrollAction
- TransportClearVotingConfigExclusionsAction - Class in org.elasticsearch.action.admin.cluster.configuration
- TransportClearVotingConfigExclusionsAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.configuration.TransportClearVotingConfigExclusionsAction
- TransportClient - Class in org.elasticsearch.client.transport
-
Deprecated.
TransportClient
is deprecated in favour of the High Level REST client and will be removed in Elasticsearch 8.0. - TransportClient(Settings, Collection<Class<? extends Plugin>>) - Constructor for class org.elasticsearch.client.transport.TransportClient
-
Deprecated.Creates a new TransportClient with the given settings and plugins
- TransportClient(Settings, Settings, Collection<Class<? extends Plugin>>, TransportClient.HostFailureListener) - Constructor for class org.elasticsearch.client.transport.TransportClient
-
Deprecated.Creates a new TransportClient with the given settings, defaults and plugins.
- TransportClient.HostFailureListener - Interface in org.elasticsearch.client.transport
-
Deprecated.Listener that allows to be notified whenever a node failure / disconnect happens
- TransportCloneSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.clone
-
Transport action for the clone snapshot operation.
- TransportCloneSnapshotAction(TransportService, ClusterService, ThreadPool, SnapshotsService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.clone.TransportCloneSnapshotAction
- TransportCloseIndexAction - Class in org.elasticsearch.action.admin.indices.close
-
Close index action
- TransportCloseIndexAction(Settings, TransportService, ClusterService, ThreadPool, MetadataIndexStateService, ClusterSettings, ActionFilters, IndexNameExpressionResolver, DestructiveOperations) - Constructor for class org.elasticsearch.action.admin.indices.close.TransportCloseIndexAction
- TransportClosePointInTimeAction - Class in org.elasticsearch.action.search
- TransportClosePointInTimeAction(TransportService, ClusterService, ActionFilters, SearchTransportService, NamedWriteableRegistry) - Constructor for class org.elasticsearch.action.search.TransportClosePointInTimeAction
- TransportClusterAllocationExplainAction - Class in org.elasticsearch.action.admin.cluster.allocation
-
The
TransportClusterAllocationExplainAction
is responsible for actually executing the explanation of a shard's allocation on the master node in the cluster. - TransportClusterAllocationExplainAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, ClusterInfoService, SnapshotsInfoService, AllocationDeciders, AllocationService) - Constructor for class org.elasticsearch.action.admin.cluster.allocation.TransportClusterAllocationExplainAction
- TransportClusterHealthAction - Class in org.elasticsearch.action.admin.cluster.health
- TransportClusterHealthAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, AllocationService) - Constructor for class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
- TransportClusterInfoAction<Request extends ClusterInfoRequest<Request>,
Response extends ActionResponse> - Class in org.elasticsearch.action.support.master.info - TransportClusterInfoAction(String, TransportService, ClusterService, ThreadPool, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver, Writeable.Reader<Response>) - Constructor for class org.elasticsearch.action.support.master.info.TransportClusterInfoAction
- TransportClusterRerouteAction - Class in org.elasticsearch.action.admin.cluster.reroute
- TransportClusterRerouteAction(TransportService, ClusterService, ThreadPool, AllocationService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.reroute.TransportClusterRerouteAction
- TransportClusterSearchShardsAction - Class in org.elasticsearch.action.admin.cluster.shards
- TransportClusterSearchShardsAction(TransportService, ClusterService, IndicesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.shards.TransportClusterSearchShardsAction
- TransportClusterStateAction - Class in org.elasticsearch.action.admin.cluster.state
- TransportClusterStateAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
- TransportClusterStatsAction - Class in org.elasticsearch.action.admin.cluster.stats
- TransportClusterStatsAction(ThreadPool, ClusterService, TransportService, NodeService, IndicesService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction
- TransportClusterStatsAction.ClusterStatsNodeRequest - Class in org.elasticsearch.action.admin.cluster.stats
- TransportClusterUpdateSettingsAction - Class in org.elasticsearch.action.admin.cluster.settings
- TransportClusterUpdateSettingsAction(TransportService, ClusterService, ThreadPool, AllocationService, ActionFilters, IndexNameExpressionResolver, ClusterSettings) - Constructor for class org.elasticsearch.action.admin.cluster.settings.TransportClusterUpdateSettingsAction
- TransportConnectionListener - Interface in org.elasticsearch.transport
-
A listener interface that allows to react on transport events.
- TransportCreateIndexAction - Class in org.elasticsearch.action.admin.indices.create
-
Create index action.
- TransportCreateIndexAction(TransportService, ClusterService, ThreadPool, MetadataCreateIndexService, ActionFilters, IndexNameExpressionResolver, SystemIndices) - Constructor for class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
- TransportCreateSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.create
-
Transport action for create snapshot operation
- TransportCreateSnapshotAction(TransportService, ClusterService, ThreadPool, SnapshotsService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.create.TransportCreateSnapshotAction
- TransportDecompressor - Interface in org.elasticsearch.transport
- TransportDeleteAction - Class in org.elasticsearch.action.delete
-
Deprecated.
- TransportDeleteAction(TransportService, ActionFilters, TransportBulkAction) - Constructor for class org.elasticsearch.action.delete.TransportDeleteAction
-
Deprecated.
- TransportDeleteComponentTemplateAction - Class in org.elasticsearch.action.admin.indices.template.delete
- TransportDeleteComponentTemplateAction(TransportService, ClusterService, ThreadPool, MetadataIndexTemplateService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteComponentTemplateAction
- TransportDeleteComposableIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.delete
- TransportDeleteComposableIndexTemplateAction(TransportService, ClusterService, ThreadPool, MetadataIndexTemplateService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteComposableIndexTemplateAction
- TransportDeleteDanglingIndexAction - Class in org.elasticsearch.action.admin.indices.dangling.delete
-
Implements the deletion of a dangling index.
- TransportDeleteDanglingIndexAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, Settings, NodeClient) - Constructor for class org.elasticsearch.action.admin.indices.dangling.delete.TransportDeleteDanglingIndexAction
- TransportDeleteIndexAction - Class in org.elasticsearch.action.admin.indices.delete
-
Delete index action.
- TransportDeleteIndexAction(TransportService, ClusterService, ThreadPool, MetadataDeleteIndexService, ActionFilters, IndexNameExpressionResolver, DestructiveOperations) - Constructor for class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
- TransportDeleteIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.delete
-
Delete index action.
- TransportDeleteIndexTemplateAction(TransportService, ClusterService, ThreadPool, MetadataIndexTemplateService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.template.delete.TransportDeleteIndexTemplateAction
- TransportDeleteRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.delete
-
Transport action for unregister repository operation
- TransportDeleteRepositoryAction(TransportService, ClusterService, RepositoriesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.delete.TransportDeleteRepositoryAction
- TransportDeleteSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.delete
-
Transport action for delete snapshot operation
- TransportDeleteSnapshotAction(TransportService, ClusterService, ThreadPool, SnapshotsService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.delete.TransportDeleteSnapshotAction
- TransportDeleteStoredScriptAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- TransportDeleteStoredScriptAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, ScriptService) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.TransportDeleteStoredScriptAction
- TransportException - Exception in org.elasticsearch.transport
- TransportException(String) - Constructor for exception org.elasticsearch.transport.TransportException
- TransportException(String, Throwable) - Constructor for exception org.elasticsearch.transport.TransportException
- TransportException(Throwable) - Constructor for exception org.elasticsearch.transport.TransportException
- TransportException(StreamInput) - Constructor for exception org.elasticsearch.transport.TransportException
- TransportExplainAction - Class in org.elasticsearch.action.explain
-
Explain transport action.
- TransportExplainAction(ThreadPool, ClusterService, TransportService, SearchService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.explain.TransportExplainAction
- TransportFieldCapabilitiesAction - Class in org.elasticsearch.action.fieldcaps
- TransportFieldCapabilitiesAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndicesService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.fieldcaps.TransportFieldCapabilitiesAction
- TransportFieldUsageAction - Class in org.elasticsearch.action.admin.indices.stats
- TransportFieldUsageAction(ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.stats.TransportFieldUsageAction
- TransportFindDanglingIndexAction - Class in org.elasticsearch.action.admin.indices.dangling.find
-
Finds a specified dangling index by its UUID, searching across all nodes.
- TransportFindDanglingIndexAction(ThreadPool, ClusterService, TransportService, ActionFilters, DanglingIndicesState) - Constructor for class org.elasticsearch.action.admin.indices.dangling.find.TransportFindDanglingIndexAction
- TransportFlushAction - Class in org.elasticsearch.action.admin.indices.flush
-
Flush ActionType.
- TransportFlushAction(ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, TransportShardFlushAction) - Constructor for class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
- TransportForceMergeAction - Class in org.elasticsearch.action.admin.indices.forcemerge
-
ForceMerge index/indices action.
- TransportForceMergeAction(ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.forcemerge.TransportForceMergeAction
- TransportFuture<V> - Interface in org.elasticsearch.transport
- TransportGetAction - Class in org.elasticsearch.action.get
-
Performs the get operation.
- TransportGetAction(ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters, IndexNameExpressionResolver, ExecutorSelector) - Constructor for class org.elasticsearch.action.get.TransportGetAction
- TransportGetAliasesAction - Class in org.elasticsearch.action.admin.indices.alias.get
- TransportGetAliasesAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, SystemIndices) - Constructor for class org.elasticsearch.action.admin.indices.alias.get.TransportGetAliasesAction
- TransportGetComponentTemplateAction - Class in org.elasticsearch.action.admin.indices.template.get
- TransportGetComponentTemplateAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.template.get.TransportGetComponentTemplateAction
- TransportGetComposableIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.get
- TransportGetComposableIndexTemplateAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.template.get.TransportGetComposableIndexTemplateAction
- TransportGetFeatureUpgradeStatusAction - Class in org.elasticsearch.action.admin.cluster.migration
-
Transport class for the get feature upgrade status action
- TransportGetFeatureUpgradeStatusAction(TransportService, ThreadPool, ActionFilters, ClusterService, IndexNameExpressionResolver, PersistentTasksService, SystemIndices) - Constructor for class org.elasticsearch.action.admin.cluster.migration.TransportGetFeatureUpgradeStatusAction
- TransportGetFieldMappingsAction - Class in org.elasticsearch.action.admin.indices.mapping.get
- TransportGetFieldMappingsAction(TransportService, ClusterService, TransportGetFieldMappingsIndexAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsAction
- TransportGetFieldMappingsIndexAction - Class in org.elasticsearch.action.admin.indices.mapping.get
-
Transport action used to retrieve the mappings related to fields that belong to a specific index
- TransportGetFieldMappingsIndexAction(ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.TransportGetFieldMappingsIndexAction
- TransportGetIndexAction - Class in org.elasticsearch.action.admin.indices.get
-
Get index action.
- TransportGetIndexAction(TransportService, ClusterService, ThreadPool, SettingsFilter, ActionFilters, IndexNameExpressionResolver, IndicesService, IndexScopedSettings) - Constructor for class org.elasticsearch.action.admin.indices.get.TransportGetIndexAction
- TransportGetIndexTemplatesAction - Class in org.elasticsearch.action.admin.indices.template.get
- TransportGetIndexTemplatesAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.template.get.TransportGetIndexTemplatesAction
- TransportGetMappingsAction - Class in org.elasticsearch.action.admin.indices.mapping.get
- TransportGetMappingsAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, IndicesService) - Constructor for class org.elasticsearch.action.admin.indices.mapping.get.TransportGetMappingsAction
- TransportGetRepositoriesAction - Class in org.elasticsearch.action.admin.cluster.repositories.get
-
Transport action for get repositories operation
- TransportGetRepositoriesAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.get.TransportGetRepositoriesAction
- TransportGetRepositoriesAction.RepositoriesResult - Class in org.elasticsearch.action.admin.cluster.repositories.get
-
A holder class that consists of the repository metadata and the names of the repositories that were not found in the cluster state.
- TransportGetScriptContextAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- TransportGetScriptContextAction(TransportService, ActionFilters, ScriptService) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.TransportGetScriptContextAction
- TransportGetScriptLanguageAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- TransportGetScriptLanguageAction(TransportService, ActionFilters, ScriptService) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.TransportGetScriptLanguageAction
- TransportGetSettingsAction - Class in org.elasticsearch.action.admin.indices.settings.get
- TransportGetSettingsAction(TransportService, ClusterService, ThreadPool, SettingsFilter, ActionFilters, IndexNameExpressionResolver, IndexScopedSettings) - Constructor for class org.elasticsearch.action.admin.indices.settings.get.TransportGetSettingsAction
- TransportGetShardSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.get.shard
- TransportGetShardSnapshotAction(TransportService, ClusterService, ThreadPool, RepositoriesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.shard.TransportGetShardSnapshotAction
- TransportGetSnapshotsAction - Class in org.elasticsearch.action.admin.cluster.snapshots.get
-
Transport Action for get snapshots operation
- TransportGetSnapshotsAction(TransportService, ClusterService, ThreadPool, RepositoriesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.get.TransportGetSnapshotsAction
- TransportGetStoredScriptAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- TransportGetStoredScriptAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, ScriptService) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.TransportGetStoredScriptAction
- TransportGetTaskAction - Class in org.elasticsearch.action.admin.cluster.node.tasks.get
-
ActionType to get a single task.
- TransportGetTaskAction(ThreadPool, TransportService, ActionFilters, ClusterService, Client, NamedXContentRegistry) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.get.TransportGetTaskAction
- TransportImportDanglingIndexAction - Class in org.elasticsearch.action.admin.indices.dangling.import_index
-
Implements the import of a dangling index.
- TransportImportDanglingIndexAction(ActionFilters, TransportService, LocalAllocateDangledIndices, NodeClient) - Constructor for class org.elasticsearch.action.admin.indices.dangling.import_index.TransportImportDanglingIndexAction
- TransportIndexAction - Class in org.elasticsearch.action.index
-
Deprecated.
- TransportIndexAction(ActionFilters, TransportService, TransportBulkAction) - Constructor for class org.elasticsearch.action.index.TransportIndexAction
-
Deprecated.
- TransportIndicesAliasesAction - Class in org.elasticsearch.action.admin.indices.alias
-
Add/remove aliases action
- TransportIndicesAliasesAction(TransportService, ClusterService, ThreadPool, MetadataIndexAliasesService, ActionFilters, IndexNameExpressionResolver, RequestValidators<IndicesAliasesRequest>) - Constructor for class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
- TransportIndicesExistsAction - Class in org.elasticsearch.action.admin.indices.exists.indices
-
Indices exists action.
- TransportIndicesExistsAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.exists.indices.TransportIndicesExistsAction
- TransportIndicesSegmentsAction - Class in org.elasticsearch.action.admin.indices.segments
- TransportIndicesSegmentsAction(ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction
- TransportIndicesShardStoresAction - Class in org.elasticsearch.action.admin.indices.shards
-
Transport action that reads the cluster state for shards with the requested criteria (see
ClusterHealthStatus
) of specific indices and fetches store information from all the nodes usingTransportNodesListGatewayStartedShards
- TransportIndicesShardStoresAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, TransportNodesListGatewayStartedShards) - Constructor for class org.elasticsearch.action.admin.indices.shards.TransportIndicesShardStoresAction
- TransportIndicesStatsAction - Class in org.elasticsearch.action.admin.indices.stats
- TransportIndicesStatsAction(ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction
- TransportInfo - Class in org.elasticsearch.transport
- TransportInfo(StreamInput) - Constructor for class org.elasticsearch.transport.TransportInfo
- TransportInfo(BoundTransportAddress, Map<String, BoundTransportAddress>) - Constructor for class org.elasticsearch.transport.TransportInfo
- TransportInfo(BoundTransportAddress, Map<String, BoundTransportAddress>, boolean) - Constructor for class org.elasticsearch.transport.TransportInfo
- TransportInstanceSingleOperationAction<Request extends InstanceShardOperationRequest<Request>,
Response extends ActionResponse> - Class in org.elasticsearch.action.support.single.instance - TransportInstanceSingleOperationAction(String, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Writeable.Reader<Request>) - Constructor for class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- TransportInterceptor - Interface in org.elasticsearch.transport
-
This interface allows plugins to intercept requests on both the sender and the receiver side.
- TransportInterceptor.AsyncSender - Interface in org.elasticsearch.transport
- TransportListDanglingIndicesAction - Class in org.elasticsearch.action.admin.indices.dangling.list
-
Implements the listing of all dangling indices.
- TransportListDanglingIndicesAction(ThreadPool, ClusterService, TransportService, ActionFilters, DanglingIndicesState) - Constructor for class org.elasticsearch.action.admin.indices.dangling.list.TransportListDanglingIndicesAction
- TransportListTasksAction - Class in org.elasticsearch.action.admin.cluster.node.tasks.list
- TransportListTasksAction(ClusterService, TransportService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
- TransportLivenessAction - Class in org.elasticsearch.action.admin.cluster.node.liveness
- TransportLivenessAction(ClusterService, TransportService) - Constructor for class org.elasticsearch.action.admin.cluster.node.liveness.TransportLivenessAction
- TransportLogger - Class in org.elasticsearch.transport
- TransportLogger() - Constructor for class org.elasticsearch.transport.TransportLogger
- TransportMainAction - Class in org.elasticsearch.action.main
- TransportMainAction(Settings, TransportService, ActionFilters, ClusterService) - Constructor for class org.elasticsearch.action.main.TransportMainAction
- TransportMasterNodeAction<Request extends MasterNodeRequest<Request>,
Response extends ActionResponse> - Class in org.elasticsearch.action.support.master -
A base class for operations that needs to be performed on the master node.
- TransportMasterNodeAction(String, boolean, TransportService, ClusterService, ThreadPool, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver, Writeable.Reader<Response>, String) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeAction
- TransportMasterNodeAction(String, TransportService, ClusterService, ThreadPool, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver, Writeable.Reader<Response>, String) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeAction
- TransportMasterNodeReadAction<Request extends MasterNodeReadRequest<Request>,
Response extends ActionResponse> - Class in org.elasticsearch.action.support.master -
A base class for read operations that needs to be performed on the master node.
- TransportMasterNodeReadAction(String, boolean, TransportService, ClusterService, ThreadPool, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver, Writeable.Reader<Response>, String) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeReadAction
- TransportMasterNodeReadAction(String, TransportService, ClusterService, ThreadPool, ActionFilters, Writeable.Reader<Request>, IndexNameExpressionResolver, Writeable.Reader<Response>, String) - Constructor for class org.elasticsearch.action.support.master.TransportMasterNodeReadAction
- TransportMessage - Class in org.elasticsearch.transport
- TransportMessage() - Constructor for class org.elasticsearch.transport.TransportMessage
-
Constructs a new empty transport message
- TransportMessage(StreamInput) - Constructor for class org.elasticsearch.transport.TransportMessage
-
Constructs a new transport message with the data from the
StreamInput
. - TransportMessageListener - Interface in org.elasticsearch.transport
- TransportMultiGetAction - Class in org.elasticsearch.action.get
- TransportMultiGetAction(TransportService, ClusterService, TransportShardMultiGetAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.get.TransportMultiGetAction
- TransportMultiSearchAction - Class in org.elasticsearch.action.search
- TransportMultiSearchAction(Settings, ThreadPool, TransportService, ClusterService, ActionFilters, NodeClient) - Constructor for class org.elasticsearch.action.search.TransportMultiSearchAction
- TransportMultiTermVectorsAction - Class in org.elasticsearch.action.termvectors
- TransportMultiTermVectorsAction(TransportService, ClusterService, TransportShardMultiTermsVectorAction, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.termvectors.TransportMultiTermVectorsAction
- transportNodeAction - Variable in class org.elasticsearch.action.support.nodes.TransportNodesAction
- transportNodeAction - Variable in class org.elasticsearch.action.support.tasks.TransportTasksAction
- TransportNodesAction<NodesRequest extends BaseNodesRequest<NodesRequest>,
NodesResponse extends BaseNodesResponse<?>, NodeRequest extends BaseNodeRequest, NodeResponse extends BaseNodeResponse> - Class in org.elasticsearch.action.support.nodes - TransportNodesAction(String, ThreadPool, ClusterService, TransportService, ActionFilters, Writeable.Reader<NodesRequest>, Writeable.Reader<NodeRequest>, String, Class<NodeResponse>) - Constructor for class org.elasticsearch.action.support.nodes.TransportNodesAction
-
Same as
TransportNodesAction(String, ThreadPool, ClusterService, TransportService, ActionFilters, Writeable.Reader, Writeable.Reader, String, String, Class)
but executes final response collection on the transport thread except for when the final node response is received from the local node, in which casenodeExecutor
is used. - TransportNodesAction(String, ThreadPool, ClusterService, TransportService, ActionFilters, Writeable.Reader<NodesRequest>, Writeable.Reader<NodeRequest>, String, String, Class<NodeResponse>) - Constructor for class org.elasticsearch.action.support.nodes.TransportNodesAction
- TransportNodesHotThreadsAction - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- TransportNodesHotThreadsAction(ThreadPool, ClusterService, TransportService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction
- TransportNodesHotThreadsAction.NodeRequest - Class in org.elasticsearch.action.admin.cluster.node.hotthreads
- TransportNodesInfoAction - Class in org.elasticsearch.action.admin.cluster.node.info
- TransportNodesInfoAction(ThreadPool, ClusterService, TransportService, NodeService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
- TransportNodesInfoAction.NodeInfoRequest - Class in org.elasticsearch.action.admin.cluster.node.info
- TransportNodesListGatewayMetaState - Class in org.elasticsearch.gateway
- TransportNodesListGatewayMetaState(ThreadPool, ClusterService, TransportService, ActionFilters, GatewayMetaState) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- TransportNodesListGatewayMetaState.NodeGatewayMetaState - Class in org.elasticsearch.gateway
- TransportNodesListGatewayMetaState.NodeRequest - Class in org.elasticsearch.gateway
- TransportNodesListGatewayMetaState.NodesGatewayMetaState - Class in org.elasticsearch.gateway
- TransportNodesListGatewayMetaState.Request - Class in org.elasticsearch.gateway
- TransportNodesListGatewayStartedShards - Class in org.elasticsearch.gateway
-
This transport action is used to fetch the shard version from each node during primary allocation in
GatewayAllocator
. - TransportNodesListGatewayStartedShards(Settings, ThreadPool, ClusterService, TransportService, ActionFilters, NodeEnvironment, IndicesService, NamedXContentRegistry) - Constructor for class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- TransportNodesListGatewayStartedShards.NodeGatewayStartedShards - Class in org.elasticsearch.gateway
- TransportNodesListGatewayStartedShards.NodeRequest - Class in org.elasticsearch.gateway
- TransportNodesListGatewayStartedShards.NodesGatewayStartedShards - Class in org.elasticsearch.gateway
- TransportNodesListGatewayStartedShards.Request - Class in org.elasticsearch.gateway
- TransportNodesListShardStoreMetadata - Class in org.elasticsearch.indices.store
- TransportNodesListShardStoreMetadata(Settings, ThreadPool, ClusterService, TransportService, IndicesService, NodeEnvironment, ActionFilters) - Constructor for class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata
- TransportNodesListShardStoreMetadata.NodeRequest - Class in org.elasticsearch.indices.store
- TransportNodesListShardStoreMetadata.NodesStoreFilesMetadata - Class in org.elasticsearch.indices.store
- TransportNodesListShardStoreMetadata.NodeStoreFilesMetadata - Class in org.elasticsearch.indices.store
- TransportNodesListShardStoreMetadata.Request - Class in org.elasticsearch.indices.store
- TransportNodesListShardStoreMetadata.StoreFilesMetadata - Class in org.elasticsearch.indices.store
- TransportNodesReloadSecureSettingsAction - Class in org.elasticsearch.action.admin.cluster.node.reload
- TransportNodesReloadSecureSettingsAction(ThreadPool, ClusterService, TransportService, ActionFilters, Environment, PluginsService) - Constructor for class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction
- TransportNodesReloadSecureSettingsAction.NodeRequest - Class in org.elasticsearch.action.admin.cluster.node.reload
- TransportNodesSnapshotsStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
-
Transport client that collects snapshot shard statuses from data nodes
- TransportNodesSnapshotsStatus(ThreadPool, ClusterService, TransportService, SnapshotShardsService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- TransportNodesSnapshotsStatus.NodeRequest - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- TransportNodesSnapshotsStatus.NodeSnapshotStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- TransportNodesSnapshotsStatus.NodesSnapshotStatus - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- TransportNodesSnapshotsStatus.Request - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- TransportNodesStatsAction - Class in org.elasticsearch.action.admin.cluster.node.stats
- TransportNodesStatsAction(ThreadPool, ClusterService, TransportService, NodeService, ActionFilters) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
- TransportNodesStatsAction.NodeStatsRequest - Class in org.elasticsearch.action.admin.cluster.node.stats
- TransportNodesUsageAction - Class in org.elasticsearch.action.admin.cluster.node.usage
- TransportNodesUsageAction(ThreadPool, ClusterService, TransportService, ActionFilters, UsageService, AggregationUsageService) - Constructor for class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction
- TransportNodesUsageAction.NodeUsageRequest - Class in org.elasticsearch.action.admin.cluster.node.usage
- TransportNotReadyException - Exception in org.elasticsearch.transport
-
Exception indicating that the
TransportService
received a request before it was ready to handle it, so the request should be rejected and the connection closed. - TransportNotReadyException() - Constructor for exception org.elasticsearch.transport.TransportNotReadyException
- TransportOpenIndexAction - Class in org.elasticsearch.action.admin.indices.open
-
Open index action
- TransportOpenIndexAction(TransportService, ClusterService, ThreadPool, MetadataIndexStateService, ActionFilters, IndexNameExpressionResolver, DestructiveOperations) - Constructor for class org.elasticsearch.action.admin.indices.open.TransportOpenIndexAction
- TransportOpenPointInTimeAction - Class in org.elasticsearch.action.search
- TransportOpenPointInTimeAction(TransportService, SearchService, ActionFilters, ClusterService, TransportSearchAction) - Constructor for class org.elasticsearch.action.search.TransportOpenPointInTimeAction
- transportOptions - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- transportOptions() - Method in class org.elasticsearch.action.ActionType
-
Optional request options for the action.
- transportOptions() - Method in class org.elasticsearch.action.bulk.BulkAction
- transportOptions() - Method in class org.elasticsearch.action.bulk.TransportShardBulkAction
- transportOptions() - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction
- transportOptions() - Method in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- TransportPendingClusterTasksAction - Class in org.elasticsearch.action.admin.cluster.tasks
- TransportPendingClusterTasksAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.tasks.TransportPendingClusterTasksAction
- TransportPostFeatureUpgradeAction - Class in org.elasticsearch.action.admin.cluster.migration
-
Transport action for post feature upgrade action
- TransportPostFeatureUpgradeAction(TransportService, ThreadPool, ActionFilters, ClusterService, IndexNameExpressionResolver, SystemIndices, PersistentTasksService) - Constructor for class org.elasticsearch.action.admin.cluster.migration.TransportPostFeatureUpgradeAction
- transportPrimaryAction - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- TransportPutComponentTemplateAction - Class in org.elasticsearch.action.admin.indices.template.put
- TransportPutComponentTemplateAction(TransportService, ClusterService, ThreadPool, MetadataIndexTemplateService, ActionFilters, IndexNameExpressionResolver, IndexScopedSettings) - Constructor for class org.elasticsearch.action.admin.indices.template.put.TransportPutComponentTemplateAction
- TransportPutComposableIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.put
- TransportPutComposableIndexTemplateAction(TransportService, ClusterService, ThreadPool, MetadataIndexTemplateService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.template.put.TransportPutComposableIndexTemplateAction
- TransportPutIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.put
-
Put index template action.
- TransportPutIndexTemplateAction(TransportService, ClusterService, ThreadPool, MetadataIndexTemplateService, ActionFilters, IndexNameExpressionResolver, IndexScopedSettings) - Constructor for class org.elasticsearch.action.admin.indices.template.put.TransportPutIndexTemplateAction
- TransportPutMappingAction - Class in org.elasticsearch.action.admin.indices.mapping.put
-
Put mapping action.
- TransportPutMappingAction(TransportService, ClusterService, ThreadPool, MetadataMappingService, ActionFilters, IndexNameExpressionResolver, RequestValidators<PutMappingRequest>, SystemIndices) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
- TransportPutRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.put
-
Transport action for register repository operation
- TransportPutRepositoryAction(TransportService, ClusterService, RepositoriesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.put.TransportPutRepositoryAction
- TransportPutStoredScriptAction - Class in org.elasticsearch.action.admin.cluster.storedscripts
- TransportPutStoredScriptAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, ScriptService) - Constructor for class org.elasticsearch.action.admin.cluster.storedscripts.TransportPutStoredScriptAction
- TransportRecoveryAction - Class in org.elasticsearch.action.admin.indices.recovery
-
Transport action for shard recovery operation.
- TransportRecoveryAction(ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction
- TransportRefreshAction - Class in org.elasticsearch.action.admin.indices.refresh
-
Refresh action.
- TransportRefreshAction(ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, TransportShardRefreshAction) - Constructor for class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
- TransportRemoteInfoAction - Class in org.elasticsearch.action.admin.cluster.remote
- TransportRemoteInfoAction(TransportService, ActionFilters, SearchTransportService) - Constructor for class org.elasticsearch.action.admin.cluster.remote.TransportRemoteInfoAction
- transportReplicaAction - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- TransportReplicationAction<Request extends ReplicationRequest<Request>,
ReplicaRequest extends ReplicationRequest<ReplicaRequest>, Response extends ReplicationResponse> - Class in org.elasticsearch.action.support.replication -
Base class for requests that should be executed on a primary copy followed by replica copies.
- TransportReplicationAction(Settings, String, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, Writeable.Reader<Request>, Writeable.Reader<ReplicaRequest>, String) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction
- TransportReplicationAction(Settings, String, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, Writeable.Reader<Request>, Writeable.Reader<ReplicaRequest>, String, boolean, boolean) - Constructor for class org.elasticsearch.action.support.replication.TransportReplicationAction
- TransportReplicationAction.ConcreteReplicaRequest<R extends TransportRequest> - Class in org.elasticsearch.action.support.replication
- TransportReplicationAction.ConcreteShardRequest<R extends TransportRequest> - Class in org.elasticsearch.action.support.replication
-
a wrapper class to encapsulate a request when being sent to a specific allocation id
- TransportReplicationAction.PrimaryResult<ReplicaRequest extends ReplicationRequest<ReplicaRequest>,
Response extends ReplicationResponse> - Class in org.elasticsearch.action.support.replication - TransportReplicationAction.ReplicaResponse - Class in org.elasticsearch.action.support.replication
- TransportReplicationAction.ReplicaResult - Class in org.elasticsearch.action.support.replication
- TransportReplicationAction.ReplicasProxy - Class in org.elasticsearch.action.support.replication
-
The
ReplicasProxy
is an implementation of theReplicas
interface that performs the actualReplicaRequest
on the replica shards. - TransportReplicationAction.RetryOnReplicaException - Exception in org.elasticsearch.action.support.replication
- TransportRequest - Class in org.elasticsearch.transport
- TransportRequest() - Constructor for class org.elasticsearch.transport.TransportRequest
- TransportRequest(StreamInput) - Constructor for class org.elasticsearch.transport.TransportRequest
- TransportRequest.Empty - Class in org.elasticsearch.transport
- TransportRequestHandler<T extends TransportRequest> - Interface in org.elasticsearch.transport
- TransportRequestOptions - Class in org.elasticsearch.transport
- TransportRequestOptions.Type - Enum Class in org.elasticsearch.transport
- TransportResetFeatureStateAction - Class in org.elasticsearch.action.admin.cluster.snapshots.features
-
Transport action for cleaning up feature index state.
- TransportResetFeatureStateAction(TransportService, ThreadPool, ActionFilters, SystemIndices, NodeClient, ClusterService, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.features.TransportResetFeatureStateAction
- TransportResizeAction - Class in org.elasticsearch.action.admin.indices.shrink
-
Main class to initiate resizing (shrink / split) an index into a new index
- TransportResizeAction(String, TransportService, ClusterService, ThreadPool, MetadataCreateIndexService, ActionFilters, IndexNameExpressionResolver, Client) - Constructor for class org.elasticsearch.action.admin.indices.shrink.TransportResizeAction
- TransportResizeAction(TransportService, ClusterService, ThreadPool, MetadataCreateIndexService, ActionFilters, IndexNameExpressionResolver, Client) - Constructor for class org.elasticsearch.action.admin.indices.shrink.TransportResizeAction
- TransportResponse - Class in org.elasticsearch.transport
- TransportResponse() - Constructor for class org.elasticsearch.transport.TransportResponse
-
Constructs a new empty transport response
- TransportResponse(StreamInput) - Constructor for class org.elasticsearch.transport.TransportResponse
-
Constructs a new transport response with the data from the
StreamInput
. - TransportResponse.Empty - Class in org.elasticsearch.transport
- TransportResponseHandler<T extends TransportResponse> - Interface in org.elasticsearch.transport
- TransportResponseHandler.Empty - Class in org.elasticsearch.transport
-
Implementations of
TransportResponseHandler
that handles the empty responseTransportResponse.Empty
. - TransportRestoreSnapshotAction - Class in org.elasticsearch.action.admin.cluster.snapshots.restore
-
Transport action for restore snapshot operation
- TransportRestoreSnapshotAction(TransportService, ClusterService, ThreadPool, RestoreService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.restore.TransportRestoreSnapshotAction
- TransportResyncReplicationAction - Class in org.elasticsearch.action.resync
- TransportResyncReplicationAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, IndexingPressure, SystemIndices) - Constructor for class org.elasticsearch.action.resync.TransportResyncReplicationAction
- TransportRolloverAction - Class in org.elasticsearch.action.admin.indices.rollover
-
Main class to swap the index pointed to by an alias, given some conditions
- TransportRolloverAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, MetadataRolloverService, Client) - Constructor for class org.elasticsearch.action.admin.indices.rollover.TransportRolloverAction
- Transports - Enum Class in org.elasticsearch.transport
- TransportSearchAction - Class in org.elasticsearch.action.search
- TransportSearchAction(ThreadPool, CircuitBreakerService, TransportService, SearchService, SearchTransportService, SearchPhaseController, ClusterService, ActionFilters, IndexNameExpressionResolver, NamedWriteableRegistry, ExecutorSelector) - Constructor for class org.elasticsearch.action.search.TransportSearchAction
- TransportSearchAction.SinglePhaseSearchAction - Interface in org.elasticsearch.action.search
- TransportSearchScrollAction - Class in org.elasticsearch.action.search
- TransportSearchScrollAction(TransportService, ClusterService, ActionFilters, SearchTransportService, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.TransportSearchScrollAction
- TransportSerializationException - Exception in org.elasticsearch.transport
- TransportSerializationException(String, Throwable) - Constructor for exception org.elasticsearch.transport.TransportSerializationException
- TransportSerializationException(StreamInput) - Constructor for exception org.elasticsearch.transport.TransportSerializationException
- transportService - Variable in class org.elasticsearch.action.support.broadcast.TransportBroadcastAction
- transportService - Variable in class org.elasticsearch.action.support.master.TransportMasterNodeAction
- transportService - Variable in class org.elasticsearch.action.support.nodes.TransportNodesAction
- transportService - Variable in class org.elasticsearch.action.support.replication.TransportReplicationAction
- transportService - Variable in class org.elasticsearch.action.support.single.instance.TransportInstanceSingleOperationAction
- transportService - Variable in class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- transportService - Variable in class org.elasticsearch.action.support.tasks.TransportTasksAction
- transportService - Variable in class org.elasticsearch.discovery.zen.FaultDetection
- transportService - Variable in class org.elasticsearch.transport.RemoteConnectionStrategy
- TransportService - Class in org.elasticsearch.transport
- TransportService(Settings, Transport, ThreadPool, TransportInterceptor, Function<BoundTransportAddress, DiscoveryNode>, ClusterSettings, Set<String>) - Constructor for class org.elasticsearch.transport.TransportService
-
Build the service.
- TransportService(Settings, Transport, ThreadPool, TransportInterceptor, Function<BoundTransportAddress, DiscoveryNode>, ClusterSettings, Set<String>, ConnectionManager) - Constructor for class org.elasticsearch.transport.TransportService
- TransportService.ContextRestoreResponseHandler<T extends TransportResponse> - Class in org.elasticsearch.transport
-
This handler wrapper ensures that the response thread executes with the correct thread context.
- TransportService.HandshakeResponse - Class in org.elasticsearch.transport
- TransportSettings - Class in org.elasticsearch.transport
- TransportShardBulkAction - Class in org.elasticsearch.action.bulk
-
Performs shard-level bulk (index, delete or update) operations
- TransportShardBulkAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, MappingUpdatedAction, UpdateHelper, ActionFilters, IndexingPressure, SystemIndices) - Constructor for class org.elasticsearch.action.bulk.TransportShardBulkAction
- TransportShardFlushAction - Class in org.elasticsearch.action.admin.indices.flush
- TransportShardFlushAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.flush.TransportShardFlushAction
- TransportShardMultiGetAction - Class in org.elasticsearch.action.get
- TransportShardMultiGetAction(ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters, IndexNameExpressionResolver, ExecutorSelector) - Constructor for class org.elasticsearch.action.get.TransportShardMultiGetAction
- TransportShardMultiTermsVectorAction - Class in org.elasticsearch.action.termvectors
- TransportShardMultiTermsVectorAction(ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.termvectors.TransportShardMultiTermsVectorAction
- TransportShardRefreshAction - Class in org.elasticsearch.action.admin.indices.refresh
- TransportShardRefreshAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.refresh.TransportShardRefreshAction
- TransportSimulateIndexTemplateAction - Class in org.elasticsearch.action.admin.indices.template.post
- TransportSimulateIndexTemplateAction(TransportService, ClusterService, ThreadPool, MetadataIndexTemplateService, ActionFilters, IndexNameExpressionResolver, NamedXContentRegistry, IndicesService) - Constructor for class org.elasticsearch.action.admin.indices.template.post.TransportSimulateIndexTemplateAction
- TransportSimulateTemplateAction - Class in org.elasticsearch.action.admin.indices.template.post
-
Handles simulating an index template either by name (looking it up in the cluster state), or by a provided template configuration
- TransportSimulateTemplateAction(TransportService, ClusterService, ThreadPool, MetadataIndexTemplateService, ActionFilters, IndexNameExpressionResolver, NamedXContentRegistry, IndicesService) - Constructor for class org.elasticsearch.action.admin.indices.template.post.TransportSimulateTemplateAction
- TransportSingleItemBulkWriteAction<Request extends ReplicatedWriteRequest<Request>,
Response extends ReplicationResponse & WriteResponse> - Class in org.elasticsearch.action.bulk -
Deprecated.
- TransportSingleItemBulkWriteAction(String, TransportService, ActionFilters, Writeable.Reader<Request>, TransportBulkAction) - Constructor for class org.elasticsearch.action.bulk.TransportSingleItemBulkWriteAction
-
Deprecated.
- TransportSingleShardAction<Request extends SingleShardRequest<Request>,
Response extends ActionResponse> - Class in org.elasticsearch.action.support.single.shard -
A base class for operations that need to perform a read operation on a single shard copy.
- TransportSingleShardAction(String, ThreadPool, ClusterService, TransportService, ActionFilters, IndexNameExpressionResolver, Writeable.Reader<Request>, String) - Constructor for class org.elasticsearch.action.support.single.shard.TransportSingleShardAction
- TransportSingleShardAction.InternalRequest - Class in org.elasticsearch.action.support.single.shard
-
Internal request class that gets built on each node.
- TransportSnapshotsStatusAction - Class in org.elasticsearch.action.admin.cluster.snapshots.status
- TransportSnapshotsStatusAction(TransportService, ClusterService, ThreadPool, RepositoriesService, TransportNodesSnapshotsStatus, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.status.TransportSnapshotsStatusAction
- TransportSnapshottableFeaturesAction - Class in org.elasticsearch.action.admin.cluster.snapshots.features
- TransportSnapshottableFeaturesAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver, SystemIndices) - Constructor for class org.elasticsearch.action.admin.cluster.snapshots.features.TransportSnapshottableFeaturesAction
- TransportStats - Class in org.elasticsearch.transport
- TransportStats(long, long, long, long, long, long) - Constructor for class org.elasticsearch.transport.TransportStats
- TransportStats(StreamInput) - Constructor for class org.elasticsearch.transport.TransportStats
- TransportStatus - Class in org.elasticsearch.transport
- TransportStatus() - Constructor for class org.elasticsearch.transport.TransportStatus
- TransportSyncedFlushAction - Class in org.elasticsearch.action.admin.indices.flush
-
Synced flush ActionType.
- TransportSyncedFlushAction(TransportService, ActionFilters, SyncedFlushService) - Constructor for class org.elasticsearch.action.admin.indices.flush.TransportSyncedFlushAction
- TransportTasksAction<OperationTask extends Task,
TasksRequest extends BaseTasksRequest<TasksRequest>, TasksResponse extends BaseTasksResponse, TaskResponse extends Writeable> - Class in org.elasticsearch.action.support.tasks -
The base class for transport actions that are interacting with currently running tasks.
- TransportTasksAction(String, ClusterService, TransportService, ActionFilters, Writeable.Reader<TasksRequest>, Writeable.Reader<TasksResponse>, Writeable.Reader<TaskResponse>, String) - Constructor for class org.elasticsearch.action.support.tasks.TransportTasksAction
- TransportTermVectorsAction - Class in org.elasticsearch.action.termvectors
-
Performs the get operation.
- TransportTermVectorsAction(ClusterService, TransportService, IndicesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.termvectors.TransportTermVectorsAction
- TransportTypesExistsAction - Class in org.elasticsearch.action.admin.indices.exists.types
-
Types exists transport action.
- TransportTypesExistsAction(TransportService, ClusterService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.exists.types.TransportTypesExistsAction
- TransportUpdateAction - Class in org.elasticsearch.action.update
- TransportUpdateAction(ThreadPool, ClusterService, TransportService, UpdateHelper, ActionFilters, IndexNameExpressionResolver, IndicesService, AutoCreateIndex, NodeClient) - Constructor for class org.elasticsearch.action.update.TransportUpdateAction
- TransportUpdateSettingsAction - Class in org.elasticsearch.action.admin.indices.settings.put
- TransportUpdateSettingsAction(TransportService, ClusterService, ThreadPool, MetadataUpdateSettingsService, ActionFilters, IndexNameExpressionResolver, SystemIndices) - Constructor for class org.elasticsearch.action.admin.indices.settings.put.TransportUpdateSettingsAction
- TransportUpgradeAction - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
Upgrade index/indices action.
- TransportUpgradeAction(ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver, NodeClient) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeAction
- TransportUpgradeSettingsAction - Class in org.elasticsearch.action.admin.indices.upgrade.post
- TransportUpgradeSettingsAction(TransportService, ClusterService, ThreadPool, MetadataUpdateSettingsService, IndexNameExpressionResolver, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.TransportUpgradeSettingsAction
- TransportUpgradeStatusAction - Class in org.elasticsearch.action.admin.indices.upgrade.get
- TransportUpgradeStatusAction(ClusterService, TransportService, IndicesService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.get.TransportUpgradeStatusAction
- TransportValidateQueryAction - Class in org.elasticsearch.action.admin.indices.validate.query
- TransportValidateQueryAction(ClusterService, TransportService, SearchService, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.TransportValidateQueryAction
- TransportVerifyRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.verify
-
Transport action for verifying repository operation
- TransportVerifyRepositoryAction(TransportService, ClusterService, RepositoriesService, ThreadPool, ActionFilters, IndexNameExpressionResolver) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.TransportVerifyRepositoryAction
- TransportVerifyShardBeforeCloseAction - Class in org.elasticsearch.action.admin.indices.close
- TransportVerifyShardBeforeCloseAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction
- TransportVerifyShardBeforeCloseAction.ShardRequest - Class in org.elasticsearch.action.admin.indices.close
- TransportVerifyShardIndexBlockAction - Class in org.elasticsearch.action.admin.indices.readonly
-
Action used to verify whether shards have properly applied a given index block, and are no longer executing any operations in violation of that block.
- TransportVerifyShardIndexBlockAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters) - Constructor for class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction
- TransportVerifyShardIndexBlockAction.ShardRequest - Class in org.elasticsearch.action.admin.indices.readonly
- TransportWriteAction<Request extends ReplicatedWriteRequest<Request>,
ReplicaRequest extends ReplicatedWriteRequest<ReplicaRequest>, Response extends ReplicationResponse & WriteResponse> - Class in org.elasticsearch.action.support.replication -
Base class for transport actions that modify data in some shard like index, delete, and shardBulk.
- TransportWriteAction(Settings, String, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction, ActionFilters, Writeable.Reader<Request>, Writeable.Reader<ReplicaRequest>, BiFunction<ExecutorSelector, IndexShard, String>, boolean, IndexingPressure, SystemIndices) - Constructor for class org.elasticsearch.action.support.replication.TransportWriteAction
- TransportWriteAction.WritePrimaryResult<ReplicaRequest extends ReplicatedWriteRequest<ReplicaRequest>,
Response extends ReplicationResponse & WriteResponse> - Class in org.elasticsearch.action.support.replication -
Result of taking the action on the primary.
- TransportWriteAction.WriteReplicaResult<ReplicaRequest extends ReplicatedWriteRequest<ReplicaRequest>> - Class in org.elasticsearch.action.support.replication
-
Result of taking the action on the replica.
- transpositions - Variable in class org.elasticsearch.index.search.MatchQueryParser
- transpositions() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- transpositions(boolean) - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- tree - Variable in class org.elasticsearch.search.profile.AbstractInternalProfileTree
-
Maps the Query to it's list of children.
- TREE_DEPTH - Static variable in class org.apache.lucene.analysis.miscellaneous.DuplicateByteSequenceSpotter
- Triangle(XTessellator.Node, boolean, XTessellator.Node, boolean, XTessellator.Node, boolean) - Constructor for class org.apache.lucene.geo.XTessellator.Triangle
- TriConsumer<S,
T, U> - Interface in org.elasticsearch.common -
Represents an operation that accepts three arguments and returns no result.
- TriFunction<S,
T, U, R> - Interface in org.elasticsearch.common -
Represents a function that accepts three arguments and produces a result.
- trim() - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
-
Trims the number of options per suggest text term to the requested size.
- trimLeadingCharacter(String, char) - Static method in class org.elasticsearch.common.Strings
-
Trim all occurrences of the supplied leading character from the given String.
- trimOperationOfPreviousPrimaryTerms(long) - Method in class org.elasticsearch.index.shard.IndexShard
- trimOperations(long, long) - Method in class org.elasticsearch.index.translog.Translog
-
Trims translog for terms of files below
belowTerm
and seq# aboveaboveSeqNo
. - trimOperationsFromTranslog(long, long) - Method in class org.elasticsearch.index.engine.Engine
-
Trims translog for terms below
belowTerm
and seq# aboveaboveSeqNo
- trimOperationsFromTranslog(long, long) - Method in class org.elasticsearch.index.engine.InternalEngine
- trimOperationsFromTranslog(long, long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- trimTier(DiscoveryNodeFilters) - Static method in class org.elasticsearch.cluster.node.DiscoveryNodeFilters
-
Removes any filters that should not be considered, returning a new
DiscoveryNodeFilters
object. - trimTranslog() - Method in class org.elasticsearch.index.shard.IndexShard
-
checks and removes translog files that no longer need to be retained.
- trimUnreferencedReaders() - Method in class org.elasticsearch.index.translog.Translog
-
Trims unreferenced translog generations by asking
TranslogDeletionPolicy
for the minimum required generation - trimUnreferencedTranslogFiles() - Method in class org.elasticsearch.index.engine.Engine
-
checks and removes translog files that no longer need to be retained.
- trimUnreferencedTranslogFiles() - Method in class org.elasticsearch.index.engine.InternalEngine
- trimUnreferencedTranslogFiles() - Method in class org.elasticsearch.index.engine.NoOpEngine
-
This implementation will trim existing translog files using a
TranslogDeletionPolicy
that retains nothing but the last translog generation from safe commit. - trimUnreferencedTranslogFiles() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- trimUnsafeCommits(long, long, Version) - Method in class org.elasticsearch.index.store.Store
-
Keeping existing unsafe commits when opening an engine can be problematic because these commits are not safe at the recovering time but they can suddenly become safe in the future.
- TRUE - Enum constant in enum class org.elasticsearch.index.mapper.ObjectMapper.Dynamic
- TRUE - Enum constant in enum class org.elasticsearch.transport.Compression.Enabled
- TRUE - Static variable in class org.elasticsearch.action.support.master.AcknowledgedResponse
- TRUE - Static variable in class org.elasticsearch.index.mapper.BooleanFieldMapper.Values
- trues() - Method in class org.elasticsearch.script.BooleanFieldScript
-
How many
true
values were returned for this document. - truncatedTo(TemporalUnit) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- TruncatedTranslogException - Exception in org.elasticsearch.index.translog
- TruncatedTranslogException(String, String, Throwable) - Constructor for exception org.elasticsearch.index.translog.TruncatedTranslogException
- TruncatedTranslogException(StreamInput) - Constructor for exception org.elasticsearch.index.translog.TruncatedTranslogException
- TruncateTranslogAction - Class in org.elasticsearch.index.translog
- TruncateTranslogAction(NamedXContentRegistry) - Constructor for class org.elasticsearch.index.translog.TruncateTranslogAction
- tryAcquire() - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
-
Try acquiring lock, returning null if unable.
- tryAcquire(TimeValue) - Method in class org.elasticsearch.common.util.concurrent.ReleasableLock
-
Try acquiring lock, returning null if unable to acquire lock within timeout.
- tryAcquire(T) - Method in class org.elasticsearch.common.util.concurrent.KeyedLock
-
Tries to acquire the lock for the given key and returns it.
- tryAction(ActionListener<Response>) - Method in class org.elasticsearch.action.support.RetryableAction
- tryIncRef() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- tryIncRef() - Method in class org.elasticsearch.index.store.Store
-
Tries to increment the refCount of this Store instance.
- tryIncRef() - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- tryIncRef() - Method in class org.elasticsearch.transport.BytesTransportRequest
- tryIncRef() - Method in class org.elasticsearch.transport.TransportMessage
- tryLock() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
- tryLock(long, TimeUnit) - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
- tryOpenIndex(Path, ShardId, NodeEnvironment.ShardLocker, Logger) - Static method in class org.elasticsearch.index.store.Store
-
Tries to open an index for the given location.
- tTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, three digit fraction of second, and time zone offset prefixed by 'T' ('T'HH:mm:ss.SSSZZ).
- tTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a two digit hour of day, two digit minute of hour, two digit second of minute, and time zone offset prefixed by 'T' ('T'HH:mm:ssZZ).
- TVD - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- TVF - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- TVM - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- TVX - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- twentyFourHours - Variable in class org.elasticsearch.script.ScriptContextStats.TimeSeries
- TWO - Static variable in class org.elasticsearch.common.unit.Fuzziness
- txCount() - Method in class org.elasticsearch.transport.TransportStats
- txGet() - Method in class org.elasticsearch.transport.PlainTransportFuture
- txGet() - Method in interface org.elasticsearch.transport.TransportFuture
-
Waits if necessary for the computation to complete, and then retrieves its result.
- txGet(long, TimeUnit) - Method in class org.elasticsearch.transport.PlainTransportFuture
- txGet(long, TimeUnit) - Method in interface org.elasticsearch.transport.TransportFuture
-
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
- txSize() - Method in class org.elasticsearch.transport.TransportStats
- type - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- type - Variable in class org.elasticsearch.gateway.AsyncShardFetch
- type - Variable in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- type - Variable in class org.elasticsearch.index.query.AbstractGeometryQueryBuilder.ParsedGeometryQueryParams
- type - Variable in class org.elasticsearch.repositories.RepositoryInfo
- type - Variable in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo.ParameterInfo
- type - Variable in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- type - Variable in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- type() - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- type() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Returns repository type
- type() - Method in class org.elasticsearch.action.admin.cluster.stats.RuntimeFieldStats
- type() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
- type() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The mapping type.
- type() - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Deprecated.Types are in the process of being removed.
- type() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the type that this request operates on
- type() - Method in class org.elasticsearch.action.explain.ExplainRequest
-
Deprecated.Types are in the process of being removed.
- type() - Method in class org.elasticsearch.action.get.GetRequest
-
Deprecated.Types are in the process of being removed.
- type() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- type() - Method in class org.elasticsearch.action.index.IndexRequest
-
Deprecated.Types are in the process of being removed.
- type() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Returns the type of document to get the term vector for.
- type() - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Types are in the process of being removed.
- type() - Method in class org.elasticsearch.Build
- type() - Method in class org.elasticsearch.cluster.metadata.MappingMetadata
- type() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
-
Returns repository type
- type() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- type() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- type() - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision
-
Get the
Decision.Type
of this decision - type() - Method in enum class org.elasticsearch.cluster.routing.Preference
- type() - Method in class org.elasticsearch.index.engine.Engine.Delete
- type() - Method in class org.elasticsearch.index.engine.Engine.Get
- type() - Method in class org.elasticsearch.index.engine.Engine.Index
- type() - Method in class org.elasticsearch.index.engine.Engine.NoOp
- type() - Method in class org.elasticsearch.index.engine.Engine.Operation
- type() - Method in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
- type() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- type() - Method in class org.elasticsearch.index.mapper.Mapping
- type() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- type() - Method in class org.elasticsearch.index.mapper.SourceToParse
- type() - Method in class org.elasticsearch.index.mapper.Uid
- type() - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Returns the execution type of the geo bounding box.
- type() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
Deprecated.Types are in the process of being removed.
- type() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- type() - Method in class org.elasticsearch.index.query.TypeQueryBuilder
- type() - Method in class org.elasticsearch.index.translog.Translog.Delete
- type() - Method in class org.elasticsearch.index.translog.Translog.Index
- type() - Method in class org.elasticsearch.indices.TermsLookup
-
Deprecated.Types are in the process of being removed.
- type() - Method in class org.elasticsearch.search.aggregations.bucket.composite.DateHistogramValuesSourceBuilder
- type() - Method in class org.elasticsearch.search.aggregations.bucket.composite.HistogramValuesSourceBuilder
- type() - Method in class org.elasticsearch.search.aggregations.bucket.composite.TermsValuesSourceBuilder
- type() - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- type() - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
-
Get the type used in this sort.
- type() - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
- type() - Method in class org.elasticsearch.transport.TransportRequestOptions
- type(Object) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Sets the type of the text query.
- type(String) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
The type of the repository "fs" - shared filesystem repository
- type(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingClusterStateUpdateRequest
- type(String) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
-
The type of the mappings.
- type(String) - Method in class org.elasticsearch.action.delete.DeleteRequest
-
Deprecated.Types are in the process of being removed.
- type(String) - Method in interface org.elasticsearch.action.DocWriteRequest
-
Set the type for this request
- type(String) - Method in class org.elasticsearch.action.explain.ExplainRequest
-
Deprecated.Types are in the process of being removed.
- type(String) - Method in class org.elasticsearch.action.get.GetRequest
-
Deprecated.Types are in the process of being removed.
- type(String) - Method in class org.elasticsearch.action.index.IndexRequest
-
Deprecated.Types are in the process of being removed.
- type(String) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
-
Sets the type of document to get the term vector for.
- type(String) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Types are in the process of being removed.
- type(String) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
For BWC: Parse type from type name.
- type(String) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
-
Deprecated.Types are in the process of being removed.
- type(GeoExecType) - Method in class org.elasticsearch.index.query.GeoBoundingBoxQueryBuilder
-
Sets the type of executing of the geo bounding box.
- type(MultiMatchQueryBuilder.Type) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
-
Sets the type of the text query.
- type(MultiMatchQueryBuilder.Type) - Method in class org.elasticsearch.index.query.QueryStringQueryBuilder
- type(HotThreads.ReportType) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- type(HotThreads.ReportType) - Method in class org.elasticsearch.monitor.jvm.HotThreads
- TYPE - Enum constant in enum class org.elasticsearch.ingest.IngestDocument.Metadata
- TYPE - Static variable in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus
- TYPE - Static variable in class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction
- TYPE - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- TYPE - Static variable in class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- TYPE - Static variable in class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- TYPE - Static variable in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- TYPE - Static variable in class org.elasticsearch.cluster.metadata.IndexGraveyard
- TYPE - Static variable in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- TYPE - Static variable in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
- TYPE - Static variable in class org.elasticsearch.cluster.RepositoryCleanupInProgress
- TYPE - Static variable in class org.elasticsearch.cluster.RestoreInProgress
- TYPE - Static variable in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- TYPE - Static variable in class org.elasticsearch.cluster.SnapshotsInProgress
- TYPE - Static variable in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState
- TYPE - Static variable in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards
- TYPE - Static variable in class org.elasticsearch.index.mapper.CustomDocValuesField
- TYPE - Static variable in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata
- TYPE - Static variable in class org.elasticsearch.ingest.DropProcessor
- TYPE - Static variable in class org.elasticsearch.ingest.IngestMetadata
- TYPE - Static variable in class org.elasticsearch.ingest.PipelineProcessor
- TYPE - Static variable in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- TYPE - Static variable in class org.elasticsearch.repositories.fs.FsRepository
- TYPE - Static variable in class org.elasticsearch.script.ScriptMetadata
-
The type of
ClusterState
data. - TYPE - Static variable in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
-
Deprecated.
- TYPE - Static variable in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion
-
Deprecated.
- TYPE - Static variable in class org.elasticsearch.search.suggest.Suggest.Suggestion
- TYPE - Static variable in class org.elasticsearch.search.suggest.term.TermSuggestion
-
Deprecated.
- TYPE - Static variable in class org.elasticsearch.upgrades.FeatureMigrationResults
- TYPE_FIELD - Static variable in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- TYPE_FIELD - Static variable in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- TYPE_FIELD - Static variable in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo.ParameterInfo
- TYPE_FIELD - Static variable in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
- TYPE_FIELD - Static variable in class org.elasticsearch.search.sort.ScriptSortBuilder
- TYPE_NAME - Static variable in interface org.elasticsearch.search.aggregations.metrics.PercentileRanks
- TYPE_NAME - Static variable in interface org.elasticsearch.search.aggregations.metrics.Percentiles
- TYPE_SETTING - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- TypeConverter - Interface in org.elasticsearch.common.inject.spi
-
Converts constant string values to a different type.
- TypeConverterBinding - Class in org.elasticsearch.common.inject.spi
-
Registration of type converters for matching target types.
- TYPED_KEYS_DELIMITER - Static variable in interface org.elasticsearch.search.aggregations.Aggregation
-
Delimiter used when prefixing aggregation names with their type using the typed_keys parameter
- TYPED_KEYS_PARAM - Static variable in class org.elasticsearch.rest.action.search.RestSearchAction
- TypeEncounter<I> - Interface in org.elasticsearch.common.inject.spi
-
Context of an injectable type encounter.
- TypeFieldMapper - Class in org.elasticsearch.index.mapper
- TypeFieldMapper.Defaults - Class in org.elasticsearch.index.mapper
- TypeFieldMapper.TypeFieldType - Class in org.elasticsearch.index.mapper
- TypeFieldType - Class in org.elasticsearch.index.mapper
-
Mediates access to the deprecated _type field
- TypeFieldType(String) - Constructor for class org.elasticsearch.index.mapper.TypeFieldMapper.TypeFieldType
- typeFilter(String[]) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypeFieldType
-
Build a type filter This does not emit a deprecation warning, as it is only called when a type has been specified in a REST request and warnings will have already been emitted at the REST layer.
- typeFromAggregator(Aggregator) - Static method in class org.elasticsearch.search.profile.aggregation.InternalAggregationProfileTree
- TypeListener - Interface in org.elasticsearch.common.inject.spi
-
Listens for Guice to encounter injectable types.
- TypeListenerBinding - Class in org.elasticsearch.common.inject.spi
-
Binds types (picked using a Matcher) to an type listener.
- TypeLiteral<T> - Class in org.elasticsearch.common.inject
-
Represents a generic type
T
. - TypeLiteral() - Constructor for class org.elasticsearch.common.inject.TypeLiteral
-
Constructs a new type literal.
- typeMapper() - Method in class org.elasticsearch.index.mapper.DocumentMapper
- TypeMissingException - Exception in org.elasticsearch.indices
- TypeMissingException(String, String...) - Constructor for exception org.elasticsearch.indices.TypeMissingException
- TypeMissingException(StreamInput) - Constructor for exception org.elasticsearch.indices.TypeMissingException
- TypeMissingException(Index, String...) - Constructor for exception org.elasticsearch.indices.TypeMissingException
- TypeMissingException(Index, Throwable, String...) - Constructor for exception org.elasticsearch.indices.TypeMissingException
- typeName() - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.BinaryFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.BooleanScriptFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper.TimestampFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.DateScriptFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.DocCountFieldMapper.DocCountFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.DoubleScriptFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
- typeName() - Method in class org.elasticsearch.index.mapper.FieldMapper
- typeName() - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.RootFlattenedFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.GeoPointScriptFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.GeoShapeFieldMapper.GeoShapeFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper.IgnoredFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.IpScriptFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Returns the name of this type, as would be specified in mapping properties
- typeName() - Method in class org.elasticsearch.index.mapper.Mapper
-
Returns a name representing the type of this mapper.
- typeName() - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- typeName() - Method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
-
Get the associated type name.
- typeName() - Method in class org.elasticsearch.index.mapper.ObjectMapper
- typeName() - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- typeName() - Method in enum class org.elasticsearch.index.mapper.RangeType
-
Get the associated type name.
- typeName() - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypeFieldType
- typeName() - Method in class org.elasticsearch.index.mapper.TypeFieldType
- typeName() - Method in enum class org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- typeName() - Method in interface org.elasticsearch.search.aggregations.support.ValuesSourceType
-
Returns the name of the Values Source Type for stats purposes
- typeParser(String) - Method in class org.elasticsearch.index.mapper.MappingParserContext
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.FieldAliasMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.NestedObjectMapper.TypeParser
- TypeParser() - Constructor for class org.elasticsearch.index.mapper.ObjectMapper.TypeParser
- TypeParser(BiFunction<String, MappingParserContext, FieldMapper.Builder>) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.TypeParser
-
Creates a new TypeParser
- TypeParser(BiFunction<String, MappingParserContext, FieldMapper.Builder>, BiConsumer<String, MappingParserContext>) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.TypeParser
- TypeParsers - Class in org.elasticsearch.index.mapper
- TypeParsers() - Constructor for class org.elasticsearch.index.mapper.TypeParsers
- typeQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Deprecated.Types are going away, prefer filtering on a field.
- TypeQueryBuilder - Class in org.elasticsearch.index.query
- TypeQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.TypeQueryBuilder
- TypeQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.TypeQueryBuilder
-
Read from a stream.
- types() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- types() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- types() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- types() - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
Document types to return stats for.
- types() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
Document types to return stats for.
- types() - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- types() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Deprecated.Types are in the process of being removed. Instead of using a type, prefer to filter on a field on the document.
- types() - Method in class org.elasticsearch.action.search.SearchRequest
-
Deprecated.Types are in the process of being removed. Instead of using a type, prefer to filter on a field on the document.
- types() - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- types() - Method in class org.elasticsearch.index.query.IdsQueryBuilder
-
Deprecated.Types are in the process of being removed, prefer to filter on a field instead.
- types() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Deprecated.Types are in the process of being removed. Instead of using a type, prefer to filter on a field of the document.
- types() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- types(String[]) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- types(String...) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- types(String...) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
-
Document types to return stats for.
- types(String...) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
-
Document types to return stats for.
- types(String...) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Deprecated.Types are in the process of being removed. Instead of using a type, prefer to filter on a field on the document.
- types(String...) - Method in class org.elasticsearch.action.search.SearchRequest
-
Deprecated.Types are in the process of being removed. Instead of using a type, prefer to filter on a field on the document.
- types(String...) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- types(String...) - Method in class org.elasticsearch.index.query.IdsQueryBuilder
-
Deprecated.Types are in the process of being removed, prefer to filter on a field instead.
- types(String...) - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
-
Deprecated.Types are in the process of being removed. Instead of using a type, prefer to filter on a field of the document.
- Types - Class in org.elasticsearch.common.inject.util
-
Static methods for working with types.
- TYPES - Enum constant in enum class org.elasticsearch.common.logging.DeprecationCategory
- TYPES_ALLOWED_SETTING - Static variable in class org.elasticsearch.script.ScriptService
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.index.mapper.TypeFieldMapper
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.index.reindex.ReindexRequest
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.admin.indices.RestCreateIndexAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.admin.indices.RestGetFieldMappingAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.admin.indices.RestGetIndexTemplateAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.admin.indices.RestGetIndicesAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.admin.indices.RestGetMappingAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.admin.indices.RestPutIndexTemplateAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.admin.indices.RestPutMappingAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.admin.indices.RestRolloverIndexAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.document.RestBulkAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.document.RestDeleteAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.document.RestGetAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.document.RestIndexAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.document.RestMultiGetAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.document.RestTermVectorsAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.document.RestUpdateAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.search.RestExplainAction
- TYPES_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.search.RestSearchAction
- TYPES_V7_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.index.mapper.TypeFieldType
- typesAllowed - Variable in class org.elasticsearch.script.ScriptLanguagesInfo
- typesExists(TypesExistsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deprecated.Types are deprecated and are in the process of being removed.
- typesExists(TypesExistsRequest, ActionListener<TypesExistsResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Deprecated.Types are deprecated and are in the process of being removed.
- TypesExistsAction - Class in org.elasticsearch.action.admin.indices.exists.types
- TypesExistsRequest - Class in org.elasticsearch.action.admin.indices.exists.types
- TypesExistsRequest() - Constructor for class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- TypesExistsRequest(String[], String...) - Constructor for class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- TypesExistsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- TypesExistsRequestBuilder - Class in org.elasticsearch.action.admin.indices.exists.types
-
Deprecated.
- TypesExistsRequestBuilder(ElasticsearchClient, TypesExistsAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequestBuilder
-
Deprecated.
- TypesExistsResponse - Class in org.elasticsearch.action.admin.indices.exists.types
-
Whether all of the existed types exist.
- TypesExistsResponse(boolean) - Constructor for class org.elasticsearch.action.admin.indices.exists.types.TypesExistsResponse
U
- uid() - Method in class org.elasticsearch.index.engine.Engine.Get
- uid() - Method in class org.elasticsearch.index.engine.Engine.NoOp
- uid() - Method in class org.elasticsearch.index.engine.Engine.Operation
- uid() - Method in class org.elasticsearch.index.fieldvisitor.FieldsVisitor
- uid() - Method in class org.elasticsearch.index.translog.Translog.Delete
- Uid - Class in org.elasticsearch.index.mapper
- Uid(String, String) - Constructor for class org.elasticsearch.index.mapper.Uid
- unassigned() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
- unassigned() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
The shard is unassigned (not allocated to any node).
- UNASSIGNED - Enum constant in enum class org.elasticsearch.cluster.routing.ShardRoutingState
-
The shard is not assigned to any node.
- UNASSIGNED_PRIMARY_TERM - Static variable in class org.elasticsearch.index.seqno.SequenceNumbers
-
Represents an unassigned primary term (e.g., when a primary shard was not yet allocated)
- UNASSIGNED_QUEUED - Static variable in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
-
Shard snapshot status for shards that are waiting for another operation to finish before they can be assigned to a node.
- UNASSIGNED_SEQ_NO - Static variable in class org.elasticsearch.index.seqno.SequenceNumbers
-
Represents an unassigned sequence number (e.g., can be used on primary operations before they are executed).
- unassignedInfo() - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Additional metadata on why the shard is/was unassigned.
- UnassignedInfo - Class in org.elasticsearch.cluster.routing
-
Holds additional information as to why the shard is in unassigned state.
- UnassignedInfo(UnassignedInfo.Reason, String) - Constructor for class org.elasticsearch.cluster.routing.UnassignedInfo
-
creates an UnassignedInfo object based on **current** time
- UnassignedInfo(UnassignedInfo.Reason, String, Exception, int, long, long, boolean, UnassignedInfo.AllocationStatus, Set<String>, String) - Constructor for class org.elasticsearch.cluster.routing.UnassignedInfo
- UnassignedInfo(StreamInput) - Constructor for class org.elasticsearch.cluster.routing.UnassignedInfo
- UnassignedInfo.AllocationStatus - Enum Class in org.elasticsearch.cluster.routing
-
Captures the status of an unsuccessful allocation attempt for the shard, causing it to remain in the unassigned state.
- UnassignedInfo.Reason - Enum Class in org.elasticsearch.cluster.routing
-
Reason why the shard is in unassigned state.
- unassignedInfoUpdated(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingNodesChangedObserver
- unassignedInfoUpdated(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.AbstractRoutingChangesObserver
- unassignedInfoUpdated(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.cluster.routing.RoutingChangesObserver.DelegatingRoutingChangesObserver
- unassignedInfoUpdated(ShardRouting, UnassignedInfo) - Method in interface org.elasticsearch.cluster.routing.RoutingChangesObserver
-
Called when an unassigned shard's unassigned information was updated
- unassignedInfoUpdated(ShardRouting, UnassignedInfo) - Method in class org.elasticsearch.snapshots.RestoreService.RestoreInProgressUpdater
- UnassignedIterator() - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
- UnassignedShards(RoutingNodes) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards
- unassignPersistentTask(String, long, String, ActionListener<PersistentTasksCustomMetadata.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksClusterService
-
This unassigns a task from any node, i.e.
- UNAUTHORIZED - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The request requires user authentication.
- UNAVAILABLE_EXPECTED_SHARD_SIZE - Static variable in class org.elasticsearch.cluster.routing.ShardRouting
-
Used if shard size is not available
- UNAVAILABLE_WRITER_UUID - Static variable in class org.elasticsearch.index.store.StoreFileMetadata
- UnavailableShardsException - Exception in org.elasticsearch.action
- UnavailableShardsException(String, int, String, Object...) - Constructor for exception org.elasticsearch.action.UnavailableShardsException
- UnavailableShardsException(StreamInput) - Constructor for exception org.elasticsearch.action.UnavailableShardsException
- UnavailableShardsException(ShardId, String, Object...) - Constructor for exception org.elasticsearch.action.UnavailableShardsException
- UncategorizedExecutionException - Exception in org.elasticsearch.common.util.concurrent
- UncategorizedExecutionException(String, Throwable) - Constructor for exception org.elasticsearch.common.util.concurrent.UncategorizedExecutionException
- UncategorizedExecutionException(StreamInput) - Constructor for exception org.elasticsearch.common.util.concurrent.UncategorizedExecutionException
- unchanged() - Static method in class org.elasticsearch.cluster.LocalClusterUpdateTask
-
no changes were made to the cluster state.
- uncompress(BytesReference) - Method in interface org.elasticsearch.common.compress.Compressor
-
Decompress bytes into a newly allocated buffer.
- uncompress(BytesReference) - Static method in class org.elasticsearch.common.compress.CompressorFactory
-
Decompress the provided
BytesReference
. - uncompress(BytesReference) - Method in class org.elasticsearch.common.compress.DeflateCompressor
- uncompressed() - Method in class org.elasticsearch.common.compress.CompressedXContent
-
Return the uncompressed bytes.
- uncompressIfNeeded(BytesReference) - Static method in class org.elasticsearch.common.compress.CompressorFactory
-
Uncompress the provided data, data can be detected as compressed using
CompressorFactory.isCompressed(BytesReference)
. - UNCONFIGURED_BOOTSTRAP_TIMEOUT_SETTING - Static variable in class org.elasticsearch.cluster.coordination.ClusterBootstrapService
- UNHEALTHY - Enum constant in enum class org.elasticsearch.monitor.StatusInfo.Status
- UNICAST_HOSTS_FILE - Static variable in class org.elasticsearch.discovery.FileBasedSeedHostsProvider
- UnicastPingRequest(int, TimeValue, ZenPing.PingResponse) - Constructor for class org.elasticsearch.discovery.zen.UnicastZenPing.UnicastPingRequest
- UnicastPingRequest(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.UnicastZenPing.UnicastPingRequest
- UnicastPingResponse(int, ZenPing.PingResponse[]) - Constructor for class org.elasticsearch.discovery.zen.UnicastZenPing.UnicastPingResponse
- UnicastPingResponse(StreamInput) - Constructor for class org.elasticsearch.discovery.zen.UnicastZenPing.UnicastPingResponse
- UnicastZenPing - Class in org.elasticsearch.discovery.zen
- UnicastZenPing(Settings, ThreadPool, TransportService, SeedHostsProvider, PingContextProvider) - Constructor for class org.elasticsearch.discovery.zen.UnicastZenPing
- UnicastZenPing.PingingRound - Class in org.elasticsearch.discovery.zen
- UnicastZenPing.UnicastPingRequest - Class in org.elasticsearch.discovery.zen
- UnicastZenPing.UnicastPingResponse - Class in org.elasticsearch.discovery.zen
- unicastZenPingExecutorService - Variable in class org.elasticsearch.discovery.zen.UnicastZenPing
- UNICODE_CHARACTER_CLASS - Static variable in class org.elasticsearch.common.regex.Regex
-
This Regex /
Pattern
flag is supported from Java 7 on. - UnifiedHighlighter - Class in org.elasticsearch.search.fetch.subphase.highlight
- UnifiedHighlighter() - Constructor for class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- union(Set<T>, Set<T>) - Static method in class org.elasticsearch.common.util.set.Sets
- UniqueAnnotations - Class in org.elasticsearch.common.inject.internal
- unit - Variable in class org.elasticsearch.common.unit.DistanceUnit.Distance
- unit() - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- unit() - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- unit() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns the distance unit to use.
- unit(String) - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- unit(DistanceUnit) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder
- unit(DistanceUnit) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
The distance unit to use.
- unit(DateHistogramInterval) - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- UNKNOWN - Enum constant in enum class org.elasticsearch.Build.Flavor
- UNKNOWN - Enum constant in enum class org.elasticsearch.Build.Type
- UNKNOWN - Static variable in class org.elasticsearch.index.shard.IndexLongFieldRange
-
Sentinel value indicating the actual range is unknown, for instance because more docs may be added in future.
- UNKNOWN - Static variable in class org.elasticsearch.index.shard.ShardLongFieldRange
-
Sentinel value indicating the actual range is unknown, for instance because more docs may be added in future.
- UNKNOWN - Static variable in class org.elasticsearch.indices.recovery.RecoveryState.Index
- UNKNOWN - Static variable in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- UNKNOWN_CLUSTER_UUID - Static variable in class org.elasticsearch.cluster.metadata.Metadata
- UNKNOWN_CLUSTER_VERSION - Static variable in class org.elasticsearch.repositories.RepositoryStatsSnapshot
- UNKNOWN_POSITION - Static variable in exception org.elasticsearch.common.ParsingException
- UNKNOWN_POSITION - Static variable in exception org.elasticsearch.search.SearchParseException
- UNKNOWN_REPO_GEN - Static variable in class org.elasticsearch.repositories.RepositoryData
-
The generation value indicating that the repository generation is unknown.
- UNKNOWN_RESERVED_BYTES - Static variable in class org.elasticsearch.index.store.StoreStats
-
Sentinel value for cases where the shard does not yet know its reserved size so we must fall back to an estimate, for instance prior to receiving the list of files in a peer recovery.
- UNKNOWN_SOURCE - Static variable in class org.elasticsearch.common.inject.internal.SourceProvider
-
Indicates that the source is unknown.
- UNKNOWN_UUID - Static variable in class org.elasticsearch.cluster.ClusterState
- UNKNOWN_VERSION - Static variable in class org.elasticsearch.cluster.ClusterState
- UnknownCondition(String, Object) - Constructor for class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownCondition
- unknownCurrentTermAndVersion(long, Map<Index, Long>) - Static method in class org.elasticsearch.cluster.metadata.Manifest
- UnknownMetadataCustom(String, Map<String, Object>) - Constructor for class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownMetadataCustom
- unknownMetaFieldConsumer - Static variable in class org.elasticsearch.search.SearchHit
- unlike(String[]) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the text from which the terms should not be selected from.
- unlike(MoreLikeThisQueryBuilder.Item[]) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
-
Sets the documents from which the terms should not be selected from.
- unlikeItems() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- unlikeTexts() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder
- UNLIMITED_COMPILATION_RATE - Static variable in class org.elasticsearch.script.ScriptCache
- unlock() - Method in class org.elasticsearch.index.engine.Engine.NoOpLock
- Unmapped(String, AggregatorFactories, R[], boolean, DocValueFormat, AggregationContext, Aggregator, InternalRange.Factory, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Unmapped
- UNMAPPED_TYPE - Static variable in class org.elasticsearch.search.sort.FieldSortBuilder
- UnmappedRareTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Result of the RareTerms aggregation when the field is unmapped.
- UnmappedRareTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
-
Read from a stream.
- UnmappedRareTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
- UnmappedSampler - Class in org.elasticsearch.search.aggregations.bucket.sampler
- UnmappedSampler(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.sampler.UnmappedSampler
-
Read from a stream.
- UnmappedSignificantTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Result of the running the significant terms aggregation on an unmapped field.
- UnmappedSignificantTerms(String, int, long, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- UnmappedSignificantTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
-
Read from a stream.
- UnmappedSignificantTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Concrete type that can't be built because Java needs a concrete type so
InternalTerms.Bucket
can have a self type but UnmappedTerms doesn't ever need to build it because it never returns any buckets. - UnmappedTerms - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Result of the
TermsAggregator
when the field is unmapped. - UnmappedTerms(String, BucketOrder, int, long, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- UnmappedTerms(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
-
Read from a stream.
- UnmappedTerms.Bucket - Class in org.elasticsearch.search.aggregations.bucket.terms
-
Concrete type that can't be built because Java needs a concrete type so
InternalTerms.Bucket
can have a self type but UnmappedTerms doesn't ever need to build it because it never returns any buckets. - unmappedType() - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Returns the type to use in case the current field is not mapped in an index.
- unmappedType(String) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
-
Set the type to use in case the current field is not mapped in an index.
- UNPROCESSABLE_ENTITY - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The 422 (Unprocessable Entity) status code means the server understands the content type of the request entity (hence a 415(Unsupported Media Type) status code is inappropriate), and the syntax of the request entity is correct (thus a 400 (Bad Request) status code is inappropriate) but was unable to process the contained instructions.
- unrecognized(RestRequest, Set<String>, Set<String>, String) - Method in class org.elasticsearch.rest.BaseRestHandler
- UNRECOVERABLE - Enum constant in enum class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
- UNRECOVERED_CLUSTER_VERSION - Static variable in class org.elasticsearch.discovery.zen.ElectMasterService.MasterCandidate
- unreferenceAll() - Method in class org.elasticsearch.gateway.MetaStateService
-
Creates empty cluster state file on disk, deleting global metadata and unreferencing all index metadata (only used for dangling indices at that point).
- unregister(Task) - Method in class org.elasticsearch.tasks.TaskManager
-
Unregister the task
- UNREGISTERED_KEY - Static variable in class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry
- unregisterInternalRepository(String) - Method in class org.elasticsearch.repositories.RepositoriesService
- unregisterRepository(DeleteRepositoryRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.repositories.RepositoriesService
-
Unregisters repository in the cluster
- UnsafeBootstrapMasterCommand - Class in org.elasticsearch.cluster.coordination
- unsafeNextWriteIndexAndGeneration(Metadata, Version) - Method in class org.elasticsearch.cluster.metadata.DataStream
-
Like
DataStream.nextWriteIndexAndGeneration(Metadata, Version)
, but does no validation, use with care only. - unsafeRollover(Index, long) - Method in class org.elasticsearch.cluster.metadata.DataStream
-
Like
DataStream.rollover(Index, long)
, but does no validation, use with care only. - UNSCOPED - Static variable in class org.elasticsearch.common.inject.internal.Scoping
-
No scoping annotation has been applied.
- UNSET_AUTO_GENERATED_TIMESTAMP - Static variable in class org.elasticsearch.action.index.IndexRequest
-
Value for
IndexRequest.getAutoGeneratedTimestamp()
if the document has an external provided ID. - UNSIGNED_LONG_SHIFTED - Static variable in interface org.elasticsearch.search.DocValueFormat
- UNSUPPORTED_MEDIA_TYPE - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The server is refusing to service the request because the entity of the request is in a format not supported by the requested resource for the requested method.
- UntargettedBinding<T> - Interface in org.elasticsearch.common.inject.spi
-
An untargetted binding.
- UntargettedBindingImpl<T> - Class in org.elasticsearch.common.inject.internal
- UntargettedBindingImpl(Object, Key<T>, Scoping) - Constructor for class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- UntargettedBindingImpl(Injector, Key<T>, Object) - Constructor for class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- until(Temporal, TemporalUnit) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- UNTRUSTED_CODEBASE - Static variable in class org.elasticsearch.bootstrap.BootstrapInfo
-
codebase location for untrusted scripts (provide some additional safety)
- UNUSED - Enum constant in enum class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus.AllocationStatus
-
Not allocated
- unweightedAvg(double[]) - Static method in class org.elasticsearch.search.aggregations.pipeline.MovingFunctions
-
Calculate a simple unweighted (arithmetic) moving average.
- unwrap() - Method in class org.elasticsearch.client.ParentTaskAssigningClient
-
Fetch the wrapped client.
- unwrap() - Method in interface org.elasticsearch.common.util.concurrent.WrappedRunnable
- unwrap(Runnable) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
- unwrap(Runnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- unwrap(Runnable) - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
- unwrap(Runnable) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Unwraps a command that was previously wrapped by
ThreadContext.preserveContext(Runnable)
. - unwrap(Throwable, Class<?>...) - Static method in class org.elasticsearch.ExceptionsHelper
-
Looks at the given Throwable and its cause(s) and returns the first Throwable that is of one of the given classes or
null
if no matching Throwable is found. - unwrap(Aggregator) - Static method in class org.elasticsearch.search.profile.aggregation.ProfilingAggregator
- unwrapAction(String) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Unwraps a proxy action and returns the underlying action
- unwrapCause() - Method in exception org.elasticsearch.ElasticsearchException
-
Unwraps the actual cause from the exception for cases when the exception is a
ElasticsearchWrapperException
. - unwrapCause(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
- unwrapCausesAndSuppressed(Throwable, Predicate<Throwable>) - Static method in class org.elasticsearch.ExceptionsHelper
- unwrapConnection(Transport.Connection) - Static method in class org.elasticsearch.transport.TransportService
-
Unwraps and returns the actual underlying connection of the given connection.
- unwrapCorruption(Throwable) - Static method in class org.elasticsearch.ExceptionsHelper
-
Looks at the given Throwable's and its cause(s) as well as any suppressed exceptions on the Throwable as well as its causes and returns the first corruption indicating exception (as defined by
ExceptionsHelper.CORRUPTION_EXCEPTIONS
) it finds. - unwrapRequest(TransportRequest) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Unwraps a proxy request and returns the original request
- unwrapSingleton(MultiGeoPointValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns a single-valued view of the
MultiGeoPointValues
, if it was previously wrapped withFieldData.singleton(GeoPointValues)
, or null. - unwrapSingleton(SortedBinaryDocValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns a single-valued view of the
SortedBinaryDocValues
, if it was previously wrapped withFieldData.singleton(BinaryDocValues)
, or null. - unwrapSingleton(SortedNumericDoubleValues) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns a single-valued view of the
SortedNumericDoubleValues
, if it was previously wrapped withDocValues.singleton(NumericDocValues)
, or null. - update(byte[]) - Method in class org.elasticsearch.common.hash.Murmur3Hasher
-
Supplies some or all of the bytes to be hashed.
- update(String, Boolean, Map<String, Object>) - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
-
Returns a new
DataStreamAlias
instance with the provided data stream name added to it as a new member. - update(Map<String, Object>, Map<String, Object>, boolean) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Updates the provided changes into the source.
- update(UpdateRequest) - Method in interface org.elasticsearch.client.Client
-
Updates a document based on a script.
- update(UpdateRequest) - Method in class org.elasticsearch.client.support.AbstractClient
- update(UpdateRequest, ActionListener<UpdateResponse>) - Method in interface org.elasticsearch.client.Client
-
Updates a document based on a script.
- update(UpdateRequest, ActionListener<UpdateResponse>) - Method in class org.elasticsearch.client.support.AbstractClient
- update(PreVoteResponse, DiscoveryNode) - Method in class org.elasticsearch.cluster.coordination.PreVoteCollector
- update(FieldMapper, MapperBuilderContext) - Method in class org.elasticsearch.index.mapper.FieldMapper.MultiFields.Builder
- UPDATE - Enum constant in enum class org.elasticsearch.action.DocWriteRequest.OpType
-
Updates a document
- UPDATE_SNAPSHOT_STATUS_ACTION_NAME - Static variable in class org.elasticsearch.snapshots.SnapshotsService
- updateableBoolParam(String, Function<FieldMapper, Explicit<Boolean>>, boolean) - Static method in class org.elasticsearch.index.mapper.MetadataFieldMapper
-
Declares an updateable boolean parameter for a metadata field We need to distinguish between explicit configuration and default value for metadata fields, because mapping updates will carry over the previous metadata values if a metadata field is not explicitly declared in the update.
- UpdateAction - Class in org.elasticsearch.action.update
- updateBlocks(IndexMetadata) - Method in class org.elasticsearch.cluster.block.ClusterBlocks.Builder
- UpdateByQueryAction - Class in org.elasticsearch.index.reindex
- UpdateByQueryRequest - Class in org.elasticsearch.index.reindex
-
Request to update some documents.
- UpdateByQueryRequest() - Constructor for class org.elasticsearch.index.reindex.UpdateByQueryRequest
- UpdateByQueryRequest(String...) - Constructor for class org.elasticsearch.index.reindex.UpdateByQueryRequest
- UpdateByQueryRequest(StreamInput) - Constructor for class org.elasticsearch.index.reindex.UpdateByQueryRequest
- UpdateByQueryRequestBuilder - Class in org.elasticsearch.index.reindex
- UpdateByQueryRequestBuilder(ElasticsearchClient, ActionType<BulkByScrollResponse>) - Constructor for class org.elasticsearch.index.reindex.UpdateByQueryRequestBuilder
- updateCompressionScheme(Compression.Scheme) - Method in class org.elasticsearch.transport.InboundAggregator
- UPDATED - Enum constant in enum class org.elasticsearch.action.DocWriteResponse.Result
- UPDATED_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- updatedClusterState(ClusterState) - Method in class org.elasticsearch.repositories.FinalizeSnapshotContext
- updateDocCountError(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.AbstractInternalTerms.AbstractTermsBucket
- updateDocCountError(long) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- updatedSettings() - Method in class org.elasticsearch.plugins.PluginsService
- updatedShardGenerations() - Method in class org.elasticsearch.repositories.FinalizeSnapshotContext
- updatedSourceAsMap() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
- updateDynamicSettings(Settings, Settings.Builder, Settings.Builder, String) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Updates a target settings builder with new, updated or deleted settings from a given settings builder.
- updateFastResponseState(long, Coordinator.Mode) - Method in class org.elasticsearch.cluster.coordination.FollowersChecker
-
The system is normally in a state in which every follower remains a follower of a stable leader in a single term for an extended period of time, and therefore our response to every follower check is the same.
- updateFromMaster(long, Set<String>, IndexShardRoutingTable) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Notifies the tracker of the current allocation IDs in the cluster state.
- updateFromSettings(BreakerSettings, Settings) - Static method in class org.elasticsearch.indices.breaker.BreakerSettings
- updateGlobalCheckpointForShard(String, long) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Update the local knowledge of the global checkpoint for the specified allocation ID.
- updateGlobalCheckpointForShard(String, long) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Update the local knowledge of the persisted global checkpoint for the specified allocation ID.
- updateGlobalCheckpointForShard(String, long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Update the local knowledge of the persisted global checkpoint for the specified allocation ID.
- updateGlobalCheckpointForShard(ShardId) - Method in class org.elasticsearch.index.seqno.GlobalCheckpointSyncAction
- updateGlobalCheckpointOnReplica(long, String) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Updates the global checkpoint on a replica shard after it has been updated by the primary.
- updateGlobalCheckpointOnReplica(long, String) - Method in class org.elasticsearch.index.shard.IndexShard
-
Updates the global checkpoint on a replica shard after it has been updated by the primary.
- UpdateHelper - Class in org.elasticsearch.action.update
-
Helper for translating an update request to an index, delete request or update response.
- UpdateHelper(ScriptService) - Constructor for class org.elasticsearch.action.update.UpdateHelper
- UpdateHelper.ContextFields - Class in org.elasticsearch.action.update
-
Field names used to populate the script context
- UpdateHelper.Result - Class in org.elasticsearch.action.update
- updateIndexMetadata(IndexMetadata) - Method in class org.elasticsearch.index.IndexSettings
-
Updates the settings and index metadata and notifies all registered settings consumers with the new settings iff at least one setting has changed.
- UpdateIndexShardSnapshotStatusRequest - Class in org.elasticsearch.snapshots
-
Internal request that is used to send changes in snapshot status to master
- UpdateIndexShardSnapshotStatusRequest(StreamInput) - Constructor for class org.elasticsearch.snapshots.UpdateIndexShardSnapshotStatusRequest
- UpdateIndexShardSnapshotStatusRequest(Snapshot, ShardId, SnapshotsInProgress.ShardSnapshotStatus) - Constructor for class org.elasticsearch.snapshots.UpdateIndexShardSnapshotStatusRequest
- updateIndicesReadOnly(Set<String>, ActionListener<Void>, boolean) - Method in class org.elasticsearch.cluster.routing.allocation.DiskThresholdMonitor
- updateLocalCheckpoint(String, long) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Notifies the service to update the local checkpoint for the shard with the provided allocation ID.
- updateLocalCheckpointForShard(String, long) - Method in interface org.elasticsearch.action.support.replication.ReplicationOperation.Primary
-
Notifies the primary of a local checkpoint for the given allocation.
- updateLocalCheckpointForShard(String, long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Notifies the service to update the local checkpoint for the shard with the provided allocation ID.
- updateMapping(IndexMetadata, IndexMetadata) - Method in class org.elasticsearch.index.IndexService
- updateMapping(IndexMetadata, IndexMetadata) - Method in class org.elasticsearch.index.mapper.MapperService
-
Update local mapping by applying the incoming mapping that have already been merged with the current one on the master
- updateMapping(IndexMetadata, IndexMetadata) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndex
-
Updates the mappings by applying the incoming ones
- updateMappingOnMaster(Index, String, Mapping, ActionListener<Void>) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
-
Update mappings on the master node, waiting for the change to be committed, but not for the mapping update to be applied on all nodes.
- updateMappings(Mapping, ShardId, String, ActionListener<Void>) - Method in interface org.elasticsearch.action.bulk.MappingUpdatePerformer
-
Update the mappings on the master.
- updateMaxUnsafeAutoIdTimestamp(long) - Method in class org.elasticsearch.index.engine.Engine
-
Forces this engine to advance its max_unsafe_auto_id_timestamp marker to at least the given timestamp.
- updateMaxUnsafeAutoIdTimestamp(long) - Method in class org.elasticsearch.index.engine.InternalEngine
- updateMaxUnsafeAutoIdTimestamp(long) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- updateMaxUnsafeAutoIdTimestamp(long) - Method in class org.elasticsearch.index.shard.IndexShard
-
Since operations stored in soft-deletes do not have max_auto_id_timestamp, the primary has to propagate its max_auto_id_timestamp (via
IndexShard.getMaxSeenAutoIdTimestamp()
of all processed append-only requests to replicas at the beginning of a peer-recovery or a primary-replica resync to force a replica to disable optimization for all append-only requests which are replicated via replication while its retry variants are replicated via recovery without auto_id_timestamp. - updateMetadata(IndexMetadata, IndexMetadata) - Method in class org.elasticsearch.index.IndexService
- updateMetadata(IndexMetadata, IndexMetadata) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndex
-
Updates the metadata of this index.
- updateMetadataWithRoutingChanges(RoutingTable) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Returns updated
Metadata
based on the changes that were made to the routing nodes - updateNodes(long, RoutingNodes) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- updateNodesAndPing(ClusterState) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection
-
make sure that nodes in clusterState are pinged.
- updateNumberOfReplicas(int, String[]) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
-
Update the number of replicas for the specified indices.
- updateNumberOfReplicas(int, String[]) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
-
Update the number of replicas for the specified indices.
- updatePersistentTaskState(String, long, PersistentTaskState, ActionListener<PersistentTasksCustomMetadata.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.PersistentTasksClusterService
-
Update the state of a persistent task
- updatePersistentTaskState(PersistentTaskState, ActionListener<PersistentTasksCustomMetadata.PersistentTask<?>>) - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
-
Updates the persistent state for the corresponding persistent task.
- UpdatePersistentTaskStatusAction - Class in org.elasticsearch.persistent
- UpdatePersistentTaskStatusAction.Request - Class in org.elasticsearch.persistent
- UpdatePersistentTaskStatusAction.RequestBuilder - Class in org.elasticsearch.persistent
- UpdatePersistentTaskStatusAction.TransportAction - Class in org.elasticsearch.persistent
- updater(Settings, Settings) - Method in interface org.elasticsearch.common.settings.AbstractScopedSettings.SettingUpdater
-
Returns a callable runnable that calls
AbstractScopedSettings.SettingUpdater.apply(Object, Settings, Settings)
if the settings actually changed. - updateRemoteCluster(String, Settings) - Method in class org.elasticsearch.transport.RemoteClusterAware
-
Subclasses must implement this to receive information about updated cluster aliases.
- updateRemoteCluster(String, Settings) - Method in class org.elasticsearch.transport.RemoteClusterService
- updateRepositoryUuidInMetadata(ClusterService, String, RepositoryData, ActionListener<Void>) - Static method in class org.elasticsearch.repositories.RepositoriesService
-
Set the repository UUID in the named repository's
RepositoryMetadata
to match the UUID in itsRepositoryData
, which may involve a cluster state update. - UpdateRequest - Class in org.elasticsearch.action.update
- UpdateRequest() - Constructor for class org.elasticsearch.action.update.UpdateRequest
- UpdateRequest(String, String) - Constructor for class org.elasticsearch.action.update.UpdateRequest
- UpdateRequest(String, String, String) - Constructor for class org.elasticsearch.action.update.UpdateRequest
-
Deprecated.Types are in the process of being removed. Use
UpdateRequest(String, String)
instead. - UpdateRequest(StreamInput) - Constructor for class org.elasticsearch.action.update.UpdateRequest
- UpdateRequest(ShardId, StreamInput) - Constructor for class org.elasticsearch.action.update.UpdateRequest
- UpdateRequestBuilder - Class in org.elasticsearch.action.update
- UpdateRequestBuilder(ElasticsearchClient, UpdateAction) - Constructor for class org.elasticsearch.action.update.UpdateRequestBuilder
- UpdateRequestBuilder(ElasticsearchClient, UpdateAction, String, String, String) - Constructor for class org.elasticsearch.action.update.UpdateRequestBuilder
- UpdateResponse - Class in org.elasticsearch.action.update
- UpdateResponse(ReplicationResponse.ShardInfo, ShardId, String, String, long, long, long, DocWriteResponse.Result) - Constructor for class org.elasticsearch.action.update.UpdateResponse
- UpdateResponse(StreamInput) - Constructor for class org.elasticsearch.action.update.UpdateResponse
- UpdateResponse(ShardId, String, String, long, long, long, DocWriteResponse.Result) - Constructor for class org.elasticsearch.action.update.UpdateResponse
-
Constructor to be used when a update didn't translate in a write.
- UpdateResponse(ShardId, StreamInput) - Constructor for class org.elasticsearch.action.update.UpdateResponse
- UpdateResponse.Builder - Class in org.elasticsearch.action.update
-
Builder class for
UpdateResponse
. - updateRestoreInfoWithRoutingChanges(RestoreInProgress) - Method in class org.elasticsearch.cluster.routing.allocation.RoutingAllocation
-
Returns updated
RestoreInProgress
based on the changes that were made to the routing nodes - updateRestoreStateWithDeletedIndices(RestoreInProgress, Set<Index>) - Static method in class org.elasticsearch.snapshots.RestoreService
- updateRetentionLeasesOnReplica(RetentionLeases) - Method in class org.elasticsearch.index.seqno.ReplicationTracker
-
Updates retention leases on a replica.
- updateRetentionLeasesOnReplica(RetentionLeases) - Method in class org.elasticsearch.index.shard.IndexShard
-
Updates retention leases on a replica.
- UpdateScript - Class in org.elasticsearch.script
-
An update script.
- UpdateScript(Map<String, Object>, Map<String, Object>) - Constructor for class org.elasticsearch.script.UpdateScript
- UpdateScript.Factory - Interface in org.elasticsearch.script
- updateSeqID(long, long) - Method in class org.elasticsearch.index.mapper.ParsedDocument
- updateSettings(ClusterUpdateSettingsRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Updates settings in the cluster.
- updateSettings(ClusterUpdateSettingsRequest, ActionListener<ClusterUpdateSettingsResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Update settings in the cluster.
- updateSettings(UpdateSettingsClusterStateUpdateRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataUpdateSettingsService
- updateSettings(UpdateSettingsRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Updates settings of one or more indices.
- updateSettings(UpdateSettingsRequest, ActionListener<AcknowledgedResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Updates settings of one or more indices.
- updateSettings(Settings, String...) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- updateSettings(Settings, Settings.Builder, Settings.Builder, String) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Updates a target settings builder with new, updated or deleted settings from a given settings builder.
- UpdateSettingsAction - Class in org.elasticsearch.action.admin.indices.settings.put
- UpdateSettingsClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.settings.put
-
Cluster state update request that allows to update settings for some indices
- UpdateSettingsClusterStateUpdateRequest() - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsClusterStateUpdateRequest
- updateSettingsRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
A request to update indices settings.
- UpdateSettingsRequest - Class in org.elasticsearch.action.admin.indices.settings.put
-
Request for an update index settings action
- UpdateSettingsRequest() - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- UpdateSettingsRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Constructs a new request to update settings for one or more indices
- UpdateSettingsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- UpdateSettingsRequest(Settings, String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
-
Constructs a new request to update settings for one or more indices
- UpdateSettingsRequestBuilder - Class in org.elasticsearch.action.admin.indices.settings.put
-
Builder for an update index settings request
- UpdateSettingsRequestBuilder(ElasticsearchClient, UpdateSettingsAction, String...) - Constructor for class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder
- updateShardState(ShardRouting, long, BiConsumer<IndexShard, ActionListener<PrimaryReplicaSyncer.ResyncTask>>, long, Set<String>, IndexShardRoutingTable) - Method in class org.elasticsearch.index.shard.IndexShard
- updateShardState(ShardRouting, long, BiConsumer<IndexShard, ActionListener<PrimaryReplicaSyncer.ResyncTask>>, long, Set<String>, IndexShardRoutingTable) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.Shard
-
Updates the shard state based on an incoming cluster state: - Updates and persists the new routing value.
- updateSourceContentType() - Method in class org.elasticsearch.action.update.UpdateHelper.Result
- updateState(ClusterState) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- updateState(ClusterState) - Method in class org.elasticsearch.repositories.FilterRepository
- updateState(ClusterState) - Method in interface org.elasticsearch.repositories.Repository
-
Update the repository with the incoming cluster state.
- updateTaskState(String, PersistentTaskState) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.Builder
-
Updates the task state
- updateUnassigned(UnassignedInfo, RecoverySource) - Method in class org.elasticsearch.cluster.routing.ShardRouting
- updateUnassigned(UnassignedInfo, RecoverySource, RoutingChangesObserver) - Method in interface org.elasticsearch.cluster.routing.allocation.ExistingShardsAllocator.UnassignedAllocationHandler
-
updates the unassigned info and recovery source on the current unassigned shard
- updateUnassigned(UnassignedInfo, RecoverySource, RoutingChangesObserver) - Method in class org.elasticsearch.cluster.routing.RoutingNodes.UnassignedShards.UnassignedIterator
-
updates the unassigned info and recovery source on the current unassigned shard
- updateVersion(long, long) - Method in enum class org.elasticsearch.index.VersionType
-
Returns the new version for a document, based on its current one and the specified in the request
- updateWithSnapshots(ClusterState, SnapshotsInProgress, SnapshotDeletionsInProgress) - Static method in class org.elasticsearch.snapshots.SnapshotsService
-
Shortcut to build new
ClusterState
from the current state and updated values ofSnapshotsInProgress
andSnapshotDeletionsInProgress
. - upgrade(UpgradeRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly upgrade one or more indices
- upgrade(UpgradeRequest) - Method in class org.elasticsearch.index.shard.IndexShard
-
Upgrades the shard to the current version of Lucene and returns the minimum segment version
- upgrade(UpgradeRequest, ActionListener<UpgradeResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Explicitly upgrade one or more indices
- upgrade(KeyStoreWrapper, Path, char[]) - Static method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Upgrades the format of the keystore, if necessary.
- UPGRADE_API_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.admin.indices.RestUpgradeActionDeprecated
- UPGRADE_ONLY_ANCIENT_SEGMENTS - Static variable in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest.Defaults
- UpgradeAction - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
Upgrade index/indices action.
- UPGRADED_INDEX_SUFFIX - Static variable in class org.elasticsearch.indices.SystemIndices
- upgradeIndexSettings(UpgradeSettingsClusterStateUpdateRequest, ActionListener<AcknowledgedResponse>) - Method in class org.elasticsearch.cluster.metadata.MetadataUpdateSettingsService
- UpgradeKeyStoreCommand - Class in org.elasticsearch.common.settings
-
A sub-command for the keystore CLI that enables upgrading the keystore format.
- upgradeOnlyAncientSegments() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest
-
Should the upgrade only the ancient (older major version of Lucene) segments? Defaults to
false
. - upgradeOnlyAncientSegments(boolean) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest
- upgradeRequest() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.ShardUpgradeRequest
- upgradeRequest(String...) - Static method in class org.elasticsearch.client.Requests
-
Creates an upgrade request.
- UpgradeRequest - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
A request to upgrade one or more indices.
- UpgradeRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest
-
Constructs an optimization request over one or more indices.
- UpgradeRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest
- UpgradeRequest.Defaults - Class in org.elasticsearch.action.admin.indices.upgrade.post
- UpgradeRequestBuilder - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
A request to upgrade one or more indices.
- UpgradeRequestBuilder(ElasticsearchClient, UpgradeAction) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequestBuilder
- UpgradeResponse - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
A response for the upgrade action.
- upgradeSettings(Settings) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Upgrade all settings eligible for upgrade in the specified settings instance.
- UpgradeSettingsAction - Class in org.elasticsearch.action.admin.indices.upgrade.post
- UpgradeSettingsClusterStateUpdateRequest - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
Cluster state update request that allows to change minimum compatibility settings for some indices
- UpgradeSettingsClusterStateUpdateRequest() - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsClusterStateUpdateRequest
- UpgradeSettingsRequest - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
Request for an update index settings action
- UpgradeSettingsRequest() - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequest
- UpgradeSettingsRequest(Map<String, Tuple<Version, String>>) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequest
-
Constructs a new request to update minimum compatible version settings for one or more indices
- UpgradeSettingsRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequest
- UpgradeSettingsRequestBuilder - Class in org.elasticsearch.action.admin.indices.upgrade.post
-
Builder for an update index settings request
- UpgradeSettingsRequestBuilder(ElasticsearchClient, UpgradeSettingsAction) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequestBuilder
- upgradeStatus(UpgradeStatusRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Check upgrade status of one or more indices
- upgradeStatus(UpgradeStatusRequest, ActionListener<UpgradeStatusResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Check upgrade status of one or more indices
- UpgradeStatusAction - Class in org.elasticsearch.action.admin.indices.upgrade.get
- UpgradeStatusRequest - Class in org.elasticsearch.action.admin.indices.upgrade.get
- UpgradeStatusRequest() - Constructor for class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusRequest
- UpgradeStatusRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusRequest
- UpgradeStatusRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusRequest
- UpgradeStatusRequestBuilder - Class in org.elasticsearch.action.admin.indices.upgrade.get
- UpgradeStatusRequestBuilder(ElasticsearchClient, UpgradeStatusAction) - Constructor for class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusRequestBuilder
- UpgradeStatusResponse - Class in org.elasticsearch.action.admin.indices.upgrade.get
- upgradeToCurrentVersion() - Method in class org.elasticsearch.env.NodeMetadata
- UPLOADED_DATA_BLOB_PREFIX - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- UPPER - Enum constant in enum class org.elasticsearch.search.aggregations.metrics.ExtendedStats.Bounds
- UPPER_POPULATION - Enum constant in enum class org.elasticsearch.search.aggregations.metrics.ExtendedStats.Bounds
- UPPER_SAMPLING - Enum constant in enum class org.elasticsearch.search.aggregations.metrics.ExtendedStats.Bounds
- upsert(byte[], int, int, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(byte[], XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(Object...) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(String, SingleFeatureMigrationResult, ActionListener<ClusterState>) - Static method in class org.elasticsearch.upgrades.MigrationResultsUpdateTask
-
Creates a task that will update the status of a feature migration.
- upsert(String, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(Map<String, Object>) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(Map<String, Object>, XContentType) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(IndexRequest) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the index request to be used if the document does not exists.
- upsert(XContentBuilder) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsert(XContentType, Object...) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the doc source of the update request to be used when the document does not exists.
- upsertRequest() - Method in class org.elasticsearch.action.update.UpdateRequest
- upserts - Variable in class org.elasticsearch.cluster.DiffableUtils.MapDiff
- URGENT - Enum constant in enum class org.elasticsearch.common.Priority
- uri() - Method in class org.elasticsearch.http.HttpPipelinedRequest
- uri() - Method in interface org.elasticsearch.http.HttpRequest
-
The uri of the rest request, with the query string.
- uri() - Method in class org.elasticsearch.rest.RestRequest
-
The uri of the rest request, with the query string.
- URIPattern - Class in org.elasticsearch.common.util
-
URI Pattern matcher The pattern is URI in which authority, path, query and fragment can be replace with simple pattern.
- URIPattern(String) - Constructor for class org.elasticsearch.common.util.URIPattern
-
Constructs uri pattern
- URL_REPOSITORY_TYPE - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- urlParamsToQueryBuilder(RestRequest) - Static method in class org.elasticsearch.rest.action.RestActions
- urls - Variable in class org.elasticsearch.plugins.PluginsService.Bundle
- UsageService - Class in org.elasticsearch.usage
-
A service to monitor usage of Elasticsearch features.
- UsageService() - Constructor for class org.elasticsearch.usage.UsageService
- USE_ADAPTIVE_REPLICA_SELECTION_SETTING - Static variable in class org.elasticsearch.cluster.routing.OperationRouting
- USE_CONTEXT_RATE_KEY_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.script.ScriptService
- USE_FOR_PEER_RECOVERY_SETTING - Static variable in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Setting that defines if the repository should be used to recover index files during peer recoveries.
- USE_NEW_FORMAT_SPECIFIERS - Static variable in class org.elasticsearch.common.joda.JodaDeprecationPatterns
- USE_PROXY - Enum constant in enum class org.elasticsearch.rest.RestStatus
-
The requested resource MUST be accessed through the proxy given by the Location field.
- USE_REAL_MEMORY_USAGE_SETTING - Static variable in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
- useAnyUnassignedShard() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
-
Returns
true
iff the first unassigned shard is to be used - useAnyUnassignedShard() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequestBuilder
-
Signal that the first unassigned shard should be used
- useCompressedOops() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
-
The value of the JVM flag UseCompressedOops, if available otherwise "unknown".
- useContextCache() - Method in class org.elasticsearch.script.ScriptService.ContextSettings
-
Should the context cache be used? This is true if "use-context" is set explicitly or implicitly, see above for implicit definition.
- useContextSet - Variable in class org.elasticsearch.script.ScriptService.ContextSettings
- used(long) - Method in class org.elasticsearch.common.util.LongLongHash
- used(long) - Method in class org.elasticsearch.common.util.LongObjectPagedHashMap
- usedDeprecatedField(String, Supplier<XContentLocation>, String) - Method in class org.elasticsearch.common.xcontent.LoggingDeprecationHandler
- usedDeprecatedField(String, Supplier<XContentLocation>, String, String) - Method in class org.elasticsearch.common.xcontent.LoggingDeprecationHandler
- usedDeprecatedName(String, Supplier<XContentLocation>, String, String) - Method in class org.elasticsearch.common.xcontent.LoggingDeprecationHandler
- useExplicitFieldOrder() - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Gets value set with
HighlightBuilder.useExplicitFieldOrder(boolean)
- useExplicitFieldOrder(boolean) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder
-
Send the fields to be highlighted using a syntax that is specific about the order in which they should be highlighted.
- useG1GC() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- useIndexGenerations(Version) - Static method in class org.elasticsearch.snapshots.SnapshotsService
-
Checks whether the metadata version supports writing
ShardGenerations
to the repository. - useOrSuppress(T, T) - Static method in class org.elasticsearch.ExceptionsHelper
- USER_DEFINED_METADATA - Static variable in class org.elasticsearch.cluster.service.ClusterService
- useRetentionLeasesInPeerRecovery() - Method in class org.elasticsearch.index.shard.IndexShard
- userInput - Variable in class org.elasticsearch.search.suggest.phrase.DirectCandidateGenerator.Candidate
- userMetadata() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- userMetadata() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- userMetadata() - Method in class org.elasticsearch.repositories.SnapshotShardContext
- userMetadata() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns the custom metadata that was attached to this snapshot at creation time.
- userMetadata(Map<String, Object>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- userValuetypeHint() - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Gets the
ValueType
for the value produced by this source - userValuetypeHint(ValueType) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
-
Sets the
ValueType
for the value produced by this source - userValueTypeHint() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- userValueTypeHint(ValueType) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceAggregationBuilder
-
Sets the
ValueType
for the value produced by this aggregation - userValueTypeHint(ValueType) - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
This setter should only be used during parsing, to set the userValueTypeHint.
- useSerialGC() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- useShardGenerations(Version) - Static method in class org.elasticsearch.snapshots.SnapshotsService
-
Checks whether the metadata version supports writing
ShardGenerations
to the repository. - utcToLocalTime(long) - Method in class org.elasticsearch.common.LocalTimeOffset
-
Convert a time in utc into a the local time at this offset.
- UTF8StreamWriter - Class in org.elasticsearch.common.io
- UTF8StreamWriter() - Constructor for class org.elasticsearch.common.io.UTF8StreamWriter
-
Creates a UTF-8 writer having a byte buffer of moderate capacity (2048).
- UTF8StreamWriter(int) - Constructor for class org.elasticsearch.common.io.UTF8StreamWriter
-
Creates a UTF-8 writer having a byte buffer of specified capacity.
- utf8ToString() - Method in class org.elasticsearch.common.bytes.AbstractBytesReference
- utf8ToString() - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Interprets the referenced bytes as UTF8 bytes, returning the resulting string
- utf8ToString() - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- uuid() - Method in class org.elasticsearch.cluster.block.ClusterBlock
- uuid() - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
-
Return the repository UUID, if set and known.
- uuid() - Method in class org.elasticsearch.cluster.RestoreInProgress.Entry
-
Returns restore uuid
- uuid() - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- UUIDs - Class in org.elasticsearch.common
- UUIDs() - Constructor for class org.elasticsearch.common.UUIDs
- UUIDS_IN_REPO_DATA_VERSION - Static variable in class org.elasticsearch.snapshots.SnapshotsService
V
- v() - Method in class org.elasticsearch.common.recycler.NoneRecycler.NV
- v() - Method in interface org.elasticsearch.common.recycler.Recycler.V
-
Reference to the value.
- V_6_0_0 - Static variable in class org.elasticsearch.Version
- V_6_0_0_alpha1 - Static variable in class org.elasticsearch.Version
- V_6_0_0_alpha2 - Static variable in class org.elasticsearch.Version
- V_6_0_0_beta1 - Static variable in class org.elasticsearch.Version
- V_6_0_0_beta2 - Static variable in class org.elasticsearch.Version
- V_6_0_0_rc1 - Static variable in class org.elasticsearch.Version
- V_6_0_0_rc2 - Static variable in class org.elasticsearch.Version
- V_6_0_1 - Static variable in class org.elasticsearch.Version
- V_6_1_0 - Static variable in class org.elasticsearch.Version
- V_6_1_1 - Static variable in class org.elasticsearch.Version
- V_6_1_2 - Static variable in class org.elasticsearch.Version
- V_6_1_3 - Static variable in class org.elasticsearch.Version
- V_6_1_4 - Static variable in class org.elasticsearch.Version
- V_6_2_0 - Static variable in class org.elasticsearch.Version
- V_6_2_1 - Static variable in class org.elasticsearch.Version
- V_6_2_2 - Static variable in class org.elasticsearch.Version
- V_6_2_3 - Static variable in class org.elasticsearch.Version
- V_6_2_4 - Static variable in class org.elasticsearch.Version
- V_6_3_0 - Static variable in class org.elasticsearch.Version
- V_6_3_1 - Static variable in class org.elasticsearch.Version
- V_6_3_2 - Static variable in class org.elasticsearch.Version
- V_6_4_0 - Static variable in class org.elasticsearch.Version
- V_6_4_1 - Static variable in class org.elasticsearch.Version
- V_6_4_2 - Static variable in class org.elasticsearch.Version
- V_6_4_3 - Static variable in class org.elasticsearch.Version
- V_6_5_0 - Static variable in class org.elasticsearch.Version
- V_6_5_1 - Static variable in class org.elasticsearch.Version
- V_6_5_2 - Static variable in class org.elasticsearch.Version
- V_6_5_3 - Static variable in class org.elasticsearch.Version
- V_6_5_4 - Static variable in class org.elasticsearch.Version
- V_6_6_0 - Static variable in class org.elasticsearch.Version
- V_6_6_1 - Static variable in class org.elasticsearch.Version
- V_6_6_2 - Static variable in class org.elasticsearch.Version
- V_6_7_0 - Static variable in class org.elasticsearch.Version
- V_6_7_1 - Static variable in class org.elasticsearch.Version
- V_6_7_2 - Static variable in class org.elasticsearch.Version
- V_6_8_0 - Static variable in class org.elasticsearch.Version
- V_6_8_1 - Static variable in class org.elasticsearch.Version
- V_6_8_10 - Static variable in class org.elasticsearch.Version
- V_6_8_11 - Static variable in class org.elasticsearch.Version
- V_6_8_12 - Static variable in class org.elasticsearch.Version
- V_6_8_13 - Static variable in class org.elasticsearch.Version
- V_6_8_14 - Static variable in class org.elasticsearch.Version
- V_6_8_15 - Static variable in class org.elasticsearch.Version
- V_6_8_16 - Static variable in class org.elasticsearch.Version
- V_6_8_17 - Static variable in class org.elasticsearch.Version
- V_6_8_18 - Static variable in class org.elasticsearch.Version
- V_6_8_19 - Static variable in class org.elasticsearch.Version
- V_6_8_2 - Static variable in class org.elasticsearch.Version
- V_6_8_20 - Static variable in class org.elasticsearch.Version
- V_6_8_21 - Static variable in class org.elasticsearch.Version
- V_6_8_22 - Static variable in class org.elasticsearch.Version
- V_6_8_23 - Static variable in class org.elasticsearch.Version
- V_6_8_24 - Static variable in class org.elasticsearch.Version
- V_6_8_3 - Static variable in class org.elasticsearch.Version
- V_6_8_4 - Static variable in class org.elasticsearch.Version
- V_6_8_5 - Static variable in class org.elasticsearch.Version
- V_6_8_6 - Static variable in class org.elasticsearch.Version
- V_6_8_7 - Static variable in class org.elasticsearch.Version
- V_6_8_8 - Static variable in class org.elasticsearch.Version
- V_6_8_9 - Static variable in class org.elasticsearch.Version
- V_7_0_0 - Static variable in class org.elasticsearch.Version
- V_7_0_1 - Static variable in class org.elasticsearch.Version
- V_7_1_0 - Static variable in class org.elasticsearch.Version
- V_7_1_1 - Static variable in class org.elasticsearch.Version
- V_7_10_0 - Static variable in class org.elasticsearch.Version
- V_7_10_1 - Static variable in class org.elasticsearch.Version
- V_7_10_2 - Static variable in class org.elasticsearch.Version
- V_7_11_0 - Static variable in class org.elasticsearch.Version
- V_7_11_1 - Static variable in class org.elasticsearch.Version
- V_7_11_2 - Static variable in class org.elasticsearch.Version
- V_7_12_0 - Static variable in class org.elasticsearch.Version
- V_7_12_1 - Static variable in class org.elasticsearch.Version
- V_7_13_0 - Static variable in class org.elasticsearch.Version
- V_7_13_1 - Static variable in class org.elasticsearch.Version
- V_7_13_2 - Static variable in class org.elasticsearch.Version
- V_7_13_3 - Static variable in class org.elasticsearch.Version
- V_7_13_4 - Static variable in class org.elasticsearch.Version
- V_7_14_0 - Static variable in class org.elasticsearch.Version
- V_7_14_1 - Static variable in class org.elasticsearch.Version
- V_7_14_2 - Static variable in class org.elasticsearch.Version
- V_7_15_0 - Static variable in class org.elasticsearch.Version
- V_7_15_1 - Static variable in class org.elasticsearch.Version
- V_7_15_2 - Static variable in class org.elasticsearch.Version
- V_7_16_0 - Static variable in class org.elasticsearch.Version
- V_7_16_1 - Static variable in class org.elasticsearch.Version
- V_7_16_2 - Static variable in class org.elasticsearch.Version
- V_7_16_3 - Static variable in class org.elasticsearch.Version
- V_7_17_0 - Static variable in class org.elasticsearch.Version
- V_7_17_1 - Static variable in class org.elasticsearch.Version
- V_7_17_10 - Static variable in class org.elasticsearch.Version
- V_7_17_2 - Static variable in class org.elasticsearch.Version
- V_7_17_3 - Static variable in class org.elasticsearch.Version
- V_7_17_4 - Static variable in class org.elasticsearch.Version
- V_7_17_5 - Static variable in class org.elasticsearch.Version
- V_7_17_6 - Static variable in class org.elasticsearch.Version
- V_7_17_7 - Static variable in class org.elasticsearch.Version
- V_7_17_8 - Static variable in class org.elasticsearch.Version
- V_7_17_9 - Static variable in class org.elasticsearch.Version
- V_7_2_0 - Static variable in class org.elasticsearch.Version
- V_7_2_1 - Static variable in class org.elasticsearch.Version
- V_7_3_0 - Static variable in class org.elasticsearch.Version
- V_7_3_1 - Static variable in class org.elasticsearch.Version
- V_7_3_2 - Static variable in class org.elasticsearch.Version
- V_7_4_0 - Static variable in class org.elasticsearch.Version
- V_7_4_1 - Static variable in class org.elasticsearch.Version
- V_7_4_2 - Static variable in class org.elasticsearch.Version
- V_7_5_0 - Static variable in class org.elasticsearch.Version
- V_7_5_1 - Static variable in class org.elasticsearch.Version
- V_7_5_2 - Static variable in class org.elasticsearch.Version
- V_7_6_0 - Static variable in class org.elasticsearch.Version
- V_7_6_1 - Static variable in class org.elasticsearch.Version
- V_7_6_2 - Static variable in class org.elasticsearch.Version
- V_7_7_0 - Static variable in class org.elasticsearch.Version
- V_7_7_1 - Static variable in class org.elasticsearch.Version
- V_7_8_0 - Static variable in class org.elasticsearch.Version
- V_7_8_1 - Static variable in class org.elasticsearch.Version
- V_7_9_0 - Static variable in class org.elasticsearch.Version
- V_7_9_1 - Static variable in class org.elasticsearch.Version
- V_7_9_2 - Static variable in class org.elasticsearch.Version
- V_7_9_3 - Static variable in class org.elasticsearch.Version
- V_EMPTY - Static variable in class org.elasticsearch.Version
- V_EMPTY_ID - Static variable in class org.elasticsearch.Version
- valid() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- VALID_ACTION_PREFIXES - Static variable in class org.elasticsearch.transport.TransportService
-
A set of all valid action prefixes.
- VALID_AGG_NAME - Static variable in class org.elasticsearch.search.aggregations.AggregatorFactories
- VALID_FIELD - Static variable in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- VALID_FIELD - Static variable in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
- VALID_MEDIA_TYPES - Static variable in class org.elasticsearch.ingest.ConfigurationUtils
- validate() - Method in class org.elasticsearch.action.ActionRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.node.liveness.LivenessRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptContextRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptLanguageRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- validate() - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- validate() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.dangling.delete.DeleteDanglingIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.dangling.import_index.ImportDanglingIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.diskusage.AnalyzeIndexDiskUsageRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Request
- validate() - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteComponentTemplateAction.Request
- validate() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteComposableIndexTemplateAction.Request
- validate() - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Request
- validate() - Method in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Request
- validate() - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction.Request
- validate() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction.Request
- validate() - Method in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
- validate() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequest
- validate() - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- validate() - Method in class org.elasticsearch.action.bulk.BulkRequest
- validate() - Method in class org.elasticsearch.action.datastreams.ModifyDataStreamsAction.Request
- validate() - Method in class org.elasticsearch.action.delete.DeleteRequest
- validate() - Method in class org.elasticsearch.action.explain.ExplainRequest
- validate() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- validate() - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- validate() - Method in class org.elasticsearch.action.get.GetRequest
- validate() - Method in class org.elasticsearch.action.get.MultiGetRequest
- validate() - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- validate() - Method in class org.elasticsearch.action.index.IndexRequest
- validate() - Method in class org.elasticsearch.action.ingest.DeletePipelineRequest
- validate() - Method in class org.elasticsearch.action.ingest.GetPipelineRequest
- validate() - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- validate() - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- validate() - Method in class org.elasticsearch.action.main.MainRequest
- validate() - Method in class org.elasticsearch.action.search.ClearScrollRequest
- validate() - Method in class org.elasticsearch.action.search.ClosePointInTimeRequest
- validate() - Method in class org.elasticsearch.action.search.MultiSearchRequest
- validate() - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- validate() - Method in class org.elasticsearch.action.search.SearchRequest
- validate() - Method in class org.elasticsearch.action.search.SearchScrollRequest
- validate() - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- validate() - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- validate() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- validate() - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- validate() - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- validate() - Method in interface org.elasticsearch.action.support.WriteRequest
- validate() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- validate() - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- validate() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- validate() - Method in class org.elasticsearch.action.update.UpdateRequest
- validate() - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand.Builder
- validate() - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- validate() - Method in class org.elasticsearch.index.reindex.DeleteByQueryRequest
- validate() - Method in class org.elasticsearch.index.reindex.ReindexRequest
- validate() - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.RemoveRequest
- validate() - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncRequest
- validate() - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction.Request
- validate() - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- validate() - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- validate() - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- validate() - Method in class org.elasticsearch.snapshots.UpdateIndexShardSnapshotStatusRequest
- validate(int) - Method in class org.elasticsearch.action.support.ActiveShardCount
-
Validates that the instance is valid for the given number of replicas in an index.
- validate(long, String) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
-
If the model is a HoltWinters, we need to ensure the window and period are compatible.
- validate(long, String) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
-
This method allows models to validate the window size if required
- validate(String, Object, Object) - Method in interface org.elasticsearch.common.settings.Setting.SettingDependency
-
Validates the dependent setting value.
- validate(String, String, String, Boolean) - Method in interface org.elasticsearch.cluster.metadata.AliasAction.NewAliasValidator
- validate(ActionRequestValidationException) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
-
Validate the root of the aggregation tree.
- validate(Metadata) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- validate(Settings, boolean) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Validates that all settings are registered and valid.
- validate(Settings, boolean, boolean) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Validates that all settings are registered and valid.
- validate(Settings, boolean, boolean, boolean) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Validates that all settings are registered and valid.
- validate(Settings, boolean, boolean, boolean, boolean) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Validates that all settings are registered and valid.
- validate(IndexSettings, boolean) - Method in class org.elasticsearch.index.mapper.DocumentMapper
- validate(MappingLookup) - Method in class org.elasticsearch.index.mapper.FieldAliasMapper
- validate(MappingLookup) - Method in class org.elasticsearch.index.mapper.FieldMapper
- validate(MappingLookup) - Method in class org.elasticsearch.index.mapper.Mapper
-
Validate any cross-field references made by this mapper
- validate(MappingLookup) - Method in class org.elasticsearch.index.mapper.ObjectMapper
- validate(Aggregator) - Method in class org.elasticsearch.search.aggregations.BucketOrder
-
Validate an aggregation against an Aggregator.
- validate(PipelineAggregationBuilder.ValidationContext) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketMetricsPipelineAggregationBuilder
- validate(PipelineAggregationBuilder.ValidationContext) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketScriptPipelineAggregationBuilder
- validate(PipelineAggregationBuilder.ValidationContext) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSelectorPipelineAggregationBuilder
- validate(PipelineAggregationBuilder.ValidationContext) - Method in class org.elasticsearch.search.aggregations.pipeline.BucketSortPipelineAggregationBuilder
- validate(PipelineAggregationBuilder.ValidationContext) - Method in class org.elasticsearch.search.aggregations.pipeline.CumulativeSumPipelineAggregationBuilder
- validate(PipelineAggregationBuilder.ValidationContext) - Method in class org.elasticsearch.search.aggregations.pipeline.DerivativePipelineAggregationBuilder
- validate(PipelineAggregationBuilder.ValidationContext) - Method in class org.elasticsearch.search.aggregations.pipeline.ExtendedStatsBucketPipelineAggregationBuilder
- validate(PipelineAggregationBuilder.ValidationContext) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
- validate(PipelineAggregationBuilder.ValidationContext) - Method in class org.elasticsearch.search.aggregations.pipeline.MovFnPipelineAggregationBuilder
- validate(PipelineAggregationBuilder.ValidationContext) - Method in class org.elasticsearch.search.aggregations.pipeline.PercentilesBucketPipelineAggregationBuilder
- validate(PipelineAggregationBuilder.ValidationContext) - Method in class org.elasticsearch.search.aggregations.pipeline.SerialDiffPipelineAggregationBuilder
- validate(PipelineAggregationBuilder.ValidationContext) - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder
-
Makes sure this builder is properly configured.
- validate(Transport.Connection, ConnectionProfile, ActionListener<Void>) - Method in interface org.elasticsearch.transport.ConnectionManager.ConnectionValidator
- validate(TransportRequest) - Method in class org.elasticsearch.search.internal.ReaderContext
- validate(Params, ClusterState) - Method in class org.elasticsearch.persistent.PersistentTasksExecutor
-
Checks the current cluster state for compatibility with the params
- validate(T) - Method in interface org.elasticsearch.common.settings.Setting.Validator
-
Validate this setting's value in isolation.
- validate(T) - Method in class org.elasticsearch.index.mapper.AbstractPointGeometryFieldMapper.PointParser
- validate(T, Map<Setting<?>, Object>) - Method in interface org.elasticsearch.common.settings.Setting.Validator
-
Validate this setting against its dependencies, specified by
Setting.Validator.settings()
. - validate(T, Map<Setting<?>, Object>, boolean) - Method in interface org.elasticsearch.common.settings.Setting.Validator
-
Validate this setting against its dependencies, specified by
Setting.Validator.settings()
. - ValidateActions - Class in org.elasticsearch.action
- ValidateActions() - Constructor for class org.elasticsearch.action.ValidateActions
- validateAlias(String, String, String, Function<String, String>) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
Validate a proposed alias.
- validateAlias(Alias, String, Metadata) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
Allows to validate an
Alias
and make sure it's valid before it gets added to the index metadata. - validateAliasFilter(String, String, SearchExecutionContext, NamedXContentRegistry) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
Validates an alias filter by parsing it using the provided
SearchExecutionContext
- validateAliasFilter(String, BytesReference, SearchExecutionContext, NamedXContentRegistry) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
Validates an alias filter by parsing it using the provided
SearchExecutionContext
- validateAliasMetadata(AliasMetadata, String, Metadata) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
Allows to validate an
AliasMetadata
and make sure it's valid before it gets added to the index metadata. - validateAliasStandalone(Alias) - Method in class org.elasticsearch.cluster.metadata.AliasValidator
-
Allows to partially validate an alias, without knowing which index it'll get applied to.
- validateAndSetStage(RecoveryState.Stage, RecoveryState.Stage) - Method in class org.elasticsearch.indices.recovery.RecoveryState
- validateBeforeLock(Terminal, Environment) - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand
-
Validate that the command can run before taking any locks.
- validateBeforeLock(Terminal, Environment) - Method in class org.elasticsearch.cluster.coordination.UnsafeBootstrapMasterCommand
- validateBeforeLock(Terminal, Environment) - Method in class org.elasticsearch.env.NodeRepurposeCommand
- validateCurrentStage(RecoveryState.Stage) - Method in class org.elasticsearch.indices.recovery.RecoveryState
- validateDataStreamAccess(String, ThreadContext) - Method in class org.elasticsearch.indices.SystemIndices
- validateDotIndex(String, Boolean) - Method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
-
Validates (if this index has a dot-prefixed name) whether it follows the rules for dot-prefixed indices.
- validateFeatureName(String, String) - Static method in class org.elasticsearch.indices.SystemIndices
-
Check that a feature name is not reserved
- validateHasParent(String, String) - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder.ValidationContext
-
Validates that there is a parent aggregation.
- validateIndexName(String, ClusterState) - Method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
-
Validate the name for an index against some static rules and a cluster state.
- validateIndexName(ClusterState, String) - Method in class org.elasticsearch.action.admin.indices.rollover.MetadataRolloverService
- validateIndexOrAliasName(String, BiFunction<String, String, ? extends RuntimeException>) - Static method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
-
Validate the name for an index or alias against some static rules.
- validateIndexSettings(String, Settings, boolean) - Method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
- validateIndexTemplate(ActionRequestValidationException) - Method in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
- ValidateJoinRequest - Class in org.elasticsearch.cluster.coordination
- ValidateJoinRequest(ClusterState) - Constructor for class org.elasticsearch.cluster.coordination.ValidateJoinRequest
- ValidateJoinRequest(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.ValidateJoinRequest
- validateLocalAbortSupported() - Method in class org.elasticsearch.persistent.PersistentTasksService
-
Throw an exception if the cluster is not able locally abort persistent tasks.
- validateNativesConfig() - Method in class org.elasticsearch.env.Environment
-
Ensure the temp directories needed for JNA are set up correctly.
- validateNodeBeforeAcceptingRequests(BootstrapContext, BoundTransportAddress, List<BootstrapCheck>) - Method in class org.elasticsearch.node.Node
-
Hook for validating the node after network services are started but before the cluster service is started and before the network service starts accepting incoming network requests.
- validateNonNullIndex() - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
- validateParentAggSequentiallyOrdered(String, String) - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder.ValidationContext
-
Validates that the parent is sequentially ordered.
- validateParentAggSequentiallyOrderedWithoutSkips(String, String) - Method in class org.elasticsearch.search.aggregations.PipelineAggregationBuilder.ValidationContext
-
Validates that the parent is sequentially ordered and doesn't have any gps.
- validateQuery(ValidateQueryRequest) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Validate a query for correctness.
- validateQuery(ValidateQueryRequest, ActionListener<ValidateQueryResponse>) - Method in interface org.elasticsearch.client.IndicesAdminClient
-
Validate a query for correctness.
- ValidateQueryAction - Class in org.elasticsearch.action.admin.indices.validate.query
- ValidateQueryRequest - Class in org.elasticsearch.action.admin.indices.validate.query
-
A request to validate a specific query.
- ValidateQueryRequest() - Constructor for class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- ValidateQueryRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
-
Constructs a new validate request against the provided indices.
- ValidateQueryRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- ValidateQueryRequestBuilder - Class in org.elasticsearch.action.admin.indices.validate.query
- ValidateQueryRequestBuilder(ElasticsearchClient, ValidateQueryAction) - Constructor for class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequestBuilder
- ValidateQueryResponse - Class in org.elasticsearch.action.admin.indices.validate.query
-
The response of the validate action.
- validateReaderContext(ReaderContext, TransportRequest) - Method in class org.elasticsearch.index.shard.SearchOperationListener.CompositeListener
- validateReaderContext(ReaderContext, TransportRequest) - Method in interface org.elasticsearch.index.shard.SearchOperationListener
-
Executed prior to using a
ReaderContext
that has been retrieved from the active contexts. - validateReferences(Version, Function<String, MappedFieldType>) - Method in class org.elasticsearch.search.suggest.completion.context.ContextMapping
-
Checks if the current context is consistent with the rest of the fields.
- validateReferences(Version, Function<String, MappedFieldType>) - Method in class org.elasticsearch.search.suggest.completion.context.GeoContextMapping
- validateRequest(T, ClusterState, Index[]) - Method in interface org.elasticsearch.action.RequestValidators.RequestValidator
-
Validates a given request with its associated concrete indices and the current state.
- validateRequest(T, ClusterState, Index[]) - Method in class org.elasticsearch.action.RequestValidators
- validateSeqNoBasedCASParams(DocWriteRequest<?>, ActionRequestValidationException) - Static method in interface org.elasticsearch.action.DocWriteRequest
- validateSequentiallyOrdered(String, String, Consumer<String>) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Called by aggregations whose parents must be sequentially ordered.
- validateSequentiallyOrdered(String, String, Consumer<String>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- validateSequentiallyOrdered(String, String, Consumer<String>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- validateSequentiallyOrdered(String, String, Consumer<String>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- validateSequentiallyOrderedWithoutGaps(String, String, Consumer<String>) - Method in class org.elasticsearch.search.aggregations.AggregationBuilder
-
Called by aggregations whose parents must be sequentially ordered without any gaps.
- validateSequentiallyOrderedWithoutGaps(String, String, Consumer<String>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder
- validateSequentiallyOrderedWithoutGaps(String, String, Consumer<String>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramAggregationBuilder
- validateSequentiallyOrderedWithoutGaps(String, String, Consumer<String>) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.HistogramAggregationBuilder
- validateSettingKey(Setting<?>) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
- validateSettingKey(Setting<?>) - Method in class org.elasticsearch.common.settings.IndexScopedSettings
- validateSettingName(String) - Static method in class org.elasticsearch.common.settings.KeyStoreWrapper
-
Ensure the given setting name is allowed.
- validateSettings(BreakerSettings[]) - Static method in class org.elasticsearch.indices.breaker.HierarchyCircuitBreakerService
-
Validate that child settings are valid
- validateShardLimit(ClusterState, Index[]) - Method in class org.elasticsearch.indices.ShardLimitValidator
-
Validates whether a list of indices can be opened without going over the cluster shard limit.
- validateShardLimit(Settings, ClusterState) - Method in class org.elasticsearch.indices.ShardLimitValidator
-
Checks whether an index can be created without going over the cluster shard limit.
- validateShardLimitOnReplicaUpdate(ClusterState, Index[], int) - Method in class org.elasticsearch.indices.ShardLimitValidator
- validateStateIsFromCurrentMaster(Logger, DiscoveryNodes, ClusterState) - Static method in class org.elasticsearch.discovery.zen.ZenDiscovery
-
In the case we follow an elected master the new cluster state needs to have the same elected master This method checks for this and throws an exception if needed
- validateStoreTypeSetting(Settings) - Static method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
- validateTimestampFieldMapping(MappingLookup) - Static method in class org.elasticsearch.cluster.metadata.MetadataCreateDataStreamService
- validateTmpFile() - Method in class org.elasticsearch.env.Environment
-
Ensure the configured temp directory is a valid directory
- validateTranslogRetentionSettings(Settings) - Static method in class org.elasticsearch.cluster.metadata.MetadataCreateIndexService
- validateType(String) - Method in class org.elasticsearch.index.mapper.MapperService
-
Check that the resolved type can be used for indexing or deletions
- validateUpdate(Settings) - Method in class org.elasticsearch.common.settings.AbstractScopedSettings
-
Validates the given settings by running it through all update listeners without applying it.
- validateV2TemplateRequest(Metadata, String, ComposableIndexTemplate) - Static method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService
- validateVersionForReads(long) - Method in enum class org.elasticsearch.index.VersionType
-
validate the version is a valid value for this type when reading.
- validateVersionForWrites(long) - Method in enum class org.elasticsearch.index.VersionType
-
validate the version is a valid value for this type when writing.
- validation() - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Returns the validation method to use for this sort builder.
- validation(GeoValidationMethod) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
-
Sets validation method for this sort builder.
- validationErrors() - Method in exception org.elasticsearch.common.ValidationException
-
Returns the validation errors accumulated
- ValidationException - Exception in org.elasticsearch.common
-
Encapsulates an accumulation of validation errors
- ValidationException() - Constructor for exception org.elasticsearch.common.ValidationException
- ValidationException(Throwable) - Constructor for exception org.elasticsearch.common.ValidationException
- validFileName(String) - Static method in class org.elasticsearch.common.Strings
- validFileNameExcludingAstrix(String) - Static method in class org.elasticsearch.common.Strings
- validHeaderValue(String) - Static method in class org.elasticsearch.rest.DeprecationRestHandler
-
This does a very basic pass at validating that a header's value contains only expected characters according to RFC-5987, and those that it references.
- validTierName(String) - Static method in class org.elasticsearch.cluster.routing.allocation.DataTier
-
Returns true if the given tier name is a valid tier
- value - Variable in class org.elasticsearch.action.admin.indices.rollover.Condition
- value - Variable in class org.elasticsearch.common.Table.Cell
- value - Variable in class org.elasticsearch.common.unit.DistanceUnit.Distance
- value - Variable in class org.elasticsearch.common.util.LongObjectPagedHashMap.Cursor
- value - Variable in class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Value to find matches for.
- value - Variable in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic.LongAccessor
- value - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- value - Variable in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- value() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.After
- value() - Method in enum class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Returns code that represents the snapshot state
- value() - Method in enum class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
- value() - Method in class org.elasticsearch.action.admin.indices.rollover.Condition
- value() - Method in enum class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus.AllocationStatus
- value() - Method in class org.elasticsearch.cluster.ClusterName
- value() - Method in enum class org.elasticsearch.cluster.health.ClusterHealthStatus
- value() - Method in enum class org.elasticsearch.cluster.metadata.DataStreamAction.Type
- value() - Method in enum class org.elasticsearch.cluster.RestoreInProgress.State
-
Returns state code
- value() - Method in enum class org.elasticsearch.cluster.routing.ShardRoutingState
-
Byte value of this
ShardRoutingState
- value() - Method in enum class org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
- value() - Method in enum class org.elasticsearch.cluster.SnapshotsInProgress.State
- value() - Method in class org.elasticsearch.common.Explicit
- value() - Element in annotation interface org.elasticsearch.common.inject.assistedinject.Assisted
-
The unique name for this parameter.
- value() - Element in annotation interface org.elasticsearch.common.inject.ImplementedBy
-
The implementation type.
- value() - Element in annotation interface org.elasticsearch.common.inject.name.Named
- value() - Element in annotation interface org.elasticsearch.common.inject.ProvidedBy
-
The implementation type.
- value() - Method in class org.elasticsearch.index.fielddata.HistogramValue
-
the current value of the histogram
- value() - Method in class org.elasticsearch.index.query.BaseTermQueryBuilder
-
Returns the value used in this query.
- value() - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- value() - Method in class org.elasticsearch.index.query.CommonTermsQueryBuilder
-
Deprecated.
- value() - Method in class org.elasticsearch.index.query.FuzzyQueryBuilder
- value() - Method in class org.elasticsearch.index.query.MatchBoolPrefixQueryBuilder
-
Returns the value used in this query.
- value() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Returns the value used in this query.
- value() - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Returns the value used in this query.
- value() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Returns the value used in this query.
- value() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- value() - Method in class org.elasticsearch.index.query.PrefixQueryBuilder
- value() - Method in enum class org.elasticsearch.index.query.RegexpFlag
- value() - Method in class org.elasticsearch.index.query.RegexpQueryBuilder
-
Returns the value used in this query.
- value() - Method in class org.elasticsearch.index.query.SimpleQueryStringBuilder
-
Returns the text to parse the query from.
- value() - Method in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- value() - Method in class org.elasticsearch.index.query.WildcardQueryBuilder
- value() - Method in enum class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
- value() - Method in interface org.elasticsearch.search.aggregations.bucket.terms.LongKeyedBucketOrds.BucketOrdsEnum
-
The current value.
- value() - Method in interface org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLog.RunLenIterator
-
Value of the register.
- value() - Method in interface org.elasticsearch.search.aggregations.metrics.AbstractLinearCounting.HashesIterator
-
Hash value.
- value() - Method in class org.elasticsearch.search.aggregations.metrics.CompensatedSum
-
The value of the sum.
- value() - Method in class org.elasticsearch.search.aggregations.metrics.InternalAvg
- value() - Method in class org.elasticsearch.search.aggregations.metrics.InternalCardinality
- value() - Method in class org.elasticsearch.search.aggregations.metrics.InternalMax
- value() - Method in class org.elasticsearch.search.aggregations.metrics.InternalMedianAbsoluteDeviation
- value() - Method in class org.elasticsearch.search.aggregations.metrics.InternalMin
- value() - Method in class org.elasticsearch.search.aggregations.metrics.InternalSum
- value() - Method in class org.elasticsearch.search.aggregations.metrics.InternalValueCount
- value() - Method in class org.elasticsearch.search.aggregations.metrics.InternalWeightedAvg
- value() - Method in interface org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregation.SingleValue
- value() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedCardinality
- value() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- value() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedValueCount
- value() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalBucketMetricValue
- value() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalSimpleValue
- value() - Method in enum class org.elasticsearch.search.aggregations.support.CoreValuesSourceType
- value() - Method in enum class org.elasticsearch.snapshots.SnapshotState
-
Returns code that represents the snapshot state
- value(boolean) - Method in class org.elasticsearch.script.BooleanFieldScript.Emit
- value(double) - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentileRanks
- value(double) - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- value(double) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentileRanks
- value(double) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- value(String) - Method in interface org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregation.MultiValue
-
Return the result of 1 value by name
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedHDRPercentiles
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentileRanks
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- value(String) - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentiles
- value(String) - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket
- value(String) - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedPercentilesBucket
- value(MultiValuesSourceFieldConfig) - Method in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- Value(BitSet, ShardId) - Constructor for class org.elasticsearch.index.cache.bitset.BitsetFilterCache.Value
- VALUE - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- VALUE_AS_STRING - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- VALUE_FIELD - Static variable in class org.elasticsearch.index.query.BaseTermQueryBuilder
- VALUE_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- VALUE_TYPE - Static variable in class org.elasticsearch.search.aggregations.AggregationBuilder.CommonFields
- VALUE_TYPE - Static variable in enum class org.elasticsearch.search.aggregations.support.ValueType
- valueAsString - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedSingleValueNumericMetricsAggregation
- valueAsString - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- valueAsString(String) - Method in class org.elasticsearch.search.aggregations.metrics.InternalNumericMetricsAggregation.MultiValue
- ValueCount - Interface in org.elasticsearch.search.aggregations.metrics
-
An get that holds the number of values that the current document set has for a specific field.
- ValueCountAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- ValueCountAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- ValueCountAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
-
Read from a stream.
- ValueCountAggregationBuilder(ValueCountAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.ValueCountAggregationBuilder
- ValueCountAggregator - Class in org.elasticsearch.search.aggregations.metrics
-
A field data based aggregator that counts the number of values a specific field has within the aggregation context.
- ValueCountAggregator(String, ValuesSourceConfig, AggregationContext, Aggregator, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.ValueCountAggregator
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.AbstractGeometryFieldMapper.AbstractGeometryFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.BinaryFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.CompletionFieldMapper.CompletionFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.DataStreamTimestampFieldMapper.TimestampFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.DocCountFieldMapper.DocCountFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.FieldNamesFieldMapper.FieldNamesFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.RootFlattenedFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.GeoPointFieldMapper.GeoPointFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.IgnoredFieldMapper.IgnoredFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Create a helper class to fetch field values during the
FetchFieldsPhase
. - valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.RangeFieldMapper.RangeFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.TypeFieldMapper.TypeFieldType
- valueFetcher(SearchExecutionContext, String) - Method in class org.elasticsearch.index.mapper.TypeFieldType
- valueFetcher(FieldValues<?>, Function<Object, Object>, SearchExecutionContext) - Static method in interface org.elasticsearch.search.lookup.FieldValues
-
Creates a
ValueFetcher
that fetches values from aFieldValues
instance - valueFetcher(FieldValues<?>, SearchExecutionContext) - Static method in interface org.elasticsearch.search.lookup.FieldValues
-
Creates a
ValueFetcher
that fetches values from aFieldValues
instance - ValueFetcher - Interface in org.elasticsearch.index.mapper
-
A helper class for fetching field values during the
FetchFieldsPhase
. - valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.BinaryFieldMapper.BinaryFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.BooleanFieldMapper.BooleanFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.BooleanScriptFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.DateFieldMapper.DateFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.DateScriptFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.DoubleScriptFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.RootFlattenedFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.IpFieldMapper.IpFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.IpScriptFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Given a value that comes from the stored fields API, convert it to the expected type.
- valueForDisplay(Object) - Method in class org.elasticsearch.index.mapper.NumberFieldMapper.NumberFieldType
- valueListFetcher(FieldValues<T>, Function<List<T>, List<Object>>, SearchExecutionContext) - Static method in interface org.elasticsearch.search.lookup.FieldValues
-
Creates a
ValueFetcher
that fetches values from aFieldValues
instance - valueNames() - Method in class org.elasticsearch.search.aggregations.metrics.InternalHDRPercentiles
- valueNames() - Method in class org.elasticsearch.search.aggregations.metrics.InternalTDigestPercentiles
- valueNames() - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- valueNames() - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- valueNames() - Method in interface org.elasticsearch.search.aggregations.metrics.MultiValueAggregation
-
Return an iterable over all value names this multi value aggregation provides.
- valueNames() - Method in interface org.elasticsearch.search.aggregations.metrics.NumericMetricsAggregation.MultiValue
-
Return an iterable over all value names this multi value aggregation provides.
- valueNames() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedHDRPercentiles
- valueNames() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentileRanks
- valueNames() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedStats
- valueNames() - Method in class org.elasticsearch.search.aggregations.metrics.ParsedTDigestPercentiles
- valueNames() - Method in class org.elasticsearch.search.aggregations.pipeline.InternalPercentilesBucket
- valueNames() - Method in class org.elasticsearch.search.aggregations.pipeline.ParsedPercentilesBucket
- valueOf(String) - Static method in enum class org.apache.lucene.queries.BinaryDocValuesRangeQuery.QueryType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest.Level
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.UpgradeStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus.Status
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.SortBy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus.AllocationStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.admin.indices.shrink.ResizeType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.DocWriteRequest.OpType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.DocWriteResponse.Result
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.search.SearchType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.support.IndicesOptions.Option
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.support.IndicesOptions.WildcardStates
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.support.WriteRequest.RefreshPolicy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.action.ThreadingModel
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.Build.Flavor
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.Build.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.block.ClusterBlockLevel
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.ClusterState.Metric
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.coordination.Coordinator.Mode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.health.ClusterHealthStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.metadata.DataStreamAction.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.metadata.IndexAbstraction.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.metadata.Metadata.XContentContext
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Status
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.node.DiscoveryNodeFilters.OpType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.RestoreInProgress.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.DebugMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.routing.Preference
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.routing.RecoverySource.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.routing.ShardRoutingState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.SnapshotDeletionsInProgress.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.SnapshotsInProgress.ShardState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.cluster.SnapshotsInProgress.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.breaker.CircuitBreaker.Durability
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.breaker.CircuitBreaker.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.cache.RemovalNotification.RemovalReason
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.component.Lifecycle.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.geo.GeoDistance
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.geo.GeometryParserFormat
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.geo.GeoUtils.EffectivePoint
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.geo.Orientation
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.geo.ShapeRelation
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.geo.SpatialStrategy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.hash.MurmurHash3
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.inject.Stage
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.logging.DeprecationCategory
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.lucene.search.function.CombineFunction
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.Priority
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.recycler.Recyclers
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.rounding.DateTimeUnit
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.Rounding.DateTimeUnit
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.settings.Setting.Property
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.time.FormatNames
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.unit.ByteSizeUnit
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.unit.MemorySizeValue
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.unit.SizeUnit
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.util.ByteUtils
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.util.Comparators
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.common.util.PageCacheRecycler.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.http.HttpRequest.HttpVersion
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.analysis.AnalysisMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.analysis.AnalyzerScope
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.engine.Engine.HistorySource
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.engine.Engine.Operation.Origin
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.engine.Engine.Operation.TYPE
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.engine.Engine.Result.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.engine.Engine.SearcherScope
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.engine.Engine.SyncedFlushResult
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsBuilder
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.IndexModule.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.IndexService.IndexCreationContext
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.mapper.DynamicTemplate.MatchType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.mapper.MappedFieldType.CollapseType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.mapper.MappedFieldType.Relation
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.mapper.MapperService.MergeReason
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.mapper.ObjectMapper.Dynamic
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.mapper.RangeType.LengthType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.mapper.RangeType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.mapper.SourceToParse.Origin
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.mapper.TextSearchInfo.TermVector
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.mapper.TimeSeriesParams.MetricType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.query.GeoExecType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.query.GeoValidationMethod
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.query.Operator
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.query.RegexpFlag
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.query.ZeroTermsQueryOption
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.search.MatchQueryParser.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.search.stats.FieldUsageStats.UsageContext
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.shard.IndexShardState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.SlowLogLevel
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.store.LuceneFilesExtensions
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.translog.Translog.Durability
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.translog.Translog.Operation.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.index.VersionType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.indices.analysis.PreBuiltCacheFactory.CachingStrategy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.indices.analysis.PreBuiltTokenizers
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices.IndexRemovalReason
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.indices.IndicesService.ShardDeletionCheckResult
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.indices.recovery.RecoveryState.Stage
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.indices.SystemDataStreamDescriptor.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.indices.SystemIndexDescriptor.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.indices.SystemIndices.SystemIndexAccessLevel
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.ingest.IngestDocument.Metadata
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.monitor.jvm.HotThreads.ReportType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.monitor.jvm.HotThreads.SortOrder
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.monitor.StatusInfo.Status
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.persistent.AllocatedPersistentTask.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.persistent.decider.AssignmentDecision.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.plugins.PluginType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.rest.RestRequest.Method
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.rest.RestStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.script.ScriptType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.AggregationBuilder.BucketCardinality
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.bucket.composite.MissingOrder
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregatorFactory.ExecutionMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregatorFactory.ExecutionMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.metrics.ExtendedStats.Bounds
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.metrics.PercentilesMethod
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.SeasonalityType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.support.CoreValuesSourceType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.support.MissingValues
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.aggregations.support.ValueType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.MultiValueMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.profile.aggregation.AggregationTimingType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.profile.query.QueryTimingType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.rescore.QueryRescoreMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.sort.SortMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.sort.SortOrder
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.suggest.completion.context.ContextMapping.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.suggest.SortBy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.snapshots.SnapshotState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.transport.Compression.Enabled
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.transport.Compression.Scheme
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.transport.TransportRequestOptions.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.transport.Transports
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.watcher.ResourceWatcherService.Frequency
-
Returns the enum constant of this class with the specified name.
- values - Variable in class org.elasticsearch.index.fielddata.ScriptDocValues.BytesRefs
- values - Variable in class org.elasticsearch.index.fielddata.SortingBinaryDocValues
- values - Variable in class org.elasticsearch.index.fielddata.SortingNumericDocValues
- values - Variable in class org.elasticsearch.index.fielddata.SortingNumericDoubleValues
- values - Variable in class org.elasticsearch.search.aggregations.metrics.AbstractPercentilesAggregationBuilder
- values - Variable in class org.elasticsearch.search.aggregations.support.MultiValuesSource
- values() - Static method in enum class org.apache.lucene.queries.BinaryDocValuesRangeQuery.QueryType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest.Level
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.UpgradeStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest.Metric
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest.Metric
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus.Status
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.SortBy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStage
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.admin.indices.get.GetIndexRequest.Feature
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus.AllocationStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.admin.indices.shrink.ResizeType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.DocWriteRequest.OpType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.DocWriteResponse.Result
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.search.SearchType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.support.IndicesOptions.Option
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.support.IndicesOptions.WildcardStates
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.support.WriteRequest.RefreshPolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.termvectors.TermVectorsRequest.Flag
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.action.ThreadingModel
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.Build.Flavor
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.Build.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.block.ClusterBlockLevel
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.ClusterState.Metric
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.coordination.Coordinator.Mode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.health.ClusterHealthStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.metadata.DataStreamAction.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.metadata.IndexAbstraction.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.metadata.Metadata.XContentContext
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Status
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.node.DiscoveryNodeFilters.OpType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.RestoreInProgress.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.routing.allocation.decider.ClusterRebalanceAllocationDecider.ClusterRebalanceType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Allocation
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider.Rebalance
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.routing.allocation.RoutingAllocation.DebugMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.routing.Preference
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.routing.RecoverySource.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.routing.ShardRoutingState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.routing.UnassignedInfo.Reason
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.SnapshotDeletionsInProgress.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.SnapshotsInProgress.ShardState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.cluster.SnapshotsInProgress.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.breaker.CircuitBreaker.Durability
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.breaker.CircuitBreaker.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.elasticsearch.common.cache.Cache
-
An LRU sequencing of the values in the cache.
- values() - Static method in enum class org.elasticsearch.common.cache.RemovalNotification.RemovalReason
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- values() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
- values() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- values() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
Returns a
Collection
view of the values contained in the map. - values() - Static method in enum class org.elasticsearch.common.component.Lifecycle.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.geo.GeoDistance
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.geo.GeometryParserFormat
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.geo.GeoUtils.EffectivePoint
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.geo.Orientation
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.geo.ShapeRelation
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.geo.SpatialStrategy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.hash.MurmurHash3
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.inject.Stage
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.logging.DeprecationCategory
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.lucene.search.function.CombineFunction
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.Priority
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.recycler.Recyclers
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.rounding.DateTimeUnit
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.Rounding.DateTimeUnit
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.settings.Setting.Property
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.time.FormatNames
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.unit.ByteSizeUnit
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.unit.MemorySizeValue
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.unit.SizeUnit
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.util.ByteUtils
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.common.util.Comparators
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.elasticsearch.common.util.LazyMap
- values() - Static method in enum class org.elasticsearch.common.util.PageCacheRecycler.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.http.HttpRequest.HttpVersion
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.analysis.AnalysisMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.analysis.AnalyzerScope
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.engine.Engine.HistorySource
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.engine.Engine.Operation.Origin
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.engine.Engine.Operation.TYPE
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.engine.Engine.Result.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.engine.Engine.SearcherScope
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.engine.Engine.SyncedFlushResult
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.fielddata.FieldData
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.fielddata.IndexNumericFieldData.NumericType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.fielddata.ordinals.GlobalOrdinalsBuilder
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.IndexModule.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.IndexService.IndexCreationContext
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.mapper.DateFieldMapper.Resolution
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.mapper.DynamicTemplate.MatchType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.mapper.DynamicTemplate.XContentFieldType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.mapper.MappedFieldType.CollapseType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.mapper.MappedFieldType.Relation
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.mapper.MapperService.MergeReason
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.mapper.NumberFieldMapper.NumberType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.mapper.ObjectMapper.Dynamic
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.mapper.RangeType.LengthType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.mapper.RangeType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.mapper.SourceToParse.Origin
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.mapper.TextSearchInfo.TermVector
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.mapper.TimeSeriesParams.MetricType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.query.GeoExecType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.query.GeoValidationMethod
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.query.Operator
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.query.RegexpFlag
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.elasticsearch.index.query.TermsQueryBuilder
-
get readable values only for
AbstractQueryBuilder.toXContent(org.elasticsearch.xcontent.XContentBuilder, org.elasticsearch.xcontent.ToXContent.Params)
and tests, don't use this to construct a query. - values() - Static method in enum class org.elasticsearch.index.query.ZeroTermsQueryOption
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.search.MatchQueryParser.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.search.stats.FieldUsageStats.UsageContext
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.shard.IndexShardState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.shard.RemoveCorruptedShardDataCommand.CleanStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.SlowLogLevel
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.Stage
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.store.LuceneFilesExtensions
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.translog.Translog.Durability
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.translog.Translog.Operation.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.index.VersionType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.indices.analysis.PreBuiltCacheFactory.CachingStrategy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in interface org.elasticsearch.indices.analysis.PreBuiltCacheFactory.PreBuiltCache
- values() - Static method in enum class org.elasticsearch.indices.analysis.PreBuiltTokenizers
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices.IndexRemovalReason
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.indices.IndicesService.ShardDeletionCheckResult
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- values() - Static method in enum class org.elasticsearch.indices.recovery.RecoveryState.Stage
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.indices.SystemDataStreamDescriptor.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.indices.SystemIndexDescriptor.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.indices.SystemIndices.SystemIndexAccessLevel
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.ingest.IngestDocument.Metadata
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.monitor.jvm.HotThreads.ReportType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.monitor.jvm.HotThreads.SortOrder
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.monitor.StatusInfo.Status
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.persistent.AllocatedPersistentTask.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.persistent.decider.AssignmentDecision.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.persistent.decider.EnableAssignmentDecider.Allocation
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.plugins.PluginType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.rest.RestRequest.Method
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.rest.RestStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.elasticsearch.script.AbstractLongFieldScript
-
Values from the last time
AbstractLongFieldScript.runForDoc(int)
was called. - values() - Method in class org.elasticsearch.script.DoubleFieldScript
-
Values from the last time
DoubleFieldScript.runForDoc(int)
was called. - values() - Method in class org.elasticsearch.script.DynamicMap
- values() - Method in class org.elasticsearch.script.IpFieldScript
-
Values from the last time
IpFieldScript.runForDoc(int)
was called. - values() - Static method in enum class org.elasticsearch.script.ScriptType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.AggregationBuilder.BucketCardinality
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.bucket.composite.MissingOrder
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.bucket.sampler.SamplerAggregator.ExecutionMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.bucket.terms.RareTermsAggregatorFactory.ExecutionMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.bucket.terms.SignificantTermsAggregatorFactory.ExecutionMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregatorFactory.ExecutionMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.metrics.ExtendedStats.Bounds
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.elasticsearch.search.aggregations.metrics.PercentileRanksAggregationBuilder
-
Get the values to compute percentiles from.
- values() - Static method in enum class org.elasticsearch.search.aggregations.metrics.PercentilesMethod
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.SeasonalityType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.support.CoreValuesSourceType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.support.MissingValues
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.aggregations.support.ValueType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.elasticsearch.search.lookup.LeafDocLookup
- values() - Method in class org.elasticsearch.search.lookup.LeafStoredFieldsLookup
- values() - Method in class org.elasticsearch.search.lookup.SourceLookup
- values() - Static method in enum class org.elasticsearch.search.MultiValueMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.profile.aggregation.AggregationTimingType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.profile.query.QueryTimingType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.rescore.QueryRescoreMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.elasticsearch.search.sort.BucketedSort.ForDoubles
- values() - Method in class org.elasticsearch.search.sort.BucketedSort.ForFloats
- values() - Method in class org.elasticsearch.search.sort.BucketedSort.ForLongs
- values() - Method in class org.elasticsearch.search.sort.BucketedSort
-
The BigArray backing this sort.
- values() - Static method in enum class org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.sort.SortMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.sort.SortOrder
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.suggest.completion.context.ContextMapping.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.suggest.SortBy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.snapshots.SnapshotState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.elasticsearch.tasks.CancellableTasksTracker
-
Return a collection of all the tracked items.
- values() - Static method in enum class org.elasticsearch.threadpool.ThreadPool.ThreadPoolType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.transport.Compression.Enabled
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.transport.Compression.Scheme
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.transport.TransportRequestOptions.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.transport.Transports
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.watcher.ResourceWatcherService.Frequency
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values(long) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractLinearCounting
-
return the current values in the counter.
- Values() - Constructor for class org.elasticsearch.index.mapper.BooleanFieldMapper.Values
- VALUES - Static variable in class org.elasticsearch.search.aggregations.Aggregation.CommonFields
- valuesCursor - Variable in class org.elasticsearch.index.fielddata.SortingNumericDocValues
- valueSerializer - Variable in class org.elasticsearch.cluster.DiffableUtils.MapDiff
- valuesForDoc(SearchLookup, LeafReaderContext, int, Consumer<T>) - Method in interface org.elasticsearch.search.lookup.FieldValues
-
Loads the values for the given document and passes them to the consumer
- valuesIt() - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap
-
Returns a direct iterator over the keys.
- valuesIt() - Method in class org.elasticsearch.common.collect.ImmutableOpenMap
-
Returns a direct iterator over the keys.
- ValueSource - Interface in org.elasticsearch.ingest
-
Holds a value.
- ValueSource.ByteValue - Class in org.elasticsearch.ingest
- ValueSource.ListValue - Class in org.elasticsearch.ingest
- ValueSource.MapValue - Class in org.elasticsearch.ingest
- ValueSource.ObjectValue - Class in org.elasticsearch.ingest
- ValueSource.TemplatedValue - Class in org.elasticsearch.ingest
- valueSourceType() - Method in class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- valuesSource - Variable in class org.elasticsearch.search.aggregations.bucket.geogrid.GeoGridAggregator
- valuesSource - Variable in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator
- valuesSource - Variable in class org.elasticsearch.search.aggregations.bucket.terms.GlobalOrdinalsStringTermsAggregator
- ValuesSource - Class in org.elasticsearch.search.aggregations.support
-
A unified interface to different ways of getting input data for
Aggregator
s like DocValues from Lucene or script output. - ValuesSource() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource
- ValuesSource.Bytes - Class in org.elasticsearch.search.aggregations.support
-
ValuesSource for fields who's values are best thought of as byte arrays without any other meaning like
keyword
orip
. - ValuesSource.Bytes.FieldData - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.Bytes.Script - Class in org.elasticsearch.search.aggregations.support
-
ValuesSource
implementation for stand alone scripts returning a Bytes value - ValuesSource.Bytes.WithOrdinals - Class in org.elasticsearch.search.aggregations.support
-
Specialization of ValuesSource.Bytes who's underlying storage de-duplicates its bytes by storing them in a per-leaf sorted lookup table.
- ValuesSource.Bytes.WithOrdinals.FieldData - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.Bytes.WithScript - Class in org.elasticsearch.search.aggregations.support
-
ValuesSource
subclass for Bytes fields with a Value Script applied - ValuesSource.GeoPoint - Class in org.elasticsearch.search.aggregations.support
-
ValuesSource for fields who's values are best thought of as points on a globe.
- ValuesSource.GeoPoint.Fielddata - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.Numeric - Class in org.elasticsearch.search.aggregations.support
-
ValuesSource for fields who's values are best thought of as numbers.
- ValuesSource.Numeric.FieldData - Class in org.elasticsearch.search.aggregations.support
- ValuesSource.Numeric.Script - Class in org.elasticsearch.search.aggregations.support
-
ValuesSource
implementation for stand alone scripts returning a Numeric value - ValuesSource.Numeric.WithScript - Class in org.elasticsearch.search.aggregations.support
-
ValuesSource
subclass for Numeric fields with a Value Script applied - ValuesSource.Range - Class in org.elasticsearch.search.aggregations.support
-
ValuesSource for fields who's values are best thought of as ranges of numbers, dates, or IP addresses.
- ValuesSourceAggregationBuilder<AB extends ValuesSourceAggregationBuilder<AB>> - Class in org.elasticsearch.search.aggregations.support
- ValuesSourceAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- ValuesSourceAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
-
Read from a stream.
- ValuesSourceAggregationBuilder(ValuesSourceAggregationBuilder<AB>, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregationBuilder
- ValuesSourceAggregationBuilder.LeafOnly<VS extends ValuesSource,
AB extends ValuesSourceAggregationBuilder<AB>> - Class in org.elasticsearch.search.aggregations.support - ValuesSourceAggregationBuilder.MetricsAggregationBuilder<VS extends ValuesSource,
AB extends ValuesSourceAggregationBuilder<AB>> - Class in org.elasticsearch.search.aggregations.support - ValuesSourceAggregationBuilder.SingleMetricAggregationBuilder<VS extends ValuesSource,
AB extends ValuesSourceAggregationBuilder<AB>> - Class in org.elasticsearch.search.aggregations.support - ValuesSourceAggregatorFactory - Class in org.elasticsearch.search.aggregations.support
- ValuesSourceAggregatorFactory(String, ValuesSourceConfig, AggregationContext, AggregatorFactory, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceAggregatorFactory
- ValuesSourceCollectorSource(ValuesSourceConfig) - Constructor for class org.elasticsearch.search.aggregations.bucket.terms.MapStringTermsAggregator.ValuesSourceCollectorSource
- ValuesSourceConfig - Class in org.elasticsearch.search.aggregations.support
-
A configuration that tells aggregations how to retrieve data from the index in order to run a specific aggregation.
- ValuesSourceConfig(ValuesSourceType, FieldContext, boolean, AggregationScript.LeafFactory, ValueType, Object, ZoneId, DocValueFormat, AggregationContext) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceConfig
- ValuesSourceRegistry - Class in org.elasticsearch.search.aggregations.support
-
ValuesSourceRegistry
holds the mapping fromValuesSourceType
s to functions for building aggregation components. - ValuesSourceRegistry(Map<ValuesSourceRegistry.RegistryKey<?>, List<Map.Entry<ValuesSourceType, ?>>>, AggregationUsageService) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSourceRegistry
- ValuesSourceRegistry.Builder - Class in org.elasticsearch.search.aggregations.support
- ValuesSourceRegistry.RegistryKey<T> - Class in org.elasticsearch.search.aggregations.support
- valuesSourceType - Variable in class org.elasticsearch.index.fielddata.IndexHistogramFieldData
- valuesSourceType - Variable in class org.elasticsearch.index.fielddata.plain.AbstractLatLonPointIndexFieldData
- valuesSourceType - Variable in class org.elasticsearch.index.fielddata.plain.BinaryIndexFieldData
- valuesSourceType - Variable in class org.elasticsearch.index.fielddata.plain.BytesBinaryIndexFieldData
- valuesSourceType - Variable in class org.elasticsearch.index.fielddata.plain.SortedNumericIndexFieldData
- valuesSourceType - Variable in class org.elasticsearch.index.fielddata.plain.StringBinaryIndexFieldData
- ValuesSourceType - Interface in org.elasticsearch.search.aggregations.support
-
ValuesSourceType
represents a collection of fields that share a common set of operations, for example all numeric fields. - ValueType - Enum Class in org.elasticsearch.search.aggregations.support
- VARIABLE - Enum constant in enum class org.elasticsearch.index.mapper.RangeType.LengthType
- VARIABLE_HEADER_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- VARIABLE_HEADER_SIZE_POSITION - Static variable in class org.elasticsearch.transport.TcpHeader
- VariableWidthHistogramAggregationBuilder - Class in org.elasticsearch.search.aggregations.bucket.histogram
- VariableWidthHistogramAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
-
Create a new builder with the given name.
- VariableWidthHistogramAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
-
Read in object data from a stream, for internal use only.
- VariableWidthHistogramAggregationBuilder(VariableWidthHistogramAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.bucket.histogram.VariableWidthHistogramAggregationBuilder
- VariableWidthHistogramAggregator - Class in org.elasticsearch.search.aggregations.bucket.histogram
- VariableWidthHistogramAggregatorFactory - Class in org.elasticsearch.search.aggregations.bucket.histogram
- VariableWidthHistogramAggregatorSupplier - Interface in org.elasticsearch.search.aggregations.bucket.histogram
- variance - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- variancePopulation - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- varianceSampling - Variable in class org.elasticsearch.search.aggregations.metrics.ParsedExtendedStats
- VARY - Static variable in class org.elasticsearch.http.CorsHandler
- VEC - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- VEM - Enum constant in enum class org.elasticsearch.index.store.LuceneFilesExtensions
- verbose - Variable in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
- verbose() - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Returns whether the request will return a verbose response.
- verbose() - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
-
true
if detailed information about each segment should be returned,false
otherwise. - verbose(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
-
Set to
false
to only show the snapshot names and the indices they contain. - verbose(boolean) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
-
Sets the
verbose
option. - VERBOSITY_INCREASE_TIMEOUT_SETTING - Static variable in class org.elasticsearch.discovery.PeerFinder
- VerificationFailure - Class in org.elasticsearch.repositories
- VerificationFailure(String, Exception) - Constructor for class org.elasticsearch.repositories.VerificationFailure
- VERIFIED_BEFORE_CLOSE_SETTING - Static variable in class org.elasticsearch.cluster.metadata.MetadataIndexStateService
- verify() - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Returns true if repository should be verified after creation
- verify() - Method in class org.elasticsearch.index.store.VerifyingIndexOutput
-
Verifies the checksum and compares the written length with the expected file length.
- verify(boolean) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
-
Sets whether or not the repository should be verified after creation
- verify(String, String, ActionListener<List<DiscoveryNode>>) - Method in class org.elasticsearch.repositories.VerifyNodeRepositoryAction
- verify(String, DiscoveryNode) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
- verify(String, DiscoveryNode) - Method in class org.elasticsearch.repositories.FilterRepository
- verify(String, DiscoveryNode) - Method in interface org.elasticsearch.repositories.Repository
-
Verifies repository settings on data node.
- verify(IndexInput) - Static method in class org.elasticsearch.index.store.Store
- verify(IndexOutput) - Static method in class org.elasticsearch.index.store.Store
- VERIFY_INDEX - Enum constant in enum class org.elasticsearch.indices.recovery.RecoveryState.Stage
-
potentially running check index
- verifyActive() - Method in class org.elasticsearch.index.shard.IndexShard
- verifyCompatibility(PluginDescriptor) - Static method in class org.elasticsearch.plugins.PluginsService
-
Verify the given plugin is compatible with the current Elasticsearch installation.
- verifyEngineBeforeIndexClosing() - Method in class org.elasticsearch.index.engine.Engine
-
Performs the pre-closing checks on the
Engine
. - verifyEngineBeforeIndexClosing() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- VerifyIndex() - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- VerifyIndex(StreamInput) - Constructor for class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- verifyIndexIsDeleted(Index, ClusterState) - Method in interface org.elasticsearch.indices.cluster.IndicesClusterStateService.AllocatedIndices
-
Verify that the contents on disk for the given index is deleted; if not, delete the contents.
- verifyIndexIsDeleted(Index, ClusterState) - Method in class org.elasticsearch.indices.IndicesService
-
Verify that the contents on disk for the given index is deleted; if not, delete the contents.
- verifyIndexMetadata(IndexMetadata, IndexMetadata) - Method in class org.elasticsearch.indices.IndicesService
-
This method verifies that the given
metadata
holds sane values to create anIndexService
. - verifyIndexMetadata(IndexMetadata, Version) - Method in class org.elasticsearch.cluster.metadata.IndexMetadataVerifier
-
Checks that the index can be upgraded to the current version of the master node.
- VerifyingIndexOutput - Class in org.elasticsearch.index.store
-
abstract class for verifying what was written.
- VerifyNodeRepositoryAction - Class in org.elasticsearch.repositories
- VerifyNodeRepositoryAction(TransportService, ClusterService, RepositoriesService) - Constructor for class org.elasticsearch.repositories.VerifyNodeRepositoryAction
- VerifyNodeRepositoryAction.VerifyNodeRepositoryRequest - Class in org.elasticsearch.repositories
- VerifyNodeRepositoryRequest(StreamInput) - Constructor for class org.elasticsearch.repositories.VerifyNodeRepositoryAction.VerifyNodeRepositoryRequest
- verifyRepository(String, ActionListener<List<DiscoveryNode>>) - Method in class org.elasticsearch.repositories.RepositoriesService
- verifyRepository(VerifyRepositoryRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Verifies a repository.
- verifyRepository(VerifyRepositoryRequest, ActionListener<VerifyRepositoryResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
-
Verifies a repository.
- VerifyRepositoryAction - Class in org.elasticsearch.action.admin.cluster.repositories.verify
-
Verify repository action
- verifyRepositoryRequest(String) - Static method in class org.elasticsearch.client.Requests
-
Verifies snapshot repository
- VerifyRepositoryRequest - Class in org.elasticsearch.action.admin.cluster.repositories.verify
-
Verify repository request.
- VerifyRepositoryRequest() - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
- VerifyRepositoryRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
-
Constructs a new unregister repository request with the provided name.
- VerifyRepositoryRequest(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
- VerifyRepositoryRequestBuilder - Class in org.elasticsearch.action.admin.cluster.repositories.verify
-
Builder for verify repository request
- VerifyRepositoryRequestBuilder(ElasticsearchClient, VerifyRepositoryAction) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequestBuilder
-
Constructs unregister repository request builder
- VerifyRepositoryRequestBuilder(ElasticsearchClient, VerifyRepositoryAction, String) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequestBuilder
-
Constructs unregister repository request builder with specified repository name
- VerifyRepositoryResponse - Class in org.elasticsearch.action.admin.cluster.repositories.verify
-
Verify repository response
- VerifyRepositoryResponse() - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- VerifyRepositoryResponse(List<VerifyRepositoryResponse.NodeView>) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- VerifyRepositoryResponse(DiscoveryNode[]) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- VerifyRepositoryResponse(StreamInput) - Constructor for class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- VerifyRepositoryResponse.NodeView - Class in org.elasticsearch.action.admin.cluster.repositories.verify
- verifyShardBeforeIndexClosing() - Method in class org.elasticsearch.index.shard.IndexShard
-
Performs the pre-closing checks on the
IndexShard
. - version - Variable in class org.elasticsearch.action.DocWriteResponse.Builder
- version - Variable in class org.elasticsearch.cluster.coordination.ApplyCommitRequest
- version - Variable in class org.elasticsearch.common.lucene.uid.VersionsAndSeqNoResolver.DocIdAndVersion
- version - Variable in class org.elasticsearch.index.engine.Segment
- version - Variable in class org.elasticsearch.transport.NetworkMessage
- version() - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- version() - Method in class org.elasticsearch.action.delete.DeleteRequest
- version() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the document version for this request
- version() - Method in class org.elasticsearch.action.get.GetRequest
-
Sets the version, which will cause the get operation to only be performed if a matching version exists and no changes happened on the doc since then.
- version() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- version() - Method in class org.elasticsearch.action.index.IndexRequest
-
Returns stored version.
- version() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- version() - Method in class org.elasticsearch.action.update.UpdateRequest
- version() - Method in class org.elasticsearch.cluster.ClusterState
- version() - Method in class org.elasticsearch.cluster.metadata.ComponentTemplate
- version() - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- version() - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- version() - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- version() - Method in class org.elasticsearch.cluster.metadata.Metadata
- version() - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- version() - Method in class org.elasticsearch.cluster.routing.RoutingTable
-
Returns the version of the
RoutingTable
. - version() - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
-
What version of metadata to use for the snapshot in the repository
- version() - Method in class org.elasticsearch.index.engine.Engine.Get
- version() - Method in class org.elasticsearch.index.engine.Engine.GetResult
- version() - Method in class org.elasticsearch.index.engine.Engine.NoOp
- version() - Method in class org.elasticsearch.index.engine.Engine.Operation
- version() - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- version() - Method in class org.elasticsearch.index.mapper.ParsedDocument
- version() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- version() - Method in class org.elasticsearch.index.seqno.RetentionLeases
-
The version of this retention lease collection.
- version() - Method in class org.elasticsearch.index.translog.Translog.Delete
- version() - Method in class org.elasticsearch.index.translog.Translog.Index
- version() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- version() - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Indicates whether the document's version will be included in the search hits.
- version() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Indicates whether the document's version will be included in the search hits.
- version() - Method in class org.elasticsearch.search.fetch.FetchContext
-
Should the response include version metadata
- version() - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- version() - Method in class org.elasticsearch.search.internal.SearchContext
- version() - Method in class org.elasticsearch.search.internal.SubSearchContext
- version() - Method in class org.elasticsearch.snapshots.SnapshotInfo
-
Returns the version of elasticsearch that the snapshot was created with.
- version() - Method in class org.elasticsearch.transport.BytesTransportRequest
- version(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.TopHitsAggregationBuilder
-
Should each
SearchHit
be returned with a version associated with it. - version(boolean) - Method in class org.elasticsearch.search.internal.FilteredSearchContext
- version(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
- version(boolean) - Method in class org.elasticsearch.search.internal.SubSearchContext
- version(long) - Method in class org.elasticsearch.action.delete.DeleteRequest
- version(long) - Method in interface org.elasticsearch.action.DocWriteRequest
-
Sets the version, which will perform the operation only if a matching version exists and no changes happened on the doc since then.
- version(long) - Method in class org.elasticsearch.action.get.GetRequest
- version(long) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- version(long) - Method in class org.elasticsearch.action.index.IndexRequest
- version(long) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- version(long) - Method in class org.elasticsearch.action.update.UpdateRequest
- version(long) - Method in class org.elasticsearch.cluster.ClusterState.Builder
- version(long) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata.Builder
- version(long) - Method in class org.elasticsearch.cluster.metadata.Metadata.Builder
- version(long) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
- version(long) - Method in class org.elasticsearch.index.engine.Engine.Get
- version(long) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- version(long) - Method in class org.elasticsearch.search.SearchHit
- version(Boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
-
Should each
SearchHit
be returned with a version associated with it. - version(Integer) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- version(Integer) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata.Builder
- version(Integer) - Method in class org.elasticsearch.cluster.metadata.MetadataIndexTemplateService.PutRequest
- version(Long) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.Builder
- version(Field) - Method in class org.elasticsearch.index.mapper.DocumentParserContext
- Version - Class in org.elasticsearch
- VERSION - Enum constant in enum class org.elasticsearch.cluster.ClusterState.Metric
- VERSION - Enum constant in enum class org.elasticsearch.ingest.IngestDocument.Metadata
- VERSION - Static variable in class org.elasticsearch.action.update.UpdateHelper.ContextFields
- VERSION - Static variable in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
- VERSION_CONFLICTS_FIELD - Static variable in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- VERSION_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- VERSION_ID_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- VERSION_KEY - Static variable in class org.elasticsearch.ingest.Pipeline
- VERSION_POSITION - Static variable in class org.elasticsearch.transport.TcpHeader
- VERSION_TYPE - Enum constant in enum class org.elasticsearch.ingest.IngestDocument.Metadata
- VERSION_WITH_HEADER_SIZE - Static variable in class org.elasticsearch.transport.TcpHeader
- VersionConflictEngineException - Exception in org.elasticsearch.index.engine
- VersionConflictEngineException(StreamInput) - Constructor for exception org.elasticsearch.index.engine.VersionConflictEngineException
- VersionConflictEngineException(ShardId, String, long, long, long, long) - Constructor for exception org.elasticsearch.index.engine.VersionConflictEngineException
- VersionConflictEngineException(ShardId, String, String) - Constructor for exception org.elasticsearch.index.engine.VersionConflictEngineException
- VersionConflictEngineException(ShardId, String, Throwable, Object...) - Constructor for exception org.elasticsearch.index.engine.VersionConflictEngineException
- VersionConflictEngineException(ShardId, Engine.Operation, long, boolean) - Constructor for exception org.elasticsearch.index.engine.VersionConflictEngineException
- VersionedNamedWriteable - Interface in org.elasticsearch.common.io.stream
-
A
NamedWriteable
that has a minimum version associated with it. - versionField() - Static method in class org.elasticsearch.index.mapper.VersionFieldMapper
- VersionFieldMapper - Class in org.elasticsearch.index.mapper
-
Mapper for the _version field.
- VersionMismatchException - Exception in org.elasticsearch.action.search
- VersionMismatchException(String, Object...) - Constructor for exception org.elasticsearch.action.search.VersionMismatchException
- VersionMismatchException(StreamInput) - Constructor for exception org.elasticsearch.action.search.VersionMismatchException
- versions() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeResponse
-
Returns the highest upgrade version of the node that performed metadata upgrade and the the version of the oldest lucene segment for each index that was upgraded.
- versions() - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsClusterStateUpdateRequest
-
Returns the index to version map for indices that should be updated
- versions(Map<String, Tuple<Version, String>>) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsClusterStateUpdateRequest
-
Sets the index to version map for indices that should be updated
- versions(Map<String, Tuple<Version, String>>) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequest
-
Sets the index versions to be updated
- Versions - Class in org.elasticsearch.common.lucene.uid
- Versions() - Constructor for class org.elasticsearch.common.lucene.uid.Versions
- VersionsAndSeqNoResolver - Class in org.elasticsearch.common.lucene.uid
-
Utility class to resolve the Lucene doc ID, version, seqNo and primaryTerms for a given uid.
- VersionsAndSeqNoResolver.DocIdAndSeqNo - Class in org.elasticsearch.common.lucene.uid
-
Wraps an
LeafReaderContext
, a doc ID relative to the context doc base and a seqNo. - VersionsAndSeqNoResolver.DocIdAndVersion - Class in org.elasticsearch.common.lucene.uid
-
Wraps an
LeafReaderContext
, a doc ID relative to the context doc base and a version. - versionSetting(String, Version, Setting.Property...) - Static method in class org.elasticsearch.common.settings.Setting
- versionStats() - Method in class org.elasticsearch.action.admin.cluster.stats.VersionStats
- VersionStats - Class in org.elasticsearch.action.admin.cluster.stats
-
VersionStats
calculates statistics for index creation versions mapped to the number of indices, primary shards, and size of primary shards on disk. - versionType() - Method in class org.elasticsearch.action.delete.DeleteRequest
- versionType() - Method in interface org.elasticsearch.action.DocWriteRequest
-
Get the document version type for this request
- versionType() - Method in class org.elasticsearch.action.get.GetRequest
- versionType() - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- versionType() - Method in class org.elasticsearch.action.index.IndexRequest
- versionType() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- versionType() - Method in class org.elasticsearch.action.update.UpdateRequest
- versionType() - Method in class org.elasticsearch.index.engine.Engine.Get
- versionType() - Method in class org.elasticsearch.index.engine.Engine.NoOp
- versionType() - Method in class org.elasticsearch.index.engine.Engine.Operation
- versionType() - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- versionType(VersionType) - Method in class org.elasticsearch.action.delete.DeleteRequest
- versionType(VersionType) - Method in interface org.elasticsearch.action.DocWriteRequest
-
Sets the versioning type.
- versionType(VersionType) - Method in class org.elasticsearch.action.get.GetRequest
-
Sets the versioning type.
- versionType(VersionType) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- versionType(VersionType) - Method in class org.elasticsearch.action.index.IndexRequest
- versionType(VersionType) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- versionType(VersionType) - Method in class org.elasticsearch.action.update.UpdateRequest
- versionType(VersionType) - Method in class org.elasticsearch.index.engine.Engine.Get
- versionType(VersionType) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- VersionType - Enum Class in org.elasticsearch.index
- versionUpdatePack() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- visit(QueryVisitor) - Method in class org.apache.lucene.queries.BlendedTermQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.common.lucene.search.function.ScriptScoreQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.index.query.DateRangeIncludingNowQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.index.search.ESToParentBlockJoinQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.search.runtime.BooleanScriptFieldTermQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.search.runtime.DoubleScriptFieldTermsQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.search.runtime.LongScriptFieldTermsQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.search.runtime.AbstractStringScriptFieldAutomatonQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.search.runtime.GeoPointScriptFieldDistanceFeatureQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.search.runtime.LongScriptFieldDistanceFeatureQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.search.runtime.StringScriptFieldPrefixQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.search.runtime.StringScriptFieldRangeQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.search.runtime.StringScriptFieldTermQuery
- visit(QueryVisitor) - Method in class org.elasticsearch.search.runtime.StringScriptFieldTermsQuery
- visit(Binding<T>) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(Binding<T>) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a mapping from a key (type and optional annotation) to the strategy for getting instances of the type.
- visit(ConstructorBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a constructor binding.
- visit(ConstructorBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(ConvertedConstantBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a binding created from converting a bound instance to a new type.
- visit(ConvertedConstantBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(ExposedBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a binding to a key exposed from an enclosed private environment.
- visit(ExposedBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(InjectionRequest<?>) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(InjectionRequest<?>) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a request to inject the instance fields and methods of an instance.
- visit(InstanceBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a instance binding.
- visit(InstanceBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(LinkedKeyBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a linked key binding.
- visit(LinkedKeyBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(MembersInjectorLookup<T>) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(MembersInjectorLookup<T>) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a lookup of the members injector.
- visit(Message) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(Message) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit an error message and the context in which it occurred.
- visit(PrivateElements) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(PrivateElements) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a collection of configuration elements for a private binder.
- visit(ProviderBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a binding to a
Provider
that delegates to the binding for the provided type. - visit(ProviderBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(ProviderInstanceBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a provider instance binding.
- visit(ProviderInstanceBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(ProviderKeyBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit a provider key binding.
- visit(ProviderKeyBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visit(ProviderLookup<T>) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(ProviderLookup<T>) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a lookup of the provider for a type.
- visit(ScopeBinding) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(ScopeBinding) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a registration of a scope annotation with the scope that implements it.
- visit(StaticInjectionRequest) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(StaticInjectionRequest) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a request to inject the static fields and methods of type.
- visit(TypeConverterBinding) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(TypeConverterBinding) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit a registration of type converters for matching target types.
- visit(TypeListenerBinding) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
- visit(TypeListenerBinding) - Method in interface org.elasticsearch.common.inject.spi.ElementVisitor
-
Visit an injectable type listener binding.
- visit(UntargettedBinding<? extends T>) - Method in interface org.elasticsearch.common.inject.spi.BindingTargetVisitor
-
Visit an untargetted binding.
- visit(UntargettedBinding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
- visitEagerSingleton() - Method in interface org.elasticsearch.common.inject.spi.BindingScopingVisitor
-
Visit an eager singleton or single instance.
- visitEagerSingleton() - Method in class org.elasticsearch.common.inject.spi.DefaultBindingScopingVisitor
- visitMapping(Map<String, ?>, BiConsumer<String, Map<String, ?>>) - Static method in class org.elasticsearch.action.admin.cluster.stats.MappingVisitor
- visitNoScoping() - Method in interface org.elasticsearch.common.inject.spi.BindingScopingVisitor
-
Visit an unspecified or unscoped strategy.
- visitNoScoping() - Method in class org.elasticsearch.common.inject.spi.DefaultBindingScopingVisitor
- visitor(FieldsVisitor) - Method in class org.elasticsearch.search.fetch.FetchProfiler
- visitOther() - Method in class org.elasticsearch.common.inject.spi.DefaultBindingScopingVisitor
-
Default visit implementation.
- visitOther(Binding<? extends T>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingTargetVisitor
-
Default visit implementation.
- visitOther(Element) - Method in class org.elasticsearch.common.inject.spi.DefaultElementVisitor
-
Default visit implementation.
- visitRuntimeMapping(Map<String, ?>, BiConsumer<String, Map<String, ?>>) - Static method in class org.elasticsearch.action.admin.cluster.stats.MappingVisitor
- visitScope(Scope) - Method in interface org.elasticsearch.common.inject.spi.BindingScopingVisitor
-
Visit a scope instance.
- visitScope(Scope) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingScopingVisitor
- visitScopeAnnotation(Class<? extends Annotation>) - Method in interface org.elasticsearch.common.inject.spi.BindingScopingVisitor
-
Visit a scope annotation.
- visitScopeAnnotation(Class<? extends Annotation>) - Method in class org.elasticsearch.common.inject.spi.DefaultBindingScopingVisitor
- visualizeKeyDistribution(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenIntMap.Builder
- visualizeKeyDistribution(int) - Method in class org.elasticsearch.common.collect.ImmutableOpenMap.Builder
- vocabluarySize - Variable in class org.elasticsearch.search.suggest.phrase.WordScorer
- voidProviderMethod() - Method in class org.elasticsearch.common.inject.internal.Errors
- VoteCollection() - Constructor for class org.elasticsearch.cluster.coordination.CoordinationState.VoteCollection
- VotingConfigExclusion(String, String) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfigExclusion
- VotingConfigExclusion(DiscoveryNode) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfigExclusion
- VotingConfigExclusion(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfigExclusion
- VotingConfiguration(Set<String>) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfiguration
- VotingConfiguration(StreamInput) - Constructor for class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfiguration
W
- WAIT - Enum constant in enum class org.elasticsearch.monitor.jvm.HotThreads.ReportType
- WAIT_FOR_ACTIVE_SHARDS_DEFAULT_DEPRECATION_MESSAGE - Static variable in class org.elasticsearch.rest.action.admin.indices.RestCloseIndexAction
- WAIT_UNTIL - Enum constant in enum class org.elasticsearch.action.support.WriteRequest.RefreshPolicy
-
Leave this request open until a refresh has made the contents of this request visible to search.
- waitForActiveShards - Variable in class org.elasticsearch.action.support.replication.ReplicationRequest
-
The number of shard copies that must be active before proceeding with the replication action.
- waitForActiveShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexClusterStateUpdateRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexClusterStateUpdateRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.bulk.BulkRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- waitForActiveShards() - Method in class org.elasticsearch.action.update.UpdateRequest
- waitForActiveShards(int) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
A shortcut for
ClusterHealthRequest.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
A shortcut for
CreateIndexRequest.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
A shortcut for
OpenIndexRequest.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(int) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
-
A shortcut for
RolloverRequestBuilder.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(int) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
A shortcut for
BulkRequest.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(int) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
A shortcut for
ReplicationRequest.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(int) - Method in class org.elasticsearch.action.update.UpdateRequest
-
A shortcut for
UpdateRequest.waitForActiveShards(ActiveShardCount)
where the numerical shard count is passed in, instead of having to first callActiveShardCount.from(int)
to get the ActiveShardCount. - waitForActiveShards(String[], ActiveShardCount, TimeValue, Consumer<Boolean>, Consumer<Exception>) - Method in class org.elasticsearch.action.support.ActiveShardsObserver
-
Waits on the specified number of active shards to be started before executing the
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
Sets the number of shard copies that must be active across all indices before getting the health status.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexClusterStateUpdateRequest
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexClusterStateUpdateRequest
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
-
Sets the number of shard copies that should be active for index creation to return.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexClusterStateUpdateRequest
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
-
Sets the number of shard copies that should be active for indices opening to return.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequestBuilder
-
Sets the number of shard copies that should be active for creation of the new rollover index to return.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.bulk.BulkRequest
-
Sets the number of shard copies that must be active before proceeding with the write.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
Sets the number of shard copies that must be active before proceeding with the replication operation.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.action.update.UpdateRequest
-
Sets the number of shard copies that must be active before proceeding with the write.
- waitForActiveShards(ActiveShardCount) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequestBuilder
-
The number of shard copies that must be active before proceeding with the write.
- waitForCheckpoint() - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- waitForCompletion() - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
- waitForCompletion() - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
Returns true if the request should wait for the snapshot completion before returning
- waitForCompletion() - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
Returns wait for completion setting
- waitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequestBuilder
- waitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
-
If set to true the operation should wait for the snapshot completion before returning.
- waitForCompletion(boolean) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
-
If this parameter is set to true the operation will wait for completion of restore process before returning.
- waitForCompletionTimeout(TimeValue) - Static method in class org.elasticsearch.action.admin.cluster.node.tasks.list.TransportListTasksAction
- waitForEvents() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForEvents(Priority) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForGreenStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForIndex(Directory, long) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Wait for an index to exist for up to
timeLimitMillis
. - waitForMetadataVersion() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- waitForMetadataVersion(long) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- waitForNewMasterAndRetry(String, ClusterStateObserver, TransportRequest, ActionListener<Void>, Predicate<ClusterState>) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction
- waitForNextChange(ClusterStateObserver.Listener) - Method in class org.elasticsearch.cluster.ClusterStateObserver
- waitForNextChange(ClusterStateObserver.Listener, Predicate<ClusterState>) - Method in class org.elasticsearch.cluster.ClusterStateObserver
- waitForNextChange(ClusterStateObserver.Listener, Predicate<ClusterState>, TimeValue) - Method in class org.elasticsearch.cluster.ClusterStateObserver
-
Wait for the next cluster state which satisfies statePredicate
- waitForNextChange(ClusterStateObserver.Listener, TimeValue) - Method in class org.elasticsearch.cluster.ClusterStateObserver
- waitForNodes() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForNodes(String) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
Waits for N number of nodes.
- waitForNoInitializingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForNoInitializingShards(boolean) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
Sets whether the request should wait for there to be no initializing shards before retrieving the cluster health status.
- waitForNoRelocatingShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForNoRelocatingShards(boolean) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
-
Sets whether the request should wait for there to be no relocating shards before retrieving the cluster health status.
- waitForPersistentTask(Predicate<PersistentTasksCustomMetadata.PersistentTask<?>>, TimeValue, PersistentTasksService.WaitForPersistentTaskListener<?>) - Method in class org.elasticsearch.persistent.AllocatedPersistentTask
-
Waits for a given persistent task to comply with a given predicate, then call back the listener accordingly.
- waitForPersistentTaskCondition(String, Predicate<PersistentTasksCustomMetadata.PersistentTask<?>>, TimeValue, PersistentTasksService.WaitForPersistentTaskListener<?>) - Method in class org.elasticsearch.persistent.PersistentTasksService
-
Waits for a given persistent task to comply with a given predicate, then call back the listener accordingly.
- waitForPersistentTasksCondition(Predicate<PersistentTasksCustomMetadata>, TimeValue, ActionListener<Boolean>) - Method in class org.elasticsearch.persistent.PersistentTasksService
-
Waits for persistent tasks to comply with a given predicate, then call back the listener accordingly.
- waitForStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForStatus(ClusterHealthStatus) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitForTaskCompletion(Task, long) - Method in class org.elasticsearch.tasks.TaskManager
-
Blocks the calling thread, waiting for the task to vanish from the TaskManager.
- waitForTimeout() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- waitForTimeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- waitForYellowStatus() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- waitIfOngoing() - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
-
Returns
true
iff a flush should block if a another flush operation is already running. - waitIfOngoing(boolean) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
-
if set to
true
the flush will block if a another flush operation is already running until the flush can be performed. - WAITING - Enum constant in enum class org.elasticsearch.cluster.SnapshotDeletionsInProgress.State
-
Delete is waiting to execute because there are snapshots and or a delete operation that has to complete before this delete may run.
- WAITING - Enum constant in enum class org.elasticsearch.cluster.SnapshotsInProgress.ShardState
-
Shard snapshot is waiting for the primary to snapshot to become available.
- waitToBeElectedAsMaster(int, TimeValue, NodeJoinController.ElectionCallback) - Method in class org.elasticsearch.discovery.zen.NodeJoinController
-
waits for enough incoming joins from master eligible nodes to complete the master election
- warm(ElasticsearchDirectoryReader) - Method in interface org.elasticsearch.index.engine.Engine.Warmer
-
Called once a new top-level reader is opened.
- warmer - Variable in class org.elasticsearch.action.admin.indices.stats.CommonStats
- warmer() - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- warmer(boolean) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- Warmer - Enum constant in enum class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags.Flag
- WARMER - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- warmerService() - Method in class org.elasticsearch.index.shard.IndexShard
- warmerStats() - Method in class org.elasticsearch.index.shard.IndexShard
- WarmerStats - Class in org.elasticsearch.index.warmer
- WarmerStats() - Constructor for class org.elasticsearch.index.warmer.WarmerStats
- WarmerStats(long, long, long) - Constructor for class org.elasticsearch.index.warmer.WarmerStats
- WarmerStats(StreamInput) - Constructor for class org.elasticsearch.index.warmer.WarmerStats
- warmReader(IndexShard, ElasticsearchDirectoryReader) - Method in interface org.elasticsearch.index.IndexWarmer.Listener
-
Queue tasks to warm-up the given segments and return handles that allow to wait for termination of the execution of those tasks.
- warn(DeprecationCategory, String, String, Object...) - Method in class org.elasticsearch.common.logging.DeprecationLogger
-
Logs a message at the
Level.WARN
level for less critical deprecations that won't break in next version. - WARN - Enum constant in enum class org.elasticsearch.index.SlowLogLevel
- WARNING_HEADER_PATTERN - Static variable in class org.elasticsearch.common.logging.HeaderWarning
-
Regular expression to test if a string matches the RFC7234 specification for warning headers.
- WARNING_XCONTENT_LOCATION_PATTERN - Static variable in class org.elasticsearch.common.logging.HeaderWarning
- wasReadFromDiff() - Method in class org.elasticsearch.cluster.ClusterState
- watcher() - Method in class org.elasticsearch.watcher.WatcherHandle
- WatcherHandle<W extends ResourceWatcher> - Class in org.elasticsearch.watcher
- WEEK - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- WEEK_BASED_FORMATS - Static variable in enum class org.elasticsearch.common.time.FormatNames
- WEEK_DATE - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- WEEK_DATE_TIME - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- WEEK_DATE_TIME_NO_MILLIS - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- WEEK_FIELDS_ROOT - Static variable in class org.elasticsearch.common.time.DateFormatters
- WEEK_OF_WEEKYEAR - Enum constant in enum class org.elasticsearch.common.rounding.DateTimeUnit
- WEEK_OF_WEEKYEAR - Enum constant in enum class org.elasticsearch.common.Rounding.DateTimeUnit
- WEEK_YEAR - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- WEEK_YEAR_WEEK - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- weekDate() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a full date as four digit weekyear, two digit week of weekyear, and one digit day of week (xxxx-'W'ww-e).
- weekDateTime() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter that combines a full weekyear date and time, separated by a 'T' (xxxx-'W'ww-e'T'HH:mm:ss.SSSZZ).
- weekDateTimeNoMillis() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter that combines a full weekyear date and time without millis, separated by a 'T' (xxxx-'W'ww-e'T'HH:mm:ssZZ).
- weeks(int) - Static method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- weekyear() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a four digit weekyear.
- WEEKYEAR - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- WEEKYEAR_WEEK_DAY - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- weekyearWeek() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a four digit weekyear and two digit week of weekyear.
- weekyearWeekDay() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a four digit weekyear, two digit week of weekyear, and one digit day of week.
- weigher(ToLongBiFunction<K, V>) - Method in class org.elasticsearch.common.cache.CacheBuilder
- weight() - Method in class org.elasticsearch.common.cache.Cache
-
The weight of the entries in the cache.
- weight(MultiValuesSourceFieldConfig) - Method in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- WEIGHT_BYTES_SETTING - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- WEIGHT_FIELD - Static variable in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder
- WEIGHT_FIELD - Static variable in class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- WEIGHT_INT_SETTING - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- WEIGHT_LONG_SETTING - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- WEIGHT_OBJECTS_SETTING - Static variable in class org.elasticsearch.common.util.PageCacheRecycler
- WeightBuilder - Class in org.elasticsearch.index.query.functionscore
-
A query that multiplies the weight to the score.
- WeightBuilder() - Constructor for class org.elasticsearch.index.query.functionscore.WeightBuilder
-
Standard constructor.
- WeightBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.functionscore.WeightBuilder
-
Read from a stream.
- weightedAvg(String) - Static method in class org.elasticsearch.search.aggregations.AggregationBuilders
-
Create a new
Avg
aggregation with the given name. - WeightedAvg - Interface in org.elasticsearch.search.aggregations.metrics
-
An aggregation that computes the average of the values in the current bucket.
- WeightedAvgAggregationBuilder - Class in org.elasticsearch.search.aggregations.metrics
- WeightedAvgAggregationBuilder(String) - Constructor for class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- WeightedAvgAggregationBuilder(StreamInput) - Constructor for class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
-
Read from a stream.
- WeightedAvgAggregationBuilder(WeightedAvgAggregationBuilder, AggregatorFactories.Builder, Map<String, Object>) - Constructor for class org.elasticsearch.search.aggregations.metrics.WeightedAvgAggregationBuilder
- weightFactorFunction(float) - Static method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilders
- WeightFactorFunction - Class in org.elasticsearch.common.lucene.search.function
- WeightFactorFunction(float) - Constructor for class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- WeightFactorFunction(float, ScoreFunction) - Constructor for class org.elasticsearch.common.lucene.search.function.WeightFactorFunction
- whenComplete(CheckedConsumer<Response, Exception>, Consumer<Exception>) - Method in class org.elasticsearch.action.StepListener
-
Registers the given actions which are called when this step is completed.
- WHITESPACE - Enum constant in enum class org.elasticsearch.index.query.SimpleQueryStringFlag
- WHITESPACE - Enum constant in enum class org.elasticsearch.indices.analysis.PreBuiltAnalyzers
- WHITESPACE_ANALYZER - Static variable in class org.elasticsearch.common.lucene.Lucene
- WHITESPACE_MATCH_ONLY - Static variable in class org.elasticsearch.index.mapper.TextSearchInfo
-
Defines indexing information for fields that index as keywords, but split query input on whitespace to build disjunctions.
- WhitespaceAnalyzerProvider - Class in org.elasticsearch.index.analysis
- WhitespaceAnalyzerProvider(IndexSettings, Environment, String, Settings) - Constructor for class org.elasticsearch.index.analysis.WhitespaceAnalyzerProvider
- width() - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- Wildcard(String, String, String) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.Wildcard
- Wildcard(StreamInput) - Constructor for class org.elasticsearch.index.query.IntervalsSourceProvider.Wildcard
- WILDCARD_CHAR - Static variable in class org.elasticsearch.common.lucene.search.AutomatonQueries
-
Char equality with support for wildcards
- WILDCARD_ESCAPE - Static variable in class org.elasticsearch.common.lucene.search.AutomatonQueries
-
Escape character
- WILDCARD_STRING - Static variable in class org.elasticsearch.common.lucene.search.AutomatonQueries
-
String equality with support for wildcards
- wildcardIntervals(BytesRef, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
-
Create a wildcard
IntervalsSource
for the given pattern. - wildcardIntervals(BytesRef, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.TextFieldMapper.TextFieldType
- wildcardQuery(String, String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
Implements the wildcard search query.
- wildcardQuery(String, MultiTermQuery.RewriteMethod, boolean, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.StringFieldType
- wildcardQuery(String, MultiTermQuery.RewriteMethod, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.LongScriptFieldType
- wildcardQuery(String, MultiTermQuery.RewriteMethod, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.ConstantFieldType
- wildcardQuery(String, MultiTermQuery.RewriteMethod, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.flattened.FlattenedFieldMapper.KeyedFlattenedFieldType
- wildcardQuery(String, MultiTermQuery.RewriteMethod, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.KeywordFieldMapper.KeywordFieldType
-
Wildcard queries on keyword fields use the normalizer of the underlying field, regardless of their case sensitivity option
- wildcardQuery(String, MultiTermQuery.RewriteMethod, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.KeywordScriptFieldType
- wildcardQuery(String, MultiTermQuery.RewriteMethod, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- wildcardQuery(String, MultiTermQuery.RewriteMethod, boolean, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.StringFieldType
- wildcardQuery(String, MultiTermQuery.RewriteMethod, SearchExecutionContext) - Method in class org.elasticsearch.index.mapper.MappedFieldType
- WildcardQueryBuilder - Class in org.elasticsearch.index.query
-
Implements the wildcard search query.
- WildcardQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.WildcardQueryBuilder
-
Implements the wildcard search query.
- WildcardQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.WildcardQueryBuilder
-
Read from a stream.
- WildcardTypeImpl(Type[], Type[]) - Constructor for class org.elasticsearch.common.inject.internal.MoreTypes.WildcardTypeImpl
- window() - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Gets the window size for the moving average.
- window(int) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgPipelineAggregationBuilder
-
Sets the window size for the moving average.
- windowSize - Variable in class org.elasticsearch.search.rescore.RescorerBuilder
- windowSize() - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- windowSize(int) - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- with(Iterable<? extends Module>) - Method in interface org.elasticsearch.common.inject.util.Modules.OverriddenModuleBuilder
-
See the EDSL example at
override()
. - with(TemporalAdjuster) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- with(TemporalField, long) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- with(Module...) - Method in interface org.elasticsearch.common.inject.util.Modules.OverriddenModuleBuilder
-
See the EDSL example at
override()
. - withAddedEntry(SnapshotDeletionsInProgress.Entry) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
-
Returns a new instance of
SnapshotDeletionsInProgress
which adds the givenSnapshotDeletionsInProgress.Entry
to the invoking instance. - withAddedEntry(SnapshotsInProgress.Entry) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- withAddedSnapshot(SnapshotId, Map<IndexId, String>, Map<String, String>) - Method in class org.elasticsearch.repositories.IndexMetaDataGenerations
-
Create a new instance with the given snapshot and index metadata uuids and identifiers added.
- withAddedSnapshots(Collection<SnapshotId>) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- withBackoff(BiConsumer<BulkRequest, ActionListener<BulkResponse>>, BulkRequest) - Method in class org.elasticsearch.action.bulk.Retry
-
Invokes #accept(BulkRequest, ActionListener).
- withBackoff(BiConsumer<BulkRequest, ActionListener<BulkResponse>>, BulkRequest, ActionListener<BulkResponse>) - Method in class org.elasticsearch.action.bulk.Retry
-
Invokes #accept(BulkRequest, ActionListener).
- withBreakerService(CircuitBreakerService) - Method in class org.elasticsearch.common.util.BigArrays
-
Creates a new
BigArray
pointing at the specifiedCircuitBreakerService
. - withCircuitBreaking() - Method in class org.elasticsearch.common.util.BigArrays
-
Return an instance of this BigArrays class with circuit breaking explicitly enabled, instead of only accounting enabled
- withClone(String, String) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshots
-
Create a new instance that has a new snapshot by name
target
added which shares all files with the snapshot of namesource
. - withClones(ImmutableOpenMap<RepositoryShardId, SnapshotsInProgress.ShardSnapshotStatus>) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- withClusterUuid(String) - Method in class org.elasticsearch.repositories.RepositoryData
- withContentOrSourceParamParserOrNull(CheckedConsumer<XContentParser, IOException>) - Method in class org.elasticsearch.rest.RestRequest
-
Call a consumer with the parser for the contents of this request if it has contents, otherwise with a parser for the
source
parameter if there is one, otherwise withnull
. - withDayOfMonth(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withDayOfYear(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withEarlierOffsetAtOverlap() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withExtraDetails(Map<SnapshotId, RepositoryData.SnapshotDetails>) - Method in class org.elasticsearch.repositories.RepositoryData
-
Creates a copy of this instance that contains additional details read from the per-snapshot metadata blobs
- withFixedOffsetZone() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withGenId(long) - Method in class org.elasticsearch.repositories.RepositoryData
-
Create a new instance with the given generation and all other fields equal to this instance.
- withHour(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- WITHIN - Enum constant in enum class org.apache.lucene.queries.BinaryDocValuesRangeQuery.QueryType
- WITHIN - Enum constant in enum class org.elasticsearch.common.geo.ShapeRelation
- WITHIN - Enum constant in enum class org.elasticsearch.index.mapper.MappedFieldType.Relation
- withIncrementedVersion() - Method in class org.elasticsearch.cluster.metadata.Metadata
- withIncrementedVersion() - Method in class org.elasticsearch.cluster.routing.RoutingTable
- withinQuery(String, Object, Object, boolean, boolean) - Method in enum class org.elasticsearch.index.mapper.RangeType
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- withKey(Key<T>) - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- withLaterOffsetAtOverlap() - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withLocale(Locale) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- withLocale(Locale) - Method in interface org.elasticsearch.common.time.DateFormatter
-
Create a copy of this formatter that is configured to parse dates in the specified locale
- withMinute(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withMonth(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withNano(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withNanosecondResolution(DocValueFormat) - Static method in interface org.elasticsearch.search.DocValueFormat
- WithOrdinals() - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithOrdinals
- withoutOffset() - Method in class org.elasticsearch.common.Rounding
-
Strip the
offset
from these bounds. - withoutShardGenerations() - Method in class org.elasticsearch.repositories.RepositoryData
-
Creates a copy of this instance that does not track any shard generations.
- withoutUUIDs() - Method in class org.elasticsearch.repositories.RepositoryData
-
For test purposes, make a copy of this instance with the cluster- and repository UUIDs removed and all other fields unchanged, as if from an older version.
- withPartialValue(Object) - Method in exception org.elasticsearch.common.inject.ConfigurationException
-
Returns a copy of this configuration exception with the specified partial value.
- withRemainDecision(Decision) - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
-
Creates a new move decision from this decision, plus adding a remain decision.
- withRemovedEntry(String) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
-
Returns a new instance of
SnapshotDeletionsInProgress
that has the entry with the givendeleteUUID
removed from its entries. - withRemovedSnapshots(Collection<SnapshotId>) - Method in class org.elasticsearch.repositories.IndexMetaDataGenerations
-
Create a new instance with the given snapshot removed.
- withRepoGen(long) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- withRepoGen(long) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- withResponseHandler(RejectAwareActionListener<?>, Consumer<X>) - Static method in interface org.elasticsearch.index.reindex.RejectAwareActionListener
-
Return a new listener that delegates failure/reject to errorDelegate but forwards response to responseHandler
- withResult(String, SingleFeatureMigrationResult) - Method in class org.elasticsearch.upgrades.FeatureMigrationResults
-
Convenience method for updating the results of a migration run.
- withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.BindingImpl
- withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.ExposedBindingImpl
- withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.InstanceBindingImpl
- withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.LinkedBindingImpl
- withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.LinkedProviderBindingImpl
- withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.ProviderInstanceBindingImpl
- withScoping(Scoping) - Method in class org.elasticsearch.common.inject.internal.UntargettedBindingImpl
- WithScript(ValuesSource.Numeric, AggregationScript.LeafFactory) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Numeric.WithScript
- WithScript(ValuesSource, AggregationScript.LeafFactory) - Constructor for class org.elasticsearch.search.aggregations.support.ValuesSource.Bytes.WithScript
- withSecond(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withSettings(Settings) - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
- withShardStates(ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
-
Create a new instance that has its shard assignments replaced by the given shard assignment map.
- withSnapshotName(String) - Method in class org.elasticsearch.index.snapshots.blobstore.SnapshotFiles
-
Creates a new instance with the given snapshot name but otherwise identical to the current instance.
- withSnapshots(Collection<SnapshotId>) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- withSource(Object) - Method in interface org.elasticsearch.common.inject.Binder
-
Returns a binder that uses
source
as the reference location for configuration errors. - withSource(Object) - Method in class org.elasticsearch.common.inject.internal.Errors
-
Returns an instance that uses
source
as a reference point for newly added errors. - withSource(Object) - Method in interface org.elasticsearch.common.inject.PrivateBinder
- withStartedShards(ImmutableOpenMap<ShardId, SnapshotsInProgress.ShardSnapshotStatus>) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
-
Same as
SnapshotsInProgress.Entry.withShardStates(org.elasticsearch.common.collect.ImmutableOpenMap<org.elasticsearch.index.shard.ShardId, org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus>)
but does not check if the snapshot completed and thus is only to be used when starting new shard snapshots on data nodes for a running snapshot. - withStatus(RestStatus, ToXContentObject) - Static method in interface org.elasticsearch.common.xcontent.StatusToXContentObject
- withTempIndexService(IndexMetadata, CheckedFunction<IndexService, T, E>) - Method in class org.elasticsearch.indices.IndicesService
- withUpdatedEntriesForRepo(String, List<SnapshotsInProgress.Entry>) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- withUpdatedGeneration(String, long, long) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
-
Creates a new instance that has the given repository moved to the given
safeGeneration
andpendingGeneration
. - withUpdatedGeneration(ShardGeneration) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- withUpdatedIndexIds(Map<IndexId, IndexId>) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- withUuid(String) - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
- withUuid(String, String) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
-
Creates a new instance that records the UUID of the given repository.
- withYear(int) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- withYear(int) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withZone(ZoneId) - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- withZone(ZoneId) - Method in interface org.elasticsearch.common.time.DateFormatter
-
Create a copy of this formatter that is configured to parse dates in the specified time zone
- withZoneSameInstant(ZoneId) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- withZoneSameLocal(ZoneId) - Method in class org.elasticsearch.script.JodaCompatibleZonedDateTime
- WKT - Enum constant in enum class org.elasticsearch.common.geo.GeometryParserFormat
- WKT - Static variable in class org.elasticsearch.common.geo.GeometryFormatterFactory
- word - Variable in class org.elasticsearch.action.termvectors.TermVectorsFilter.ScoreTerm
- WORD - Enum constant in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
- WordScorer - Class in org.elasticsearch.search.suggest.phrase
- WordScorer(IndexReader, String, double, BytesRef) - Constructor for class org.elasticsearch.search.suggest.phrase.WordScorer
- WordScorer(IndexReader, Terms, String, double, BytesRef) - Constructor for class org.elasticsearch.search.suggest.phrase.WordScorer
- WordScorer.WordScorerFactory - Interface in org.elasticsearch.search.suggest.phrase
- WorkerBulkByScrollTaskState - Class in org.elasticsearch.index.reindex
-
Task behavior for
BulkByScrollTask
that does the actual work of querying and indexing - WorkerBulkByScrollTaskState(BulkByScrollTask, Integer, float) - Constructor for class org.elasticsearch.index.reindex.WorkerBulkByScrollTaskState
- WORSE_BALANCE - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
The shard could not be rebalanced to another node despite rebalancing being allowed, because moving the shard to the other node would not form a better cluster balance.
- wrap(boolean, Iterable<? extends BucketCollector>) - Static method in class org.elasticsearch.search.aggregations.MultiBucketCollector
-
Wraps a list of
BucketCollector
s with aMultiBucketCollector
. - wrap(byte[]) - Static method in class org.elasticsearch.common.io.stream.StreamInput
- wrap(byte[], int, int) - Static method in class org.elasticsearch.common.io.stream.StreamInput
- wrap(Object, ScriptService) - Static method in interface org.elasticsearch.ingest.ValueSource
- wrap(Object, ScriptService, Map<String, String>) - Static method in interface org.elasticsearch.ingest.ValueSource
- wrap(Runnable) - Static method in interface org.elasticsearch.action.ActionListener
-
Creates a listener that listens for a response (or failure) and executes the corresponding runnable when the response (or failure) is received.
- wrap(Runnable, Priority) - Static method in class org.elasticsearch.common.util.concurrent.PrioritizedRunnable
- wrap(Comparator<T>) - Method in enum class org.elasticsearch.search.sort.SortOrder
-
Wrap a comparator in one for this direction.
- wrap(Callable<T>, Priority) - Static method in class org.elasticsearch.common.util.concurrent.PrioritizedCallable
- wrap(Function<Q, T>, Writeable.Reader<Q>) - Method in interface org.elasticsearch.transport.TransportResponseHandler
- wrap(DirectoryReader, ShardId) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
-
Wraps the given reader in a
ElasticsearchDirectoryReader
as well as all it's sub-readers inElasticsearchLeafReader
to expose the given shard Id. - wrap(DirectoryReader, ShardId, ESCacheHelper) - Static method in class org.elasticsearch.common.lucene.index.ElasticsearchDirectoryReader
-
Wraps the given reader in a
ElasticsearchDirectoryReader
as well as all it's sub-readers inElasticsearchLeafReader
to expose the given shard Id. - wrap(ActionListener<Response>) - Method in class org.elasticsearch.action.support.ThreadedActionListener.Wrapper
- wrap(ActionListener<T>, CheckedConsumer<ActionListener<T>, Exception>) - Static method in class org.elasticsearch.action.ActionRunnable
- wrap(BackoffPolicy, Runnable) - Static method in class org.elasticsearch.action.bulk.BackoffPolicy
-
Wraps the backoff policy in one that calls a method every time a new backoff is taken from the policy.
- wrap(BytesReference) - Static method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- wrap(CheckedConsumer<Response, ? extends Exception>, Consumer<Exception>) - Static method in interface org.elasticsearch.action.ActionListener
-
Creates a listener that listens for a response (or failure) and executes the corresponding consumer when the response (or failure) is received.
- wrap(CheckedConsumer<Response, ? extends Exception>, Consumer<Exception>, Consumer<Exception>) - Static method in interface org.elasticsearch.index.reindex.RejectAwareActionListener
-
Similar to
ActionListener.wrap(CheckedConsumer, Consumer)
, extended to have handler for onRejection. - wrap(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.BestBucketsDeferringCollector
-
Wrap the provided aggregator so that it behaves (almost) as if it had been collected directly.
- wrap(Aggregator) - Method in class org.elasticsearch.search.aggregations.bucket.DeferringBucketCollector
-
Wrap the provided aggregator so that it behaves (almost) as if it had been collected directly.
- wrapAllDocsLive(DirectoryReader) - Static method in class org.elasticsearch.common.lucene.Lucene
-
Wraps a directory reader to make all documents live except those were rolled back or hard-deleted due to non-aborting exceptions during indexing.
- wrapAnalyzer(Analyzer, Integer) - Method in class org.elasticsearch.search.fetch.subphase.highlight.UnifiedHighlighter
- wrapAsCancellable(Future<?>) - Static method in interface org.elasticsearch.threadpool.Scheduler
-
Utility method to wrap a
Future
as aCancellable
- wrapAsScheduledCancellable(ScheduledFuture<?>) - Static method in interface org.elasticsearch.threadpool.Scheduler
-
Utility method to wrap a
ScheduledFuture
as aScheduledCancellable
- wrapBulkResponse(ActionListener<Response>) - Static method in class org.elasticsearch.action.bulk.TransportSingleItemBulkWriteAction
-
Deprecated.
- wrapChild(BlobContainer) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- wrapComponents(String, Analyzer.TokenStreamComponents) - Method in class org.elasticsearch.search.fetch.subphase.highlight.LimitTokenOffsetAnalyzer
- wrapLongitude - Variable in class org.elasticsearch.search.aggregations.metrics.InternalGeoBounds
- wrapLongitude() - Method in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
-
Get whether to wrap longitudes.
- wrapLongitude(boolean) - Method in class org.elasticsearch.search.aggregations.metrics.GeoBoundsAggregationBuilder
-
Set whether to wrap longitudes.
- WrappedRunnable - Interface in org.elasticsearch.common.util.concurrent
- Wrapper(Logger, Settings, ThreadPool) - Constructor for class org.elasticsearch.action.support.ThreadedActionListener.Wrapper
- Wrapper(IndexReader.CacheHelper) - Constructor for class org.elasticsearch.indices.ESCacheHelper.Wrapper
- Wrapper(BaseRestHandler) - Constructor for class org.elasticsearch.rest.BaseRestHandler.Wrapper
- wrapperQuery(byte[]) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query builder which allows building a query thanks to a JSON string or binary data.
- wrapperQuery(String) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query builder which allows building a query thanks to a JSON string or binary data.
- wrapperQuery(BytesReference) - Static method in class org.elasticsearch.index.query.QueryBuilders
-
A Query builder which allows building a query thanks to a JSON string or binary data.
- WrapperQueryBuilder - Class in org.elasticsearch.index.query
-
A Query builder which allows building a query given JSON string or binary data provided as input.
- WrapperQueryBuilder(byte[]) - Constructor for class org.elasticsearch.index.query.WrapperQueryBuilder
-
Creates a query builder given a query provided as a bytes array
- WrapperQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.WrapperQueryBuilder
-
Creates a query builder given a query provided as a string
- WrapperQueryBuilder(BytesReference) - Constructor for class org.elasticsearch.index.query.WrapperQueryBuilder
-
Creates a query builder given a query provided as a
BytesReference
- WrapperQueryBuilder(StreamInput) - Constructor for class org.elasticsearch.index.query.WrapperQueryBuilder
-
Read from a stream.
- WrappingProcessor - Interface in org.elasticsearch.ingest
-
A srapping processor is one that encapsulates an inner processor, or a processor that the wrapped processor enacts upon.
- wrapPreservingContext(ActionListener<R>, ThreadContext) - Static method in class org.elasticsearch.action.support.ContextPreservingActionListener
-
Wraps the provided action listener in a
ContextPreservingActionListener
that will also copy the response headers when theThreadContext.StoredContext
is closed - wrapReader(DirectoryReader, Function<DirectoryReader, DirectoryReader>, ESCacheHelper) - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- wrapRequest(DiscoveryNode, TransportRequest) - Static method in class org.elasticsearch.transport.TransportActionProxy
-
Wraps the actual request in a proxy request object that encodes the target node.
- wrapRestorable(ThreadContext.StoredContext) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
-
Same as
ThreadContext.newRestorableContext(boolean)
but wraps an existing context to restore. - wrapRunnable(Runnable) - Method in class org.elasticsearch.common.util.concurrent.EsThreadPoolExecutor
- wrapRunnable(Runnable) - Method in class org.elasticsearch.common.util.concurrent.PrioritizedEsThreadPoolExecutor
- wrapRunnable(Runnable) - Method in class org.elasticsearch.common.util.concurrent.QueueResizingEsThreadPoolExecutor
- wrapUnmodifiableOrEmptySingleton(List<E>) - Static method in class org.elasticsearch.common.util.CollectionUtils
- wrapWithTimeout(ThreadPool, ActionListener<Response>, TimeValue, String, String) - Static method in class org.elasticsearch.action.support.ListenerTimeouts
-
Wraps a listener with a listener that can timeout.
- wrapWithTimeout(ThreadPool, TimeValue, String, ActionListener<Response>, Consumer<ActionListener<Response>>) - Static method in class org.elasticsearch.action.support.ListenerTimeouts
-
Wraps a listener with a listener that can timeout.
- write(byte[]) - Method in class org.elasticsearch.common.lucene.store.IndexOutputOutputStream
- write(byte[]) - Method in class org.elasticsearch.transport.ReuseBuffersLZ4BlockOutputStream
- write(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- write(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.IndexOutputOutputStream
- write(byte[], int, int) - Method in class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
- write(byte[], int, int) - Method in class org.elasticsearch.transport.ReuseBuffersLZ4BlockOutputStream
- write(char) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Writes a single character.
- write(char[], int, int) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Writes a portion of an array of characters.
- write(int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- write(int) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Writes a character given its 31-bits Unicode.
- write(int) - Method in class org.elasticsearch.common.lucene.store.IndexOutputOutputStream
- write(int) - Method in class org.elasticsearch.repositories.blobstore.ChunkedBlobOutputStream
- write(int) - Method in class org.elasticsearch.transport.ReuseBuffersLZ4BlockOutputStream
- write(CharSequence) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Writes the specified character sequence.
- write(String, int, int) - Method in class org.elasticsearch.common.io.UTF8StreamWriter
-
Writes a portion of a string.
- write(List<Tuple<Item, Consumer<Exception>>>) - Method in class org.elasticsearch.common.util.concurrent.AsyncIOProcessor
-
Writes or processes the items out or to disk.
- write(Set<String>, StreamOutput) - Method in class org.elasticsearch.cluster.DiffableUtils.StringSetValueSerializer
- write(StreamOutput, V) - Method in interface org.elasticsearch.common.io.stream.Writeable.Writer
-
Write
V
-typevalue
to theout
put stream. - write(Rounding, StreamOutput) - Static method in class org.elasticsearch.common.rounding.Rounding.Streams
-
Deprecated.
- write(HttpPipelinedResponse, Listener) - Method in class org.elasticsearch.http.HttpPipeliningAggregator
- write(TDigestState, StreamOutput) - Static method in class org.elasticsearch.search.aggregations.metrics.TDigestState
- write(T, Path...) - Method in class org.elasticsearch.gateway.MetadataStateFormat
-
Writes the given state to the given directories.
- write(T, BlobContainer, String, boolean) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
-
Writes blob with resolving the blob name using
ChecksumBlobStoreFormat.blobName(java.lang.String)
method. - write(T, BlobContainer, String, boolean, Map<String, String>) - Method in class org.elasticsearch.repositories.blobstore.ChecksumBlobStoreFormat
-
Writes blob with resolving the blob name using
ChecksumBlobStoreFormat.blobName(java.lang.String)
method. - write(V, StreamOutput) - Method in class org.elasticsearch.cluster.DiffableUtils.DiffableValueSerializer
- write(V, StreamOutput) - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Writes value to stream
- WRITE - Enum constant in enum class org.elasticsearch.cluster.block.ClusterBlockLevel
- WRITE - Enum constant in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
- WRITE - Static variable in class org.elasticsearch.threadpool.ThreadPool.Names
- WRITE_CHUNK_SIZE - Static variable in class org.elasticsearch.common.io.Channels
-
The maximum chunk size for writes in bytes
- WRITE_DANGLING_INDICES_INFO_SETTING - Static variable in class org.elasticsearch.indices.IndicesService
- WRITE_DATA_STREAM_FIELD - Static variable in class org.elasticsearch.cluster.metadata.DataStreamAlias
- WRITE_PORTS_FILE_SETTING - Static variable in class org.elasticsearch.node.Node
- Writeable - Interface in org.elasticsearch.common.io.stream
-
Implementers can be written to a StreamOutput and read from a StreamInput.
- Writeable.Reader<V> - Interface in org.elasticsearch.common.io.stream
-
Reference to a method that can read some object from a stream.
- Writeable.Writer<V> - Interface in org.elasticsearch.common.io.stream
-
Reference to a method that can write some object to a
StreamOutput
. - WriteableZoneId - Class in org.elasticsearch.common.time
-
Simple wrapper around
ZoneId
so that it can be written to XContent - WriteableZoneId(ZoneId) - Constructor for class org.elasticsearch.common.time.WriteableZoneId
- WriteableZoneId(StreamInput) - Constructor for class org.elasticsearch.common.time.WriteableZoneId
- writeAdditionalFields(StreamOutput) - Method in class org.elasticsearch.cluster.routing.RecoverySource.ExistingStoreRecoverySource
- writeAdditionalFields(StreamOutput) - Method in class org.elasticsearch.cluster.routing.RecoverySource.SnapshotRecoverySource
- writeAdditionalFields(StreamOutput) - Method in class org.elasticsearch.cluster.routing.RecoverySource
-
to be overridden by subclasses
- writeAndCleanup(T, Path...) - Method in class org.elasticsearch.gateway.MetadataStateFormat
-
Writes the given state to the given directories and performs cleanup of old state files if the write succeeds or newly created state file if write fails.
- writeArray(Writeable.Writer<T>, T[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes the specified array to the stream using the specified
Writeable.Writer
for each element in the array. - writeArray(T[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes the specified array of
Writeable
s. - writeBlob(String, boolean, boolean, CheckedConsumer<OutputStream, IOException>) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Write a blob by providing a consumer that will write its contents to an output stream.
- writeBlob(String, boolean, boolean, CheckedConsumer<OutputStream, IOException>) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- writeBlob(String, boolean, boolean, CheckedConsumer<OutputStream, IOException>) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- writeBlob(String, InputStream, long, boolean) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Reads blob content from the input stream and writes it to the container in a new blob with the given name.
- writeBlob(String, InputStream, long, boolean) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- writeBlob(String, InputStream, long, boolean) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- writeBlob(String, BytesReference, boolean) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Reads blob content from a
BytesReference
and writes it to the container in a new blob with the given name. - writeBlob(String, BytesReference, boolean) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- writeBlobAtomic(String, BytesReference, boolean) - Method in interface org.elasticsearch.common.blobstore.BlobContainer
-
Reads blob content from a
BytesReference
and writes it to the container in a new blob with the given name, using an atomic write operation if the implementation supports it. - writeBlobAtomic(String, BytesReference, boolean) - Method in class org.elasticsearch.common.blobstore.fs.FsBlobContainer
- writeBlobAtomic(String, BytesReference, boolean) - Method in class org.elasticsearch.common.blobstore.support.FilterBlobContainer
- writeBoolean(boolean) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a boolean.
- writeBuild(Build, StreamOutput) - Static method in class org.elasticsearch.Build
- writeByte(byte) - Method in class org.elasticsearch.common.bytes.RecyclingBytesStreamOutput
- writeByte(byte) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- writeByte(byte) - Method in class org.elasticsearch.common.io.stream.DataOutputStreamOutput
- writeByte(byte) - Method in class org.elasticsearch.common.io.stream.OutputStreamStreamOutput
- writeByte(byte) - Method in class org.elasticsearch.common.io.stream.PositionTrackingOutputStreamStreamOutput
- writeByte(byte) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a single byte.
- writeByte(byte) - Method in class org.elasticsearch.common.lucene.store.FilterIndexOutput
- writeByte(byte) - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
- writeByteArray(byte[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an array of bytes.
- writeBytes(byte[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an array of bytes.
- writeBytes(byte[], int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an array of bytes.
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.bytes.RecyclingBytesStreamOutput
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.BytesStreamOutput
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.DataOutputStreamOutput
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.OutputStreamStreamOutput
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.PositionTrackingOutputStreamStreamOutput
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an array of bytes.
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.common.lucene.store.FilterIndexOutput
- writeBytes(byte[], int, int) - Method in class org.elasticsearch.index.translog.BufferedChecksumStreamOutput
- writeBytesRef(BytesRef) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeBytesReference(BytesReference) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes the bytes reference, including a length header.
- writeCollection(Collection<? extends Writeable>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a collection to this stream.
- writeCollection(Collection<T>, Writeable.Writer<T>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a collection of objects via a
Writeable.Writer
. - writeDanglingIndicesInfo() - Method in class org.elasticsearch.index.IndexService
- writeDiff(Diff<V>, StreamOutput) - Method in class org.elasticsearch.cluster.DiffableUtils.DiffableValueSerializer
- writeDiff(Diff<V>, StreamOutput) - Method in class org.elasticsearch.cluster.DiffableUtils.NonDiffableValueSerializer
- writeDiff(Diff<V>, StreamOutput) - Method in interface org.elasticsearch.cluster.DiffableUtils.ValueSerializer
-
Writes value as diff to stream if this serializer supports diffable values
- writeDocumentRequest(StreamOutput, DocWriteRequest<?>) - Static method in interface org.elasticsearch.action.DocWriteRequest
-
write a document write (index/delete/update) request
- writeDocumentRequestThin(StreamOutput, DocWriteRequest<?>) - Static method in interface org.elasticsearch.action.DocWriteRequest
-
write a document write (index/delete/update) request without shard id
- writeDouble(double) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeDoubleArray(double[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeDoubleLE(double, byte[], int) - Static method in enum class org.elasticsearch.common.util.ByteUtils
-
Write a double in little-endian format.
- writeEnum(E) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an enum with type E based on its ordinal value
- writeEnumSet(EnumSet<E>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an EnumSet with type E that by serialized it based on it's ordinal value
- writeException(Throwable) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeException(Throwable, StreamOutput) - Static method in exception org.elasticsearch.ElasticsearchException
- writeExplanation(StreamOutput, Explanation) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeFieldDoc(StreamOutput, FieldDoc) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeFieldStats(StreamOutput, ObjectObjectHashMap<String, CollectionStatistics>) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- writeFile(StoreFileMetadata, long, InputStream) - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
- writeFileChunk(StoreFileMetadata, long, ReleasableBytesReference, boolean) - Method in class org.elasticsearch.indices.recovery.MultiFileWriter
- writeFileChunk(StoreFileMetadata, long, ReleasableBytesReference, boolean, int, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RecoveryTarget
- writeFileChunk(StoreFileMetadata, long, ReleasableBytesReference, boolean, int, ActionListener<Void>) - Method in interface org.elasticsearch.indices.recovery.RecoveryTargetHandler
-
writes a partial file chunk to the target store
- writeFileChunk(StoreFileMetadata, long, ReleasableBytesReference, boolean, int, ActionListener<Void>) - Method in class org.elasticsearch.indices.recovery.RemoteRecoveryTargetHandler
- writeFloat(float) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeFloatArray(float[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeFloatLE(float, byte[], int) - Static method in enum class org.elasticsearch.common.util.ByteUtils
-
Write a float in little-endian format.
- writeFullStateAndCommit(long, ClusterState) - Method in class org.elasticsearch.gateway.PersistedClusterStateService.Writer
-
Overrides and commits the given current term and cluster state
- writeGenericValue(Object) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Notice: when serialization a map, the stream out map with the stream in map maybe have the different key-value orders, they will maybe have different stream order.
- writeGeometry(StreamOutput, Geometry) - Static method in class org.elasticsearch.common.geo.GeometryIO
- writeGeoPoint(GeoPoint) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes the given
GeoPoint
to the stream - writeHeader(StreamOutput, long, byte, Version, int, int) - Static method in class org.elasticsearch.transport.TcpHeader
- writeHistogramOrder(BucketOrder, StreamOutput, boolean) - Static method in class org.elasticsearch.search.aggregations.InternalOrder.Streams
-
ONLY FOR HISTOGRAM ORDER: Backwards compatibility logic to write a
BucketOrder
to a stream. - writeIncrementalTermUpdateAndCommit(long, long, Version) - Method in class org.elasticsearch.gateway.PersistedClusterStateService.Writer
- writeIndex() - Method in class org.elasticsearch.action.admin.indices.alias.Alias
- writeIndex() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- writeIndex() - Method in class org.elasticsearch.cluster.metadata.AliasAction.Add
- writeIndex() - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- writeIndex(Boolean) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
-
Sets whether an alias is pointing to a write-index
- writeIndex(Boolean) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- writeIndex(Boolean) - Method in class org.elasticsearch.cluster.metadata.AliasMetadata.Builder
- writeIndex(String, IndexMetadata) - Method in class org.elasticsearch.gateway.MetaStateService
-
Writes the index state.
- writeIndexGen(RepositoryData, long, Version, Function<ClusterState, ClusterState>, ActionListener<RepositoryData>) - Method in class org.elasticsearch.repositories.blobstore.BlobStoreRepository
-
Writing a new index generation is a three step process.
- writeIndexingBuffer() - Method in class org.elasticsearch.index.engine.Engine
-
Called when our engine is using too much heap and should move buffered indexed/deleted documents to disk.
- writeIndexingBuffer() - Method in class org.elasticsearch.index.engine.InternalEngine
- writeIndexingBuffer() - Method in class org.elasticsearch.index.engine.ReadOnlyEngine
- writeIndexingBuffer() - Method in class org.elasticsearch.index.shard.IndexShard
-
Called when our shard is using too much heap and should move buffered indexed/deleted documents to disk.
- writeIndexingBufferAsync(IndexShard) - Method in class org.elasticsearch.indices.IndexingMemoryController
-
ask this shard to refresh, in the background, to free up heap
- writeIndexOnly() - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- writeIndexOnly(boolean) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- writeIndicesOptions(StreamOutput) - Method in class org.elasticsearch.action.support.IndicesOptions
- writeInstant(Instant) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an
Instant
to the stream with nanosecond resolution - writeInt(int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an int as four bytes.
- writeIntArray(int[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeIntLE(int, byte[], int) - Static method in enum class org.elasticsearch.common.util.ByteUtils
-
Write an int in little-endian format.
- writeKey(K, StreamOutput) - Method in interface org.elasticsearch.cluster.DiffableUtils.KeySerializer
- writeKilobytes() - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- writeList(List<? extends Writeable>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a list of
Writeable
objects - writeLock - Variable in class org.elasticsearch.index.engine.Engine
- writeLock - Variable in class org.elasticsearch.index.translog.Translog
- writeLong(long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a long as eight bytes.
- writeLongArray(long[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeLongLE(long, byte[], int) - Static method in enum class org.elasticsearch.common.util.ByteUtils
-
Write a long in little-endian format.
- writeManifestAndCleanup(String, Manifest) - Method in class org.elasticsearch.gateway.MetaStateService
-
Writes manifest file (represented by
Manifest
) to disk and performs cleanup of old manifest state file if the write succeeds or newly created manifest state if the write fails. - writeMap(Map<String, Object>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeMap(Map<K, V>, Writeable.Writer<K>, Writeable.Writer<V>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeMap(ImmutableOpenMap<K, V>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeMap(ImmutableOpenMap<K, V>, Writeable.Writer<K>, Writeable.Writer<V>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeMapOfLists(Map<K, List<V>>, Writeable.Writer<K>, Writeable.Writer<V>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeMapWithConsistentOrder(Map<String, ? extends Object>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
write map to stream with consistent order to make sure every map generated bytes order are same.
- writeMultiLineFormat(MultiSearchRequest, XContent) - Static method in class org.elasticsearch.action.search.MultiSearchRequest
- writeNamedWriteable(NamedWriteable) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a
NamedWriteable
to the current stream, by first writing its name and then the object itself - writeNamedWriteableList(List<? extends NamedWriteable>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a list of
NamedWriteable
objects. - writeNodesTo(StreamOutput, List<NodeHotThreads>) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsResponse
- writeNodesTo(StreamOutput, List<NodeInfo>) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoResponse
- writeNodesTo(StreamOutput, List<NodesReloadSecureSettingsResponse.NodeResponse>) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse
- writeNodesTo(StreamOutput, List<NodeStats>) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
- writeNodesTo(StreamOutput, List<NodeUsage>) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageResponse
- writeNodesTo(StreamOutput, List<TransportNodesSnapshotsStatus.NodeSnapshotStatus>) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodesSnapshotStatus
- writeNodesTo(StreamOutput, List<ClusterStatsNodeResponse>) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- writeNodesTo(StreamOutput, List<NodeFindDanglingIndexResponse>) - Method in class org.elasticsearch.action.admin.indices.dangling.find.FindDanglingIndexResponse
- writeNodesTo(StreamOutput, List<NodeListDanglingIndicesResponse>) - Method in class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesResponse
- writeNodesTo(StreamOutput, List<TransportNodesListGatewayMetaState.NodeGatewayMetaState>) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodesGatewayMetaState
- writeNodesTo(StreamOutput, List<TransportNodesListGatewayStartedShards.NodeGatewayStartedShards>) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodesGatewayStartedShards
- writeNodesTo(StreamOutput, List<TransportNodesListShardStoreMetadata.NodeStoreFilesMetadata>) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodesStoreFilesMetadata
- writeNodesTo(StreamOutput, List<TNodeResponse>) - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
-
Write the
BaseNodesResponse.nodes
to the stream. - writeOperation(StreamOutput, Translog.Operation) - Static method in interface org.elasticsearch.index.translog.Translog.Operation
-
Writes the type and translog operation to the given stream
- writeOperationNoSize(BufferedChecksumStreamOutput, Translog.Operation) - Static method in class org.elasticsearch.index.translog.Translog
- writeOperations() - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- writeOperations(StreamOutput, List<Translog.Operation>) - Static method in class org.elasticsearch.index.translog.Translog
-
Writes all operations in the given iterable to the given output stream including the size of the array use
Translog.readOperations(StreamInput, String)
to read it back. - writeOptionalArray(Writeable.Writer<T>, T[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Same as
StreamOutput.writeArray(Writer, Object[])
but the provided array may be null. - writeOptionalArray(T[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Same as
StreamOutput.writeArray(Writeable[])
but the provided array may be null. - writeOptionalBoolean(Boolean) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalBytesReference(BytesReference) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an optional bytes reference including a length header.
- writeOptionalDouble(Double) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalEnum(E) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an optional enum with type E based on its ordinal value
- writeOptionalFloat(Float) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalInstant(Instant) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an
Instant
to the stream, which could possibly be null - writeOptionalInt(Integer) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an optional
Integer
. - writeOptionalLong(Long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalNamedWriteable(NamedWriteable) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write an optional
NamedWriteable
to the stream. - writeOptionalSecureString(SecureString) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalString(String) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalStringArray(String[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a string array, for nullable string, writes false.
- writeOptionalStringCollection(Collection<String>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an optional collection of a strings.
- writeOptionalText(Text) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalTimeValue(TimeValue) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write an optional
TimeValue
to the stream. - writeOptionalTimeZone(DateTimeZone) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write an optional DateTimeZone to the stream.
- writeOptionalVInt(Integer) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalVLong(Long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalWriteable(Writeable) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeOptionalZoneId(ZoneId) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write an optional ZoneId to the stream.
- writeOrder(BucketOrder, StreamOutput) - Static method in class org.elasticsearch.search.aggregations.InternalOrder.Streams
-
Write a
BucketOrder
to aStreamOutput
. - writeOriginalIndices(OriginalIndices, StreamOutput) - Static method in class org.elasticsearch.action.OriginalIndices
- writeOtherStatsTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalExtendedStats
- writeOtherStatsTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.InternalStats
- WritePrimaryResult(ReplicaRequest, Response, Translog.Location, Exception, IndexShard, Logger) - Constructor for class org.elasticsearch.action.support.replication.TransportWriteAction.WritePrimaryResult
- writeRawField(String, BytesReference, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Deprecated.use
XContentHelper.writeRawField(String, BytesReference, XContentType, XContentBuilder, Params)
to avoid content type auto-detection - writeRawField(String, BytesReference, XContentType, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Writes a "raw" (bytes) field, handling cases where the bytes are compressed, and tries to optimize writing using
XContentBuilder.rawField(String, InputStream, XContentType)
. - WriteReplicaResult(ReplicaRequest, Translog.Location, Exception, IndexShard, Logger) - Constructor for class org.elasticsearch.action.support.replication.TransportWriteAction.WriteReplicaResult
- WriteRequest<R extends WriteRequest<R>> - Interface in org.elasticsearch.action.support
-
Interface implemented by requests that modify the documents in an index like
IndexRequest
,UpdateRequest
, andBulkRequest
. - WriteRequest.RefreshPolicy - Enum Class in org.elasticsearch.action.support
- WriteRequestBuilder<B extends WriteRequestBuilder<B>> - Interface in org.elasticsearch.action.support
- WriteResponse - Interface in org.elasticsearch.action.support
-
Interface implemented by responses for actions that modify the documents in an index like
IndexResponse
,UpdateResponse
, andBulkResponse
. - writerSegmentStats(SegmentsStats) - Method in class org.elasticsearch.index.engine.Engine
- writerSegmentStats(SegmentsStats) - Method in class org.elasticsearch.index.engine.InternalEngine
- writerUuid() - Method in class org.elasticsearch.index.store.StoreFileMetadata
-
Returns the globally-unique ID that was assigned by the
IndexWriter
that originally wrote this file: - For `segments_N` files this isSegmentInfos.getId()
which uniquely identifies the commit. - writeScoreDoc(StreamOutput, ScoreDoc) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeSearchRequestParams(SearchRequest, XContentBuilder) - Static method in class org.elasticsearch.action.search.MultiSearchRequest
- writeSecureString(SecureString) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeSettingsToStream(Settings, StreamOutput) - Static method in class org.elasticsearch.common.settings.Settings
- writeShardsAcknowledged(StreamOutput) - Method in class org.elasticsearch.action.support.master.ShardsAcknowledgedResponse
- writeShort(short) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeSingleTermStats(StreamOutput, TermStatistics) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- writeSize(int, StreamOutput) - Static method in class org.elasticsearch.search.aggregations.InternalAggregation
-
Write a size under the assumption that a value of 0 means unlimited.
- writeSortField(StreamOutput, SortField) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeSortType(StreamOutput, SortField.Type) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeSortValue(StreamOutput, Object) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeStackTraces(Throwable, StreamOutput, Writeable.Writer<Throwable>) - Static method in exception org.elasticsearch.ElasticsearchException
-
Serializes the given exceptions stacktrace elements as well as it's suppressed exceptions to the given output stream.
- WriteStateException - Exception in org.elasticsearch.gateway
-
This exception is thrown when there is a problem of writing state to disk.
- writeString(String) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeStringArray(String[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeStringArrayNullable(String[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a string array, for nullable string, writes it as 0 (empty string).
- writeStringCollection(Collection<String>) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a collection of a strings.
- writeTermStats(StreamOutput, TermStatistics[]) - Static method in class org.elasticsearch.search.dfs.DfsSearchResult
- writeTermTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- writeTermTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- writeTermTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongRareTerms.Bucket
- writeTermTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.LongTerms.Bucket
- writeTermTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringRareTerms.Bucket
- writeTermTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.StringTerms.Bucket
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedRareTerms
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedSignificantTerms
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalMappedTerms
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalSignificantTerms
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedRareTerms
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedSignificantTerms
- writeTermTypeInfoTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.UnmappedTerms
- writeText(Text) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeThin(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkItemRequest
- writeThin(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkItemResponse
- writeThin(StreamOutput) - Method in class org.elasticsearch.action.delete.DeleteRequest
- writeThin(StreamOutput) - Method in class org.elasticsearch.action.DocWriteResponse
- writeThin(StreamOutput) - Method in class org.elasticsearch.action.index.IndexRequest
- writeThin(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ReplicatedWriteRequest
- writeThin(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
-
Thin serialization that does not write
ReplicationRequest.shardId
and will only writeReplicationRequest.index
if it is different from the index name inReplicationRequest.shardId
. - writeThin(StreamOutput) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- writeThin(StreamOutput) - Method in class org.elasticsearch.action.update.UpdateRequest
- writeThin(StreamOutput) - Method in class org.elasticsearch.action.update.UpdateResponse
- writeThin(StreamOutput) - Method in class org.elasticsearch.transport.BytesTransportRequest
-
Writes the data in a "thin" manner, without the actual bytes, assumes the actual bytes will be appended right after this content.
- writeTimeValue(TimeValue) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write a
TimeValue
to the stream - writeTimeZone(DateTimeZone) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write a DateTimeZone to the stream.
- writeTo(long, StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.AbstractHyperLogLogPlusPlus
- writeTo(OutputStream) - Method in class org.elasticsearch.common.bytes.AbstractBytesReference
- writeTo(OutputStream) - Method in class org.elasticsearch.common.bytes.BytesArray
- writeTo(OutputStream) - Method in interface org.elasticsearch.common.bytes.BytesReference
-
Writes the bytes directly to the output stream.
- writeTo(OutputStream) - Method in class org.elasticsearch.common.bytes.CompositeBytesReference
- writeTo(OutputStream) - Method in class org.elasticsearch.common.bytes.ReleasableBytesReference
- writeTo(AllocationCommands, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.allocation.command.AllocationCommands
-
Writes
AllocationCommands
to aStreamOutput
- writeTo(RerouteExplanation, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.allocation.RerouteExplanation
- writeTo(RoutingExplanations, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.allocation.RoutingExplanations
-
Write the RoutingExplanations object
- writeTo(IndexShardRoutingTable, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ActionRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ActionResponse.Empty
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplainResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.allocation.ClusterAllocationExplanation
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.configuration.AddVotingConfigExclusionsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.configuration.ClearVotingConfigExclusionsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.FeatureUpgradeStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse.IndexInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.migration.GetFeatureUpgradeStatusResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse.Feature
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.migration.PostFeatureUpgradeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodeHotThreads
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction.NodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.info.PluginsAndModules
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction.NodeInfoRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.liveness.LivenessResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.reload.NodesReloadSecureSettingsResponse.NodeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.reload.TransportNodesReloadSecureSettingsAction.NodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction.NodeStatsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.cancel.CancelTasksRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.get.GetTaskResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.tasks.list.ListTasksResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodesUsageRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.usage.NodeUsage
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.node.usage.TransportNodesUsageAction.NodeUsageRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.remote.RemoteInfoResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.cleanup.CleanupRepositoryResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.delete.DeleteRepositoryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.get.GetRepositoriesResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse.NodeView
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.reroute.ClusterRerouteResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterGetSettingsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.settings.ClusterUpdateSettingsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsGroup
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.shards.ClusterSearchShardsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.clone.CloneSnapshotRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse.SnapshottableFeature
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.GetSnapshottableFeaturesResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse.ResetFeatureStateStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.features.ResetFeatureStateResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest.After
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.get.shard.GetShardSnapshotResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.restore.RestoreSnapshotResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotIndexShardStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotsStatusResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.SnapshotStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeSnapshotStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.AnalysisStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsNodeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.ClusterStatsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.FieldScriptStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.FieldStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.IndexFeatureStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.MappingStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.RuntimeFieldStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction.ClusterStatsNodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.stats.VersionStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.DeleteStoredScriptRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptContextResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetScriptLanguageResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.tasks.PendingClusterTasksResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.Alias
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.exists.AliasesExistResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.get.GetAliasesResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest.AliasActions
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeToken
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.AnalyzeTokenList
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.CharFilteredText
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.DetailAnalyzeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.analyze.AnalyzeAction.Response
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.IndexResult
- writeTo(StreamOutput) - Method in exception org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult.Failure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.close.CloseIndexResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.close.TransportVerifyShardBeforeCloseAction.ShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.dangling.DanglingIndexInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.dangling.delete.DeleteDanglingIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.dangling.find.FindDanglingIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.dangling.find.NodeFindDanglingIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.dangling.find.NodeFindDanglingIndexResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.dangling.import_index.ImportDanglingIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.dangling.list.ListDanglingIndicesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.dangling.list.NodeListDanglingIndicesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.dangling.list.NodeListDanglingIndicesResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.delete.DeleteIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.diskusage.AnalyzeIndexDiskUsageRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.diskusage.AnalyzeIndexDiskUsageResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats.PerFieldDiskUsage
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.diskusage.IndexDiskUsageStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.exists.types.TypesExistsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.flush.FlushRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.flush.ShardFlushRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.flush.SyncedFlushResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.forcemerge.ForceMergeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.get.GetIndexResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.get.GetMappingsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.open.OpenIndexResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockResult
- writeTo(StreamOutput) - Method in exception org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult.Failure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.readonly.TransportVerifyShardIndexBlockAction.ShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.recovery.RecoveryResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedAlias
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedDataStream
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.ResolvedIndex
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.resolve.ResolveIndexAction.Response
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxAgeCondition
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxDocsCondition
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxPrimaryShardSizeCondition
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.rollover.MaxSizeCondition
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.rollover.RolloverResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.segments.IndicesSegmentsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.segments.ShardSegments
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.settings.get.GetSettingsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresRequest
- writeTo(StreamOutput) - Method in exception org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.Failure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.StoreStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.shrink.ResizeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.CommonStatsFlags
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageShardResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.FieldUsageStatsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.IndexShardStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.IndicesStatsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.stats.ShardStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteComponentTemplateAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteComposableIndexTemplateAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.delete.DeleteIndexTemplateRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.get.GetComponentTemplateAction.Response
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.get.GetComposableIndexTemplateAction.Response
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.get.GetIndexTemplatesResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateIndexTemplateResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.post.SimulateTemplateAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.put.PutComponentTemplateAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.put.PutComposableIndexTemplateAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.template.put.PutIndexTemplateRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.ShardUpgradeStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.upgrade.get.UpgradeStatusResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.ShardUpgradeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.upgrade.post.UpgradeSettingsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.validate.query.QueryExplanation
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.validate.query.ValidateQueryResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkItemRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkItemResponse.Failure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkItemResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.bulk.BulkShardResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.datastreams.ModifyDataStreamsAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.delete.DeleteRequest
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.action.DocWriteResponse.Result
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.DocWriteResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.explain.ExplainRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.explain.ExplainResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilities
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesFailure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesIndexResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.fieldcaps.FieldCapabilitiesResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.fieldcaps.IndexFieldCapabilities
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.GetRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.GetResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetItemResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetRequest.Item
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetResponse.Failure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.get.MultiGetShardResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.index.IndexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.DeletePipelineRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.GetPipelineRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.GetPipelineResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.PutPipelineRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.SimulateDocumentBaseResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.SimulateDocumentVerboseResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.SimulatePipelineRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.SimulatePipelineResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.ingest.SimulateProcessorResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.main.MainResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.resync.ResyncReplicationRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.CanMatchNodeRequest.Shard
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.CanMatchNodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.CanMatchNodeResponse.ResponseOrFailure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.CanMatchNodeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.ClearScrollRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.ClearScrollResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.ClosePointInTimeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.MultiSearchRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.MultiSearchResponse.Item
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.MultiSearchResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.OpenPointInTimeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.OpenPointInTimeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchContextIdForNode
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchResponse.Clusters
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchResponseSections
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchScrollRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.search.SearchTransportService.SearchFreeContextResponse
- writeTo(StreamOutput) - Method in exception org.elasticsearch.action.search.ShardSearchFailure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.ActiveShardCount
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.BroadcastShardResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.EmptyResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.broadcast.node.TransportBroadcastByNodeAction.NodeRequest
- writeTo(StreamOutput) - Method in exception org.elasticsearch.action.support.DefaultShardOperationFailedException
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.master.AcknowledgedRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.master.AcknowledgedResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.master.info.ClusterInfoRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.master.MasterNodeReadRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.master.MasterNodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.nodes.BaseNodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.nodes.BaseNodeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.nodes.BaseNodesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.nodes.BaseNodesResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ReplicatedWriteRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ReplicationRequest
- writeTo(StreamOutput) - Method in exception org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ReplicationResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.ReplicationTask.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteReplicaRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ConcreteShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.replication.TransportReplicationAction.ReplicaResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.single.instance.InstanceShardOperationRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.single.shard.SingleShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.tasks.BaseTasksRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.tasks.BaseTasksResponse
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.action.support.WriteRequest.RefreshPolicy
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.TaskOperationFailure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsItemResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse.Failure
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.MultiTermVectorsShardResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest.FilterSettings
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.termvectors.TermVectorsResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.update.UpdateRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.action.update.UpdateResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.FailedShardEntry
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.action.shard.ShardStateAction.StartedShardEntry
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.block.ClusterBlock
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.block.ClusterBlocks
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.ClusterInfo.NodeAndPath
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.ClusterInfo.ReservedSpace
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.ClusterInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.ClusterName
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.ClusterState
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.ApplyCommitRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.ClusterStateSerializationStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfigExclusion
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata.VotingConfiguration
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.CoordinationMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownCondition
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.ElasticsearchNodeCommand.UnknownMetadataCustom
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.FollowersChecker.FollowerCheckRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.Join
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.JoinRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.PeersResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.PreVoteRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.PreVoteResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.PublishResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.PublishWithJoinResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.StartJoinRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.coordination.ValidateJoinRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.DiffableUtils.MapDiff
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.DiskUsage
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.cluster.health.ClusterHealthStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.health.ClusterIndexHealth
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.health.ClusterShardHealth
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.health.ClusterStateHealth
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.AliasMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.ComponentTemplate
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.ComponentTemplateMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate.DataStreamTemplate
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplate
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.ComposableIndexTemplateMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.DataStream.TimestampField
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.DataStream
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.DataStreamAction
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.DataStreamAlias
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.DataStreamMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap.DiffableStringMapDiff
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.DiffableStringMap
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.IndexGraveyardDiff
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard.Tombstone
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.IndexGraveyard
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.cluster.metadata.IndexMetadata.APIBlock
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.IndexMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.IndexTemplateMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.ItemUsage
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.MappingMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.Metadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata.NodeShutdownMetadataDiff
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.NodesShutdownMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.RepositoriesMetadata
-
Write this into the StreamOutput.
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.RepositoryMetadata
-
Writes repository metadata to stream output
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.ShutdownPersistentTasksStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.ShutdownPluginsStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.ShutdownShardMigrationStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.SingleNodeShutdownMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.Template
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.node.DiscoveryNode
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.RepositoryCleanupInProgress.Entry
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.RepositoryCleanupInProgress
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.RestoreInProgress.ShardRestoreStatus
-
Writes restore status to stream output
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.RestoreInProgress
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.AbstractAllocationDecision
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.command.AbstractAllocateAllocationCommand
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.command.BasePrimaryAllocationCommand
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.command.CancelAllocationCommand
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.command.MoveAllocationCommand
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Multi
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.decider.Decision.Single
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.MoveDecision
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult.ShardStoreInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.NodeAllocationResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.allocation.ShardAllocationDecision
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.AllocationId
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.RecoverySource
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.RoutingTable
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.ShardRouting
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.cluster.routing.UnassignedInfo.AllocationStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.routing.UnassignedInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.service.ClusterApplierRecordingService.Stats.Recording
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.service.ClusterApplierRecordingService.Stats
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.service.ClusterStateUpdateStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.service.PendingClusterTask
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress.Entry
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.cluster.SnapshotDeletionsInProgress.State
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.SnapshotDeletionsInProgress
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.Entry
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.SnapshotsInProgress.ShardSnapshotStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.SnapshotsInProgress
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.compress.CompressedXContent
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.document.DocumentField
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.FieldMemoryStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.geo.GeoBoundingBox
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.common.geo.GeoDistance
-
Writes an instance of a GeoDistance object to an output stream
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.common.geo.Orientation
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.common.geo.ShapeRelation
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.common.geo.SpatialStrategy
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.io.stream.DelayableWriteable.Serialized
- writeTo(StreamOutput) - Method in interface org.elasticsearch.common.io.stream.Writeable
-
Write this into the StreamOutput.
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.common.lucene.search.function.CombineFunction
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction.Modifier
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.common.lucene.search.function.FunctionScoreQuery.ScoreMode
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.Rounding
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.time.WriteableZoneId
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.transport.BoundTransportAddress
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.transport.TransportAddress
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.common.unit.ByteSizeUnit
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.unit.ByteSizeValue
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.common.unit.DistanceUnit
-
Write a
DistanceUnit
to aStreamOutput
. - writeTo(StreamOutput) - Method in class org.elasticsearch.common.unit.Fuzziness
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.unit.SizeValue
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.util.concurrent.ThreadContext
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.util.CuckooFilter
- writeTo(StreamOutput) - Method in class org.elasticsearch.common.util.SetBackedScalingCuckooFilter
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.DiscoveryStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.PeersRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection.MasterPingRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.MasterFaultDetection.MasterPingResponseResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.MembershipAction.JoinRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.MembershipAction.LeaveRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection.PingRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.NodesFaultDetection.PingResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.PendingClusterStateStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.PublishClusterStateAction.CommitClusterStateRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.PublishClusterStateStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.UnicastPingRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.UnicastZenPing.UnicastPingResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.ZenDiscovery.RejoinClusterRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.discovery.zen.ZenPing.PingResponse
- writeTo(StreamOutput) - Method in exception org.elasticsearch.ElasticsearchException
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.LocalAllocateDangledIndices.AllocateDangledRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.LocalAllocateDangledIndices.AllocateDangledResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayMetaState.NodeGatewayMetaState
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeGatewayStartedShards
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.NodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.gateway.TransportNodesListGatewayStartedShards.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.http.HttpInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.http.HttpStats.ClientStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.http.HttpStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.analysis.NameOrDefinition
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.cache.query.QueryCacheStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.cache.request.RequestCacheStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.engine.CommitStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.engine.Engine.CommitId
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.engine.Segment
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.engine.SegmentsStats.FileStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.engine.SegmentsStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.fielddata.FieldDataStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.flush.FlushStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.get.GetResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.get.GetStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.Index
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.merge.MergeStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.AbstractQueryBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.functionscore.FunctionScoreQueryBuilder.FilterFunctionBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.functionscore.ScoreFunctionBuilder
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.index.query.GeoExecType
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.index.query.GeoValidationMethod
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.InnerHitBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Combine
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Disjunction
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Fuzzy
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.IntervalFilter
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Match
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Prefix
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.IntervalsSourceProvider.Wildcard
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.MoreLikeThisQueryBuilder.Item
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.index.query.MultiMatchQueryBuilder.Type
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.index.query.Operator
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.query.SpanNearQueryBuilder.SpanGapQueryBuilder
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.index.query.ZeroTermsQueryOption
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.recovery.RecoveryStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.refresh.RefreshStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.AbstractBulkByScrollRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.AbstractBulkIndexByScrollRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.BulkByScrollResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.BulkByScrollTask.StatusOrException
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.ReindexRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.RemoteInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.ScrollableHitSource.SearchFailure
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.reindex.UpdateByQueryRequest
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.index.search.MatchQueryParser.Type
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.search.stats.FieldUsageStats.PerFieldUsageStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.search.stats.FieldUsageStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.search.stats.SearchStats.Stats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.search.stats.SearchStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.ReplicationTracker.CheckpointState
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.ReplicationTracker.PrimaryContext
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.RetentionLease
-
Writes a retention lease to a stream in a manner suitable for later reconstruction via
RetentionLease(StreamInput)
. - writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.RenewRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.RetentionLeaseActions.RemoveRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.RetentionLeaseBackgroundSyncAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.RetentionLeases
-
Writes a retention lease collection to a stream in a manner suitable for later reconstruction via
RetentionLeases(StreamInput)
(StreamInput)}. - writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.RetentionLeaseStats
-
Writes a retention lease stats object to a stream in a manner suitable for later reconstruction via
RetentionLeaseStats(StreamInput)
(StreamInput)}. - writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.RetentionLeaseSyncAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.seqno.SeqNoStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.DocsStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.IndexingStats.Stats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.IndexingStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.IndexLongFieldRange
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.PrimaryReplicaSyncer.ResyncTask.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.ShardCountStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.ShardId
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.ShardLongFieldRange
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.snapshots.blobstore.BlobStoreIndexShardSnapshot.FileInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.stats.IndexingPressureStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.store.Store.MetadataSnapshot
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.store.StoreFileMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.store.StoreStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.translog.TranslogStats
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.index.VersionType
- writeTo(StreamOutput) - Method in class org.elasticsearch.index.warmer.WarmerStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.breaker.AllCircuitBreakerStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.breaker.CircuitBreakerStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.flush.ShardsSyncedFlushResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.flush.SyncedFlushService.InFlightOpsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.flush.SyncedFlushService.PreShardSyncedFlushRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.flush.SyncedFlushService.ShardSyncedFlushResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.NodeIndicesStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryCleanFilesRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryFileChunkRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryFilesInfoRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoverySnapshotFileRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.FileDetail
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Index
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.RecoveryFilesDetails
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Timer
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.Translog
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState.VerifyIndex
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryState
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryTranslogOperationsRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.RecoveryTransportRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.ReestablishRecoveryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.recovery.StartRecoveryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.NodeStoreFilesMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.store.TransportNodesListShardStoreMetadata.StoreFilesMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.indices.TermsLookup
- writeTo(StreamOutput) - Method in class org.elasticsearch.ingest.IngestInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.ingest.IngestMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.ingest.IngestStats.Stats
- writeTo(StreamOutput) - Method in class org.elasticsearch.ingest.IngestStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.ingest.PipelineConfiguration
- writeTo(StreamOutput) - Method in class org.elasticsearch.ingest.ProcessorInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.fs.FsInfo.DeviceStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.fs.FsInfo.IoStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.fs.FsInfo.Path
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.fs.FsInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmInfo.Mem
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.BufferPool
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.Classes
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.MemoryPool
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup.CpuStat
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats.Cgroup
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats.Mem
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats.Swap
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.os.OsStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
- writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.node.AdaptiveSelectionStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.node.ResponseCollectorService.ComputedNodeStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.CompletionPersistentTaskAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.PersistentTaskResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata.PersistentTask
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.PersistentTasksCustomMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.PersistentTasksNodeService.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.RemovePersistentTaskAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.StartPersistentTaskAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.persistent.UpdatePersistentTaskStatusAction.Request
- writeTo(StreamOutput) - Method in class org.elasticsearch.plugins.PluginDescriptor
- writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.IndexId
- writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.RepositoryCleanupResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.RepositoryInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.RepositoryShardId
- writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.RepositoryStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.RepositoryStatsSnapshot
- writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.ShardGeneration
- writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.ShardSnapshotInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.ShardSnapshotResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.repositories.VerifyNodeRepositoryAction.VerifyNodeRepositoryRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.Script
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.ScriptCacheStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo.ParameterInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.ScriptContextInfo.ScriptMethodInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.ScriptContextInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.ScriptContextStats.TimeSeries
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.ScriptContextStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.ScriptLanguagesInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.ScriptMetadata
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.ScriptStats
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.script.ScriptType
- writeTo(StreamOutput) - Method in class org.elasticsearch.script.StoredScriptSource
-
Writes a
StoredScriptSource
to a stream. - writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.AbstractAggregationBuilder
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.aggregations.Aggregator.SubAggCollectionMode
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.AggregatorFactories.Builder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.AdjacencyMatrixAggregator.KeyedFilter
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.adjacency.InternalAdjacencyMatrix.InternalBucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.composite.InternalComposite.InternalBucket
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.aggregations.bucket.composite.MissingOrder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.filter.FiltersAggregator.KeyedFilter
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.filter.InternalFilters.InternalBucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.geogrid.InternalGeoGridBucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.AutoDateHistogramAggregationBuilder.RoundingInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper.IntervalTypeEnum
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DateIntervalWrapper
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.DoubleBounds
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalAutoDateHistogram.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalDateHistogram.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalHistogram.EmptyBucketInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket.BucketBounds
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.InternalVariableWidthHistogram.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.histogram.LongBounds
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.GeoDistanceAggregationBuilder.Range
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalBinaryRange.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.InternalRange.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.range.RangeAggregator.Range
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.GND
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.JLHScore
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.NXYSignificanceHeuristic
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.PercentageScore
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.IncludeExclude
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalRareTerms.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.InternalTerms.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantLongTerms.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.SignificantStringTerms.Bucket
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.bucket.terms.TermsAggregator.BucketCountThresholds
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.BucketOrder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.InternalAggregation
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.InternalAggregations
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.Hdr
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig.TDigest
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.metrics.PercentilesConfig
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.aggregations.metrics.PercentilesMethod
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.AbstractPipelineAggregationBuilder
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.aggregations.pipeline.BucketHelpers.GapPolicy
-
Serialize the GapPolicy to the output stream
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.EwmaModel
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltLinearModel
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel.SeasonalityType
-
Serialize the SeasonalityType to the output stream
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.HoltWintersModel
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.LinearModel
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.MovAvgModel
-
Write the model to the output stream
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.PipelineAggregator
-
Deprecated.pipeline aggregations added after 7.8.0 shouldn't call this
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.pipeline.SimpleModel
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.AggregationInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.aggregations.support.MultiValuesSourceFieldConfig
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.aggregations.support.ValueType
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.builder.PointInTimeBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.IndexBoost
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder.ScriptField
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.CanMatchShardResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.collapse.CollapseBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.dfs.AggregatedDfs
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.DocValueFormat.BinaryDocValueFormat
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.DocValueFormat.BooleanDocValueFormat
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.DocValueFormat.DateTime
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.DocValueFormat.Decimal
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.DocValueFormat.GeoHashDocValueFormat
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.DocValueFormat.GeoTileDocValueFormat
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.DocValueFormat.IpDocValueFormat
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.DocValueFormat.RawDocValueFormat
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.DocValueFormat.UnsignedLongShiftedDocValueFormat
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.FetchSearchResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.ScrollQueryFetchSearchResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.ShardFetchRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.ShardFetchSearchRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.StoredFieldsContext
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.subphase.FetchSourceContext
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.subphase.FieldAndFormat
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.subphase.highlight.AbstractHighlighterBuilder
-
write common parameters to
StreamOutput
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.BoundaryScannerType
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.fetch.subphase.highlight.HighlightBuilder.Order
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.fetch.subphase.highlight.HighlightField
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.AliasFilter
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalSearchResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.ShardSearchContextId
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.ShardSearchRequest
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.MultiValueMode
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.profile.aggregation.AggregationProfileShardResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.profile.ProfileResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.profile.query.CollectorResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.profile.query.QueryProfileShardResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.profile.SearchProfileQueryPhaseResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.profile.SearchProfileResults
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.profile.SearchProfileShardResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.query.QuerySearchRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.query.QuerySearchResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.query.ScrollQuerySearchResult
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.rescore.QueryRescoreMode
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.rescore.RescorerBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.RescoreDocIds
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.Scroll
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.searchafter.SearchAfterBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchHit.NestedIdentity
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchHit
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchHits
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchPhaseResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchShardTarget
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchSortValues
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchSortValuesAndFormats
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.slice.SliceBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.sort.FieldSortBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.sort.GeoDistanceSortBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.sort.MinAndMax
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.sort.NestedSortBuilder
-
Write this object's fields to a StreamOutput.
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.sort.ScoreSortBuilder
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.sort.ScriptSortBuilder.ScriptSortType
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.sort.ScriptSortBuilder
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.sort.SortMode
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.sort.SortOrder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.completion.CompletionStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion.Entry.Option
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.completion.CompletionSuggestion
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.completion.FuzzyOptions
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.completion.RegexOptions
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.phrase.DirectCandidateGeneratorBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.phrase.Laplace
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.phrase.LinearInterpolation
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.phrase.PhraseSuggestion.Entry
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.phrase.StupidBackoff
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.suggest.SortBy
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry.Option
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion.Entry
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest.Suggestion
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.Suggest
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.SuggestBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.SuggestionBuilder
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion.Entry.Option
- writeTo(StreamOutput) - Method in class org.elasticsearch.search.suggest.term.TermSuggestion
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.StringDistanceImpl
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.search.suggest.term.TermSuggestionBuilder.SuggestMode
- writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.RestoreInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.Snapshot
- writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.SnapshotFeatureInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.SnapshotId
- writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.SnapshotInfo.IndexSnapshotDetails
- writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.SnapshotInfo
- writeTo(StreamOutput) - Method in exception org.elasticsearch.snapshots.SnapshotShardFailure
- writeTo(StreamOutput) - Method in class org.elasticsearch.snapshots.UpdateIndexShardSnapshotStatusRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.tasks.RawTaskStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.tasks.TaskId
- writeTo(StreamOutput) - Method in class org.elasticsearch.tasks.TaskInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.tasks.TaskResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.threadpool.ThreadPool.Info
- writeTo(StreamOutput) - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.threadpool.ThreadPoolStats.Stats
- writeTo(StreamOutput) - Method in class org.elasticsearch.threadpool.ThreadPoolStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.BytesTransportRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.ProxyConnectionStrategy.ProxyModeInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.RemoteConnectionInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.SniffConnectionStrategy.SniffModeInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportInfo
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportResponse.Empty
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportService.HandshakeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.transport.TransportStats
- writeTo(StreamOutput) - Method in class org.elasticsearch.upgrades.FeatureMigrationResults.ResultsDiff
- writeTo(StreamOutput) - Method in class org.elasticsearch.upgrades.FeatureMigrationResults
- writeTo(StreamOutput) - Method in class org.elasticsearch.upgrades.SingleFeatureMigrationResult
- writeTo(StreamOutput) - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskParams
- writeTo(StreamOutput) - Method in class org.elasticsearch.upgrades.SystemIndexMigrationTaskState
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.action.FailedNodeException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.action.RoutingMissingException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.action.search.SearchPhaseExecutionException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.action.TimestampParsingException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.cluster.block.ClusterBlockException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.common.breaker.CircuitBreakingException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.common.io.stream.NotSerializableExceptionWrapper
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.common.ParsingException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.ElasticsearchException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.ElasticsearchStatusException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.index.engine.RecoveryEngineException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.index.shard.IllegalIndexShardStateException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.indices.IndexTemplateMissingException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.indices.InvalidIndexTemplateException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.repositories.RepositoryException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.script.ScriptException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.search.SearchContextMissingException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.search.SearchException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.search.SearchParseException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.snapshots.SnapshotException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.transport.ActionNotFoundTransportException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.transport.ActionTransportException
- writeTo(StreamOutput, Writeable.Writer<Throwable>) - Method in exception org.elasticsearch.transport.ConnectTransportException
- writeTo(StreamOutput, RestStatus) - Static method in enum class org.elasticsearch.rest.RestStatus
- writeTo(Priority, StreamOutput) - Static method in enum class org.elasticsearch.common.Priority
- writeTo(CompositeValuesSourceBuilder<?>, StreamOutput) - Static method in class org.elasticsearch.search.aggregations.bucket.composite.CompositeValuesSourceParserHelper
- writeToChannel(byte[], int, int, FileChannel, long) - Static method in class org.elasticsearch.common.io.Channels
-
Writes part of a byte array to a
WritableByteChannel
at the provided position. - writeToChannel(byte[], int, int, WritableByteChannel) - Static method in class org.elasticsearch.common.io.Channels
-
Writes part of a byte array to a
WritableByteChannel
- writeToChannel(byte[], FileChannel, long) - Static method in class org.elasticsearch.common.io.Channels
-
Writes part of a byte array to a
WritableByteChannel
at the provided position. - writeToChannel(byte[], WritableByteChannel) - Static method in class org.elasticsearch.common.io.Channels
-
Writes part of a byte array to a
WritableByteChannel
- writeToChannel(ByteBuffer, WritableByteChannel) - Static method in class org.elasticsearch.common.io.Channels
-
Writes a
ByteBuffer
to aWritableByteChannel
- writeToNoId(StreamOutput) - Method in class org.elasticsearch.search.query.QuerySearchResult
- writeTopDocs(StreamOutput, TopDocsAndMaxScore) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeTotalHits(StreamOutput, TotalHits) - Static method in class org.elasticsearch.common.lucene.Lucene
- writeToThin(IndexShardRoutingTable, StreamOutput) - Static method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
- writeToThin(StreamOutput) - Method in class org.elasticsearch.cluster.routing.ShardRouting
-
Writes shard information to
StreamOutput
without writing index name and shard id - writeVersion(Version, StreamOutput) - Static method in class org.elasticsearch.Version
- writeVInt(int) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes an int in a variable-length format.
- writeVIntArray(int[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeVLong(long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a non-negative long in a variable-length format.
- writeVLongArray(long[]) - Method in class org.elasticsearch.common.io.stream.StreamOutput
- writeZLong(long) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Writes a long in a variable-length format.
- writeZoneId(ZoneId) - Method in class org.elasticsearch.common.io.stream.StreamOutput
-
Write a ZoneId to the stream.
- writtenBy() - Method in class org.elasticsearch.index.store.StoreFileMetadata
-
Returns a String representation of the Lucene version this file has been written by or
null
if unknown
X
- X_ELASTIC_PRODUCT_ORIGIN_HTTP_HEADER - Static variable in class org.elasticsearch.tasks.Task
-
A request header that indicates the origin of the request from Elastic stack.
- X_FIELD_NAME - Static variable in class org.elasticsearch.common.unit.Fuzziness
- X_OPAQUE_ID_FIELD_NAME - Static variable in class org.elasticsearch.common.logging.DeprecatedMessage
- X_OPAQUE_ID_HTTP_HEADER - Static variable in class org.elasticsearch.tasks.Task
-
The request header to mark tasks with specific ids
- XContentElasticsearchExtension - Class in org.elasticsearch.common.xcontent
-
SPI extensions for Elasticsearch-specific classes (like the Lucene or Joda dependency classes) that need to be encoded by
XContentBuilder
in a specific way. - XContentElasticsearchExtension() - Constructor for class org.elasticsearch.common.xcontent.XContentElasticsearchExtension
- XContentHelper - Class in org.elasticsearch.common.xcontent
- XContentHelper() - Constructor for class org.elasticsearch.common.xcontent.XContentHelper
- XContentMapValues - Class in org.elasticsearch.common.xcontent.support
- XContentMapValues() - Constructor for class org.elasticsearch.common.xcontent.support.XContentMapValues
- XContentParserUtils - Class in org.elasticsearch.common.xcontent
-
A set of static methods to get
XContentParser.Token
fromXContentParser
while checking for their types and throwParsingException
if needed. - xContentRegistry() - Method in class org.elasticsearch.index.IndexService
- xContentType() - Method in class org.elasticsearch.action.admin.cluster.storedscripts.PutStoredScriptRequest
- xContentType() - Method in class org.elasticsearch.action.termvectors.TermVectorsRequest
- xContentType(BytesReference) - Static method in class org.elasticsearch.common.xcontent.XContentHelper
-
Deprecated.the content type should not be guessed except for few cases where we effectively don't know the content type. The REST layer should move to reading the Content-Type header instead. There are other places where auto-detection may be needed. This method is deprecated to prevent usages of it from spreading further without specific reasons.
- XFieldComparatorSource(Object, MultiValueMode, IndexFieldData.XFieldComparatorSource.Nested) - Constructor for class org.elasticsearch.index.fielddata.IndexFieldData.XFieldComparatorSource
- XLatLonShape - Class in org.apache.lucene.document
-
This is a copy of the same class from Lucene used here as a way to access a modified version of Tessellator class.
- XLatLonShape.Triangle - Class in org.apache.lucene.document
- XMoreLikeThis - Class in org.elasticsearch.common.lucene.search
-
Generate "more like this" similarity queries.
- XMoreLikeThis(IndexReader) - Constructor for class org.elasticsearch.common.lucene.search.XMoreLikeThis
-
Constructor requiring an IndexReader.
- XMoreLikeThis(IndexReader, TFIDFSimilarity) - Constructor for class org.elasticsearch.common.lucene.search.XMoreLikeThis
- XQueryParser - Class in org.apache.lucene.queryparser.classic
-
This class is just a workaround to make
QueryParserBase.handleBareFuzzy(String, Token, String)
accessible by sub-classes. - XQueryParser(String, Analyzer) - Constructor for class org.apache.lucene.queryparser.classic.XQueryParser
- XTessellator - Class in org.apache.lucene.geo
-
This is a copy of a newer the version of same class from Lucene, one that includes a fix not yet released by Lucene.
- XTessellator.Node - Class in org.apache.lucene.geo
-
Circular Doubly-linked list used for polygon coordinates
- XTessellator.Triangle - Class in org.apache.lucene.geo
-
Triangle in the tessellated mesh
Y
- YARD - Enum constant in enum class org.elasticsearch.common.unit.DistanceUnit
- year() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a four digit year.
- YEAR - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- YEAR - Static variable in class org.elasticsearch.search.aggregations.bucket.histogram.DateHistogramInterval
- YEAR_MONTH - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- YEAR_MONTH_DAY - Enum constant in enum class org.elasticsearch.common.time.FormatNames
- YEAR_OF_CENTURY - Enum constant in enum class org.elasticsearch.common.rounding.DateTimeUnit
- YEAR_OF_CENTURY - Enum constant in enum class org.elasticsearch.common.Rounding.DateTimeUnit
- yearMonth() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a four digit year and two digit month of year.
- yearMonthDay() - Static method in class org.joda.time.format.StrictISODateTimeFormat
-
Returns a formatter for a four digit year, two digit month of year, and two digit day of month.
- YELLOW - Enum constant in enum class org.elasticsearch.cluster.health.ClusterHealthStatus
- yes(DiscoveryNode, String, List<NodeAllocationResult>, boolean) - Static method in class org.elasticsearch.cluster.routing.allocation.AllocateUnassignedDecision
-
Creates a YES decision with the given individual node-level decisions that comprised the final YES decision, along with the node id to which the shard is assigned and the allocation id for the shard, if available.
- YES - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.AllocationDecision
-
The shard can be allocated to a node.
- YES - Enum constant in enum class org.elasticsearch.cluster.routing.allocation.decider.Decision.Type
- YES - Enum constant in enum class org.elasticsearch.persistent.decider.AssignmentDecision.Type
- YES - Static variable in class org.elasticsearch.cluster.routing.allocation.decider.Decision
- YES - Static variable in class org.elasticsearch.persistent.decider.AssignmentDecision
- YOUNG - Static variable in class org.elasticsearch.monitor.jvm.GcNames
Z
- ZEN_DISCOVERY_TYPE - Static variable in class org.elasticsearch.discovery.DiscoveryModule
- ZEN1_BWC_TERM - Static variable in class org.elasticsearch.cluster.coordination.Coordinator
- ZEN2_DISCOVERY_TYPE - Static variable in class org.elasticsearch.discovery.DiscoveryModule
- ZenDiscovery - Class in org.elasticsearch.discovery.zen
- ZenDiscovery(Settings, ThreadPool, TransportService, NamedWriteableRegistry, MasterService, ClusterApplier, ClusterSettings, SeedHostsProvider, AllocationService, Collection<BiConsumer<DiscoveryNode, ClusterState>>, RerouteService) - Constructor for class org.elasticsearch.discovery.zen.ZenDiscovery
- ZenDiscovery.RejoinClusterRequest - Class in org.elasticsearch.discovery.zen
- zenPing - Variable in class org.elasticsearch.discovery.zen.ZenDiscovery
- ZenPing - Interface in org.elasticsearch.discovery.zen
- ZenPing.PingCollection - Class in org.elasticsearch.discovery.zen
-
a utility collection of pings where only the most recent ping is stored per node
- ZenPing.PingResponse - Class in org.elasticsearch.discovery.zen
- ZERO - Static variable in class org.elasticsearch.common.blobstore.DeleteResult
- ZERO - Static variable in class org.elasticsearch.common.unit.ByteSizeValue
- ZERO - Static variable in class org.elasticsearch.common.unit.Fuzziness
- ZERO - Static variable in class org.elasticsearch.common.unit.RelativeByteSizeValue
- ZERO_TERMS_QUERY_FIELD - Static variable in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- ZERO_TERMS_QUERY_FIELD - Static variable in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- ZERO_TERMS_QUERY_FIELD - Static variable in class org.elasticsearch.index.query.MatchQueryBuilder
- zeroTermsQuery - Variable in class org.elasticsearch.index.search.MatchQueryParser
- zeroTermsQuery() - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- zeroTermsQuery() - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
- zeroTermsQuery() - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
- zeroTermsQuery() - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Returns the setting for handling zero terms queries.
- zeroTermsQuery() - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- zeroTermsQuery(ZeroTermsQueryOption) - Method in class org.elasticsearch.index.query.CombinedFieldsQueryBuilder
- zeroTermsQuery(ZeroTermsQueryOption) - Method in class org.elasticsearch.index.query.MatchPhrasePrefixQueryBuilder
-
Sets query to use in case no query terms are available, e.g.
- zeroTermsQuery(ZeroTermsQueryOption) - Method in class org.elasticsearch.index.query.MatchPhraseQueryBuilder
-
Sets query to use in case no query terms are available, e.g.
- zeroTermsQuery(ZeroTermsQueryOption) - Method in class org.elasticsearch.index.query.MatchQueryBuilder
-
Sets query to use in case no query terms are available, e.g.
- zeroTermsQuery(ZeroTermsQueryOption) - Method in class org.elasticsearch.index.query.MultiMatchQueryBuilder
- ZeroTermsQueryOption - Enum Class in org.elasticsearch.index.query
- zigZagDecode(long) - Static method in enum class org.elasticsearch.common.util.ByteUtils
-
Zig-zag decode.
- zigZagEncode(long) - Static method in enum class org.elasticsearch.common.util.ByteUtils
-
Zig-zag encode: this helps transforming small signed numbers into small positive numbers.
- ZIP - Enum constant in enum class org.elasticsearch.Build.Type
- zone() - Method in class org.elasticsearch.common.joda.JodaDateFormatter
- zone() - Method in interface org.elasticsearch.common.time.DateFormatter
-
Returns the configured time zone of the date formatter
- zoneId() - Method in class org.elasticsearch.common.time.WriteableZoneId
- zoneIdToDateTimeZone(ZoneId) - Static method in class org.elasticsearch.common.time.DateUtils
_
- _getDocBaseId() - Method in class org.elasticsearch.script.ScoreScript
-
Starting a name with underscore, so that the user cannot access this function directly through a script It is only used within predefined painless functions.
- _getDocId() - Method in class org.elasticsearch.script.ScoreScript
-
Starting a name with underscore, so that the user cannot access this function directly through a script It is only used within predefined painless functions.
- _getIndex() - Method in class org.elasticsearch.script.ScoreScript
-
Starting a name with underscore, so that the user cannot access this function directly through a script It is only used within predefined painless functions.
- _getShardId() - Method in class org.elasticsearch.script.ScoreScript
-
Starting a name with underscore, so that the user cannot access this function directly through a script It is only used within predefined painless functions.
- _ID - Static variable in class org.elasticsearch.index.get.GetResult
- _ID_PARSE_FIELD - Static variable in class org.elasticsearch.action.admin.cluster.storedscripts.GetStoredScriptResponse
- _INDEX - Static variable in class org.elasticsearch.index.get.GetResult
- _NONE_ - Static variable in class org.elasticsearch.search.fetch.StoredFieldsContext
- _setIndexName(String) - Method in class org.elasticsearch.script.ScoreScript
-
Starting a name with underscore, so that the user cannot access this function directly through a script
- _setShard(int) - Method in class org.elasticsearch.script.ScoreScript
-
Starting a name with underscore, so that the user cannot access this function directly through a script
- _SHARDS_FIELD - Static variable in class org.elasticsearch.rest.action.RestActions
- _SOURCE_FIELD - Static variable in class org.elasticsearch.search.builder.SearchSourceBuilder
- _TYPE - Static variable in class org.elasticsearch.index.get.GetResult
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
AbstractGeometryQueryBuilder(String, String)
instead